From 7cbffad749a0f8917658406dae73c7fb7151b55d Mon Sep 17 00:00:00 2001 From: "release-please[bot]" <55107282+release-please[bot]@users.noreply.github.com> Date: Fri, 20 Dec 2024 16:48:17 -0800 Subject: [PATCH 01/16] chore(main): release storage 1.49.0 (#11273) Co-authored-by: release-please[bot] <55107282+release-please[bot]@users.noreply.github.com> --- .release-please-manifest-individual.json | 2 +- storage/CHANGES.md | 18 ++++++++++++++++++ storage/internal/version.go | 2 +- 3 files changed, 20 insertions(+), 2 deletions(-) diff --git a/.release-please-manifest-individual.json b/.release-please-manifest-individual.json index e87d33b35e1c..962a661cc2b5 100644 --- a/.release-please-manifest-individual.json +++ b/.release-please-manifest-individual.json @@ -11,6 +11,6 @@ "pubsub": "1.45.3", "pubsublite": "1.8.2", "spanner": "1.73.0", - "storage": "1.48.0", + "storage": "1.49.0", "vertexai": "0.13.3" } diff --git a/storage/CHANGES.md b/storage/CHANGES.md index dd1dc1c8970a..a1961604faef 100644 --- a/storage/CHANGES.md +++ b/storage/CHANGES.md @@ -1,6 +1,24 @@ # Changes +## [1.49.0](https://github.com/googleapis/google-cloud-go/compare/storage/v1.48.0...storage/v1.49.0) (2024-12-21) + + +### Features + +* **storage/internal:** Add finalize_time field in Object metadata ([46fc993](https://github.com/googleapis/google-cloud-go/commit/46fc993a3195203a230e2831bee456baaa9f7b1c)) +* **storage/internal:** Add MoveObject RPC ([46fc993](https://github.com/googleapis/google-cloud-go/commit/46fc993a3195203a230e2831bee456baaa9f7b1c)) +* **storage:** Add ObjectHandle.Move method ([#11302](https://github.com/googleapis/google-cloud-go/issues/11302)) ([a3cb8c4](https://github.com/googleapis/google-cloud-go/commit/a3cb8c4fc48883b54d4e830ae5f5ef4f1a3b8ca3)) +* **storage:** Return file metadata on read ([#11212](https://github.com/googleapis/google-cloud-go/issues/11212)) ([d49263b](https://github.com/googleapis/google-cloud-go/commit/d49263b2ab614cad801e26b4a169eafe08d4a2a0)) + + +### Bug Fixes + +* **storage/dataflux:** Address deadlock when reading from ranges ([#11303](https://github.com/googleapis/google-cloud-go/issues/11303)) ([32cbf56](https://github.com/googleapis/google-cloud-go/commit/32cbf561590541eb0387787bf729be6ddf68e4ee)) +* **storage:** Disable allow non-default credentials flag ([#11337](https://github.com/googleapis/google-cloud-go/issues/11337)) ([145ddf4](https://github.com/googleapis/google-cloud-go/commit/145ddf4f6123d9561856d2b6adeefdfae462b3f7)) +* **storage:** Monitored resource detection ([#11197](https://github.com/googleapis/google-cloud-go/issues/11197)) ([911bcd8](https://github.com/googleapis/google-cloud-go/commit/911bcd8b1816256482bd52e85da7eaf00c315293)) +* **storage:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.48.0](https://github.com/googleapis/google-cloud-go/compare/storage/v1.47.0...storage/v1.48.0) (2024-12-05) diff --git a/storage/internal/version.go b/storage/internal/version.go index 3e13b71a98c0..8e10894500bc 100644 --- a/storage/internal/version.go +++ b/storage/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.48.0" +const Version = "1.49.0" From e9a8e3ad04b655dcf202c989f0295892b62e2b37 Mon Sep 17 00:00:00 2001 From: rahul2393 Date: Mon, 23 Dec 2024 11:09:57 +0530 Subject: [PATCH 02/16] chore(spanner): track precommit token for R/W multiplexed session (#11229) * chore(spanner): add support for multiplexed session with read write transactions. * fix tests * incorporate changes * disable multiplxed session for ReadWrite only when unimplemented error is because of multiplex from server * re-trigger --- spanner/client.go | 80 +++++--- .../internal/testutil/inmem_spanner_server.go | 35 +++- spanner/kokoro/presubmit.sh | 1 + spanner/read.go | 47 +++-- spanner/session.go | 25 ++- spanner/transaction.go | 27 ++- spanner/transaction_test.go | 179 ++++++++++++++++++ 7 files changed, 333 insertions(+), 61 deletions(-) diff --git a/spanner/client.go b/spanner/client.go index ef53bafdb42c..1ce356266108 100644 --- a/spanner/client.go +++ b/spanner/client.go @@ -107,19 +107,20 @@ func parseDatabaseName(db string) (project, instance, database string, err error // Client is a client for reading and writing data to a Cloud Spanner database. // A client is safe to use concurrently, except for its Close method. type Client struct { - sc *sessionClient - idleSessions *sessionPool - logger *log.Logger - qo QueryOptions - ro ReadOptions - ao []ApplyOption - txo TransactionOptions - bwo BatchWriteOptions - ct *commonTags - disableRouteToLeader bool - dro *sppb.DirectedReadOptions - otConfig *openTelemetryConfig - metricsTracerFactory *builtinMetricsTracerFactory + sc *sessionClient + idleSessions *sessionPool + logger *log.Logger + qo QueryOptions + ro ReadOptions + ao []ApplyOption + txo TransactionOptions + bwo BatchWriteOptions + ct *commonTags + disableRouteToLeader bool + enableMultiplexedSessionForRW bool + dro *sppb.DirectedReadOptions + otConfig *openTelemetryConfig + metricsTracerFactory *builtinMetricsTracerFactory } // DatabaseName returns the full name of a database, e.g., @@ -487,6 +488,21 @@ func newClientWithConfig(ctx context.Context, database string, config ClientConf md.Append(endToEndTracingHeader, "true") } + if isMultiplexed := strings.ToLower(os.Getenv("GOOGLE_CLOUD_SPANNER_MULTIPLEXED_SESSIONS")); isMultiplexed != "" { + config.SessionPoolConfig.enableMultiplexSession, err = strconv.ParseBool(isMultiplexed) + if err != nil { + return nil, spannerErrorf(codes.InvalidArgument, "GOOGLE_CLOUD_SPANNER_MULTIPLEXED_SESSIONS must be either true or false") + } + } + //TODO: Uncomment this once the feature is enabled. + //if isMultiplexForRW := os.Getenv("GOOGLE_CLOUD_SPANNER_MULTIPLEXED_SESSIONS_FOR_RW"); isMultiplexForRW != "" { + // config.enableMultiplexedSessionForRW, err = strconv.ParseBool(isMultiplexForRW) + // if err != nil { + // return nil, spannerErrorf(codes.InvalidArgument, "GOOGLE_CLOUD_SPANNER_MULTIPLEXED_SESSIONS_FOR_RW must be either true or false") + // } + // config.enableMultiplexedSessionForRW = config.enableMultiplexedSessionForRW && config.SessionPoolConfig.enableMultiplexSession + //} + // Create a session client. sc := newSessionClient(pool, database, config.UserAgent, sessionLabels, config.DatabaseRole, config.DisableRouteToLeader, md, config.BatchTimeout, config.Logger, config.CallOptions) @@ -532,19 +548,20 @@ func newClientWithConfig(ctx context.Context, database string, config ClientConf } c = &Client{ - sc: sc, - idleSessions: sp, - logger: config.Logger, - qo: getQueryOptions(config.QueryOptions), - ro: config.ReadOptions, - ao: config.ApplyOptions, - txo: config.TransactionOptions, - bwo: config.BatchWriteOptions, - ct: getCommonTags(sc), - disableRouteToLeader: config.DisableRouteToLeader, - dro: config.DirectedReadOptions, - otConfig: otConfig, - metricsTracerFactory: metricsTracerFactory, + sc: sc, + idleSessions: sp, + logger: config.Logger, + qo: getQueryOptions(config.QueryOptions), + ro: config.ReadOptions, + ao: config.ApplyOptions, + txo: config.TransactionOptions, + bwo: config.BatchWriteOptions, + ct: getCommonTags(sc), + disableRouteToLeader: config.DisableRouteToLeader, + dro: config.DirectedReadOptions, + otConfig: otConfig, + metricsTracerFactory: metricsTracerFactory, + enableMultiplexedSessionForRW: config.enableMultiplexedSessionForRW, } return c, nil } @@ -1008,8 +1025,12 @@ func (c *Client) rwTransaction(ctx context.Context, f func(context.Context, *Rea err error ) if sh == nil || sh.getID() == "" || sh.getClient() == nil { - // Session handle hasn't been allocated or has been destroyed. - sh, err = c.idleSessions.take(ctx) + if c.enableMultiplexedSessionForRW { + sh, err = c.idleSessions.takeMultiplexed(ctx) + } else { + // Session handle hasn't been allocated or has been destroyed. + sh, err = c.idleSessions.take(ctx) + } if err != nil { // If session retrieval fails, just fail the transaction. return err @@ -1050,6 +1071,9 @@ func (c *Client) rwTransaction(ctx context.Context, f func(context.Context, *Rea resp, err = t.runInTransaction(ctx, f) return err }) + if isUnimplementedErrorForMultiplexedRW(err) { + c.enableMultiplexedSessionForRW = false + } return resp, err } diff --git a/spanner/internal/testutil/inmem_spanner_server.go b/spanner/internal/testutil/inmem_spanner_server.go index 08be3b21742c..86770e4d2948 100644 --- a/spanner/internal/testutil/inmem_spanner_server.go +++ b/spanner/internal/testutil/inmem_spanner_server.go @@ -25,6 +25,7 @@ import ( "sort" "strings" "sync" + "sync/atomic" "time" "cloud.google.com/go/spanner/apiv1/spannerpb" @@ -333,7 +334,8 @@ type inMemSpannerServer struct { // counters. transactionCounters map[string]*uint64 // The transactions that have been created on this mock server. - transactions map[string]*spannerpb.Transaction + transactions map[string]*spannerpb.Transaction + multiplexedSessionTransactionsToSeqNo map[string]*atomic.Int32 // The transactions that have been (manually) aborted on the server. abortedTransactions map[string]bool // The transactions that are marked as PartitionedDMLTransaction @@ -521,11 +523,25 @@ func (s *inMemSpannerServer) initDefaults() { s.sessions = make(map[string]*spannerpb.Session) s.sessionLastUseTime = make(map[string]time.Time) s.transactions = make(map[string]*spannerpb.Transaction) + s.multiplexedSessionTransactionsToSeqNo = make(map[string]*atomic.Int32) s.abortedTransactions = make(map[string]bool) s.partitionedDmlTransactions = make(map[string]bool) s.transactionCounters = make(map[string]*uint64) } +func (s *inMemSpannerServer) getPreCommitToken(transactionID, operation string) *spannerpb.MultiplexedSessionPrecommitToken { + s.mu.Lock() + defer s.mu.Unlock() + sequence, ok := s.multiplexedSessionTransactionsToSeqNo[transactionID] + if !ok { + return nil + } + return &spannerpb.MultiplexedSessionPrecommitToken{ + SeqNum: sequence.Add(1), + PrecommitToken: []byte(fmt.Sprintf("precommit-token-%v-%v", operation, sequence.Load())), + } +} + func (s *inMemSpannerServer) generateSessionNameLocked(database string, isMultiplexed bool) string { s.sessionCounter++ if isMultiplexed { @@ -597,6 +613,9 @@ func (s *inMemSpannerServer) beginTransaction(session *spannerpb.Session, option ReadTimestamp: getCurrentTimestamp(), } s.mu.Lock() + if options.GetReadWrite() != nil && session.Multiplexed { + s.multiplexedSessionTransactionsToSeqNo[id] = new(atomic.Int32) + } s.transactions[id] = res s.partitionedDmlTransactions[id] = options.GetPartitionedDml() != nil s.mu.Unlock() @@ -634,6 +653,7 @@ func (s *inMemSpannerServer) removeTransaction(tx *spannerpb.Transaction) { s.mu.Lock() defer s.mu.Unlock() delete(s.transactions, string(tx.Id)) + delete(s.multiplexedSessionTransactionsToSeqNo, string(tx.Id)) delete(s.partitionedDmlTransactions, string(tx.Id)) } @@ -870,9 +890,16 @@ func (s *inMemSpannerServer) ExecuteSql(ctx context.Context, req *spannerpb.Exec case StatementResultError: return nil, statementResult.Err case StatementResultResultSet: + + // if request's session is multiplexed and transaction is Read/Write then add Pre-commit Token in Metadata + if statementResult.ResultSet != nil { + statementResult.ResultSet.PrecommitToken = s.getPreCommitToken(string(id), "ResultSetPrecommitToken") + } return statementResult.ResultSet, nil case StatementResultUpdateCount: - return statementResult.convertUpdateCountToResultSet(!isPartitionedDml), nil + res := statementResult.convertUpdateCountToResultSet(!isPartitionedDml) + res.PrecommitToken = s.getPreCommitToken(string(id), "ResultSetPrecommitToken") + return res, nil } return nil, gstatus.Error(codes.Internal, "Unknown result type") } @@ -938,6 +965,9 @@ func (s *inMemSpannerServer) executeStreamingSQL(req *spannerpb.ExecuteSqlReques return nextPartialResultSetError.Err } } + // For every PartialResultSet, if request's session is multiplexed and transaction is Read/Write then add Pre-commit Token in Metadata + // and increment the sequence number + part.PrecommitToken = s.getPreCommitToken(string(id), "PartialResultSetPrecommitToken") if err := stream.Send(part); err != nil { return err } @@ -997,6 +1027,7 @@ func (s *inMemSpannerServer) ExecuteBatchDml(ctx context.Context, req *spannerpb resp.ResultSets[idx] = statementResult.convertUpdateCountToResultSet(!isPartitionedDml) } } + resp.PrecommitToken = s.getPreCommitToken(string(id), "ExecuteBatchDmlResponsePrecommitToken") return resp, nil } diff --git a/spanner/kokoro/presubmit.sh b/spanner/kokoro/presubmit.sh index f92440377a06..f5ac7c1b389a 100755 --- a/spanner/kokoro/presubmit.sh +++ b/spanner/kokoro/presubmit.sh @@ -46,6 +46,7 @@ exit_code=0 case $JOB_TYPE in integration-with-multiplexed-session ) GOOGLE_CLOUD_SPANNER_MULTIPLEXED_SESSIONS=true + GOOGLE_CLOUD_SPANNER_MULTIPLEXED_SESSIONS_FOR_RW=true echo "running presubmit with multiplexed sessions enabled: $GOOGLE_CLOUD_SPANNER_MULTIPLEXED_SESSIONS" ;; esac diff --git a/spanner/read.go b/spanner/read.go index 32c3f488050a..3e1ffaaccbc5 100644 --- a/spanner/read.go +++ b/spanner/read.go @@ -68,6 +68,7 @@ func stream( func(err error) error { return err }, + nil, setTimestamp, release, gsc, @@ -85,6 +86,7 @@ func streamWithReplaceSessionFunc( replaceSession func(ctx context.Context) error, setTransactionID func(transactionID), updateTxState func(err error) error, + updatePrecommitToken func(token *sppb.MultiplexedSessionPrecommitToken), setTimestamp func(time.Time), release func(error), gsc *grpcSpannerClient, @@ -92,14 +94,15 @@ func streamWithReplaceSessionFunc( ctx, cancel := context.WithCancel(ctx) ctx = trace.StartSpan(ctx, "cloud.google.com/go/spanner.RowIterator") return &RowIterator{ - meterTracerFactory: meterTracerFactory, - streamd: newResumableStreamDecoder(ctx, logger, rpc, replaceSession, gsc), - rowd: &partialResultSetDecoder{}, - setTransactionID: setTransactionID, - updateTxState: updateTxState, - setTimestamp: setTimestamp, - release: release, - cancel: cancel, + meterTracerFactory: meterTracerFactory, + streamd: newResumableStreamDecoder(ctx, logger, rpc, replaceSession, gsc), + rowd: &partialResultSetDecoder{}, + setTransactionID: setTransactionID, + updatePrecommitToken: updatePrecommitToken, + updateTxState: updateTxState, + setTimestamp: setTimestamp, + release: release, + cancel: cancel, } } @@ -130,18 +133,19 @@ type RowIterator struct { // RowIterator.Next() returned an error that is not equal to iterator.Done. Metadata *sppb.ResultSetMetadata - ctx context.Context - meterTracerFactory *builtinMetricsTracerFactory - streamd *resumableStreamDecoder - rowd *partialResultSetDecoder - setTransactionID func(transactionID) - updateTxState func(err error) error - setTimestamp func(time.Time) - release func(error) - cancel func() - err error - rows []*Row - sawStats bool + ctx context.Context + meterTracerFactory *builtinMetricsTracerFactory + streamd *resumableStreamDecoder + rowd *partialResultSetDecoder + setTransactionID func(transactionID) + updateTxState func(err error) error + updatePrecommitToken func(token *sppb.MultiplexedSessionPrecommitToken) + setTimestamp func(time.Time) + release func(error) + cancel func() + err error + rows []*Row + sawStats bool } // this is for safety from future changes to RowIterator making sure that it implements rowIterator interface. @@ -192,6 +196,9 @@ func (r *RowIterator) Next() (*Row, error) { } r.setTransactionID = nil } + if r.updatePrecommitToken != nil { + r.updatePrecommitToken(prs.GetPrecommitToken()) + } if prs.Stats != nil { r.sawStats = true r.QueryPlan = prs.Stats.QueryPlan diff --git a/spanner/session.go b/spanner/session.go index e07f67dedf3e..2165fdee04d8 100644 --- a/spanner/session.go +++ b/spanner/session.go @@ -24,7 +24,6 @@ import ( "log" "math" "math/rand" - "os" "runtime/debug" "strings" "sync" @@ -507,6 +506,11 @@ type SessionPoolConfig struct { // Defaults to false. TrackSessionHandles bool + enableMultiplexSession bool + + // enableMultiplexedSessionForRW is a flag to enable multiplexed session for read/write transactions, is used in testing + enableMultiplexedSessionForRW bool + // healthCheckSampleInterval is how often the health checker samples live // session (for use in maintaining session pool size). // @@ -699,10 +703,7 @@ func newSessionPool(sc *sessionClient, config SessionPoolConfig) (*sessionPool, if config.MultiplexSessionCheckInterval == 0 { config.MultiplexSessionCheckInterval = 10 * time.Minute } - isMultiplexed := strings.ToLower(os.Getenv("GOOGLE_CLOUD_SPANNER_MULTIPLEXED_SESSIONS")) - if isMultiplexed != "" && isMultiplexed != "true" && isMultiplexed != "false" { - return nil, spannerErrorf(codes.InvalidArgument, "GOOGLE_CLOUD_SPANNER_MULTIPLEXED_SESSIONS must be either true or false") - } + pool := &sessionPool{ sc: sc, valid: true, @@ -713,7 +714,7 @@ func newSessionPool(sc *sessionClient, config SessionPoolConfig) (*sessionPool, mw: newMaintenanceWindow(config.MaxOpened), rand: rand.New(rand.NewSource(time.Now().UnixNano())), otConfig: sc.otConfig, - enableMultiplexSession: isMultiplexed == "true", + enableMultiplexSession: config.enableMultiplexSession, } _, instance, database, err := parseDatabaseName(sc.database) @@ -1944,15 +1945,19 @@ func isSessionNotFoundError(err error) bool { return strings.Contains(err.Error(), "Session not found") } -// isUnimplementedError returns true if the gRPC error code is Unimplemented. func isUnimplementedError(err error) bool { if err == nil { return false } - if ErrCode(err) == codes.Unimplemented { - return true + return ErrCode(err) == codes.Unimplemented +} + +// isUnimplementedErrorForMultiplexedRW returns true if the gRPC error code is Unimplemented and related to use of multiplexed session with ReadWrite txn. +func isUnimplementedErrorForMultiplexedRW(err error) bool { + if err == nil { + return false } - return false + return ErrCode(err) == codes.Unimplemented && strings.Contains(err.Error(), "Transaction type read_write not supported with multiplexed sessions") } func isFailedInlineBeginTransaction(err error) bool { diff --git a/spanner/transaction.go b/spanner/transaction.go index f70b29050bb9..dbc1c5e969ef 100644 --- a/spanner/transaction.go +++ b/spanner/transaction.go @@ -50,6 +50,8 @@ type txReadEnv interface { getTransactionSelector() *sppb.TransactionSelector // sets the transactionID setTransactionID(id transactionID) + // updatePrecommitToken updates the precommit token for the transaction + updatePrecommitToken(token *sppb.MultiplexedSessionPrecommitToken) // sets the transaction's read timestamp setTimestamp(time.Time) // release should be called at the end of every transactional read to deal @@ -355,6 +357,7 @@ func (t *txReadOnly) ReadWithOptions(ctx context.Context, table string, keys Key func(err error) error { return t.updateTxState(err) }, + t.updatePrecommitToken, t.setTimestamp, t.release, client.(*grpcSpannerClient), @@ -643,6 +646,7 @@ func (t *txReadOnly) query(ctx context.Context, statement Statement, options Que func(err error) error { return t.updateTxState(err) }, + t.updatePrecommitToken, t.setTimestamp, t.release, client.(*grpcSpannerClient)) @@ -871,6 +875,11 @@ func (t *ReadOnlyTransaction) begin(ctx context.Context) error { return err } +// no-op for ReadOnlyTransaction. +func (t *ReadOnlyTransaction) updatePrecommitToken(token *sppb.MultiplexedSessionPrecommitToken) { + return +} + // acquire implements txReadEnv.acquire. func (t *ReadOnlyTransaction) acquire(ctx context.Context) (*sessionHandle, *sppb.TransactionSelector, error) { if err := checkNestedTxn(ctx); err != nil { @@ -1155,7 +1164,9 @@ type ReadWriteTransaction struct { // tx is the transaction ID in Cloud Spanner that uniquely identifies the // ReadWriteTransaction. It is set only once in ReadWriteTransaction.begin() // during the initialization of ReadWriteTransaction. - tx transactionID + tx transactionID + precommitToken *sppb.MultiplexedSessionPrecommitToken + // txReadyOrClosed is for broadcasting that transaction ID has been returned // by Cloud Spanner or that transaction is closed. txReadyOrClosed chan struct{} @@ -1252,6 +1263,7 @@ func (t *ReadWriteTransaction) update(ctx context.Context, stmt Statement, opts return 0, errInlineBeginTransactionFailed() } } + t.updatePrecommitToken(resultSet.GetPrecommitToken()) if resultSet.Stats == nil { return 0, spannerErrorf(codes.InvalidArgument, "query passed to Update: %q", stmt.SQL) } @@ -1371,6 +1383,7 @@ func (t *ReadWriteTransaction) batchUpdateWithOptions(ctx context.Context, stmts t.setTransactionID(nil) return counts, errInlineBeginTransactionFailed() } + t.updatePrecommitToken(resp.PrecommitToken) if resp.Status != nil && resp.Status.Code != 0 { return counts, t.txReadOnly.updateTxState(spannerError(codes.Code(uint32(resp.Status.Code)), resp.Status.Message)) } @@ -1486,6 +1499,17 @@ func (t *ReadWriteTransaction) setTransactionID(tx transactionID) { t.txReadyOrClosed = make(chan struct{}) } +func (t *ReadWriteTransaction) updatePrecommitToken(token *sppb.MultiplexedSessionPrecommitToken) { + if token == nil { + return + } + t.mu.Lock() + defer t.mu.Unlock() + if t.precommitToken == nil || token.SeqNum > t.precommitToken.SeqNum { + t.precommitToken = token + } +} + // release implements txReadEnv.release. func (t *ReadWriteTransaction) release(err error) { t.mu.Lock() @@ -1676,6 +1700,7 @@ func (t *ReadWriteTransaction) commit(ctx context.Context, options CommitOptions Transaction: &sppb.CommitRequest_TransactionId{ TransactionId: t.tx, }, + PrecommitToken: t.precommitToken, RequestOptions: createRequestOptions(t.txOpts.CommitPriority, "", t.txOpts.TransactionTag), Mutations: mPb, ReturnCommitStats: options.ReturnCommitStats, diff --git a/spanner/transaction_test.go b/spanner/transaction_test.go index 3c12ac7eca3c..1acd7f72f390 100644 --- a/spanner/transaction_test.go +++ b/spanner/transaction_test.go @@ -302,6 +302,185 @@ func TestReadWriteTransaction_ErrorReturned(t *testing.T) { } } +func TestClient_ReadWriteTransaction_UnimplementedErrorWithMultiplexedSessionSwitchesToRegular(t *testing.T) { + ctx := context.Background() + server, client, teardown := setupMockedTestServerWithConfig(t, ClientConfig{ + DisableNativeMetrics: true, + SessionPoolConfig: SessionPoolConfig{ + MinOpened: 1, + MaxOpened: 1, + enableMultiplexSession: true, + enableMultiplexedSessionForRW: true, + }, + }) + defer teardown() + + for _, sumulatdError := range []error{ + status.Error(codes.Unimplemented, "other Unimplemented error which should not turn off multiplexed session"), + status.Error(codes.Unimplemented, "Transaction type read_write not supported with multiplexed sessions")} { + server.TestSpanner.PutExecutionTime( + MethodExecuteStreamingSql, + SimulatedExecutionTime{Errors: []error{sumulatdError}}, + ) + _, err := client.ReadWriteTransaction(ctx, func(ctx context.Context, tx *ReadWriteTransaction) error { + iter := tx.Query(ctx, NewStatement(SelectFooFromBar)) + defer iter.Stop() + for { + _, err := iter.Next() + if err == iterator.Done { + break + } + if err != nil { + return err + } + } + return nil + }) + requests := drainRequestsFromServer(server.TestSpanner) + foundMultiplexedSession := false + for _, req := range requests { + if sqlReq, ok := req.(*sppb.ExecuteSqlRequest); ok { + if strings.Contains(sqlReq.Session, "multiplexed") { + foundMultiplexedSession = true + break + } + } + } + + // Assert that the error is an Unimplemented error. + if status.Code(err) != codes.Unimplemented { + t.Fatalf("Expected Unimplemented error, got: %v", err) + } + if !foundMultiplexedSession { + t.Fatalf("Expected first transaction to use a multiplexed session, but it did not") + } + server.TestSpanner.Reset() + } + + // Attempt a second read-write transaction. + _, err := client.ReadWriteTransaction(ctx, func(ctx context.Context, tx *ReadWriteTransaction) error { + iter := tx.Query(ctx, NewStatement(SelectFooFromBar)) + defer iter.Stop() + for { + _, err := iter.Next() + if err == iterator.Done { + break + } + if err != nil { + return err + } + } + return nil + }) + + if err != nil { + t.Fatalf("Unexpected error in second transaction: %v", err) + } + + // Check that the second transaction used a regular session. + requests := drainRequestsFromServer(server.TestSpanner) + foundMultiplexedSession := false + for _, req := range requests { + if sqlReq, ok := req.(*sppb.CommitRequest); ok { + if strings.Contains(sqlReq.Session, "multiplexed") { + foundMultiplexedSession = true + break + } + } + } + + if foundMultiplexedSession { + t.Fatalf("Expected second transaction to use a regular session, but it did not") + } +} + +func TestReadWriteTransaction_PrecommitToken(t *testing.T) { + t.Parallel() + ctx := context.Background() + server, client, teardown := setupMockedTestServerWithConfig(t, ClientConfig{ + DisableNativeMetrics: true, + SessionPoolConfig: SessionPoolConfig{ + MinOpened: 1, + MaxOpened: 1, + enableMultiplexSession: true, + enableMultiplexedSessionForRW: true, + }, + }) + defer teardown() + + type testCase struct { + name string + query bool + update bool + batchUpdate bool + expectedPrecommitToken string + expectedSequenceNumber int32 + } + + testCases := []testCase{ + {"Only Query", true, false, false, "PartialResultSetPrecommitToken", 3}, //since mock server is returning 3 rows + {"Query and Update", true, true, false, "ResultSetPrecommitToken", 4}, + {"Query, Update, and Batch Update", true, true, true, "ExecuteBatchDmlResponsePrecommitToken", 5}, + } + + for _, tc := range testCases { + t.Run(tc.name, func(t *testing.T) { + _, err := client.ReadWriteTransaction(ctx, func(ctx context.Context, tx *ReadWriteTransaction) error { + if tc.query { + iter := tx.Query(ctx, NewStatement(SelectSingerIDAlbumIDAlbumTitleFromAlbums)) + defer iter.Stop() + for { + _, err := iter.Next() + if err == iterator.Done { + break + } + if err != nil { + return err + } + } + } + + if tc.update { + if _, err := tx.Update(ctx, Statement{SQL: UpdateBarSetFoo}); err != nil { + return err + } + } + + if tc.batchUpdate { + if _, err := tx.BatchUpdate(ctx, []Statement{{SQL: UpdateBarSetFoo}}); err != nil { + return err + } + } + + return nil + }) + if err != nil { + t.Fatalf("%s failed: %v", tc.name, err) + } + + requests := drainRequestsFromServer(server.TestSpanner) + var commitReq *sppb.CommitRequest + for _, req := range requests { + if c, ok := req.(*sppb.CommitRequest); ok { + commitReq = c + break + } + } + if commitReq.PrecommitToken == nil || len(commitReq.PrecommitToken.GetPrecommitToken()) == 0 { + t.Fatalf("Expected commit request to contain a valid precommitToken, got: %v", commitReq.PrecommitToken) + } + // Validate that the precommit token contains the test argument. + if !strings.Contains(string(commitReq.PrecommitToken.GetPrecommitToken()), tc.expectedPrecommitToken) { + t.Fatalf("Precommit token does not contain the expected test argument") + } + // Validate that the sequence number is as expected. + if got, want := commitReq.PrecommitToken.GetSeqNum(), tc.expectedSequenceNumber; got != want { + t.Fatalf("Precommit token sequence number mismatch: got %d, want %d", got, want) + } + }) + } +} + func TestBatchDML_WithMultipleDML(t *testing.T) { t.Parallel() ctx := context.Background() From 1513106ba51540aef11a264d09e73f24350ad95b Mon Sep 17 00:00:00 2001 From: rahul2393 Date: Fri, 27 Dec 2024 10:48:04 +0530 Subject: [PATCH 03/16] test(spanner): skip failing tests on cloud-devel and staging (#11347) * test(spanner): skip failing tests on cloud-devel and staging * updated asserts to check for contains since we now are returning requestID with error message --- spanner/integration_test.go | 11 ++++++++++- 1 file changed, 10 insertions(+), 1 deletion(-) diff --git a/spanner/integration_test.go b/spanner/integration_test.go index 1988e40babf0..a2b441621f03 100644 --- a/spanner/integration_test.go +++ b/spanner/integration_test.go @@ -859,6 +859,8 @@ func TestIntegration_SingleUse_WithQueryOptions(t *testing.T) { func TestIntegration_TransactionWasStartedInDifferentSession(t *testing.T) { t.Parallel() + // TODO: unskip once https://b.corp.google.com/issues/309745482 is fixed + skipOnNonProd(t) ctx, cancel := context.WithTimeout(context.Background(), 5*time.Minute) defer cancel() @@ -5332,7 +5334,7 @@ func TestIntegration_Foreign_Key_Delete_Cascade_Action(t *testing.T) { t.Run(tt.name, func(t *testing.T) { gotErr := tt.test() // convert the error to lower case because resource names are in lower case for PG dialect. - if gotErr != nil && !strings.EqualFold(gotErr.Error(), tt.wantErr.Error()) { + if gotErr != nil && !strings.Contains(gotErr.Error(), tt.wantErr.Error()) { t.Errorf("FKDC error=%v, wantErr: %v", gotErr, tt.wantErr) } else { tt.validate() @@ -6220,6 +6222,13 @@ func skipUnsupportedPGTest(t *testing.T) { } } +func skipOnNonProd(t *testing.T) { + job := os.Getenv("JOB_TYPE") + if strings.Contains(job, "cloud-devel") || strings.Contains(job, "cloud-staging") { + t.Skip("Skipping test on non-production environment.") + } +} + func onlyRunForPGTest(t *testing.T) { if testDialect != adminpb.DatabaseDialect_POSTGRESQL { t.Skip("Skipping tests supported only in Postgres dialect.") From 6aa27dc79046df09e34e93044dbfe47cb3e9aa54 Mon Sep 17 00:00:00 2001 From: Baha Aiman Date: Fri, 27 Dec 2024 08:37:42 -0800 Subject: [PATCH 04/16] fix(bigtable): Correct the 'method' label value (#11350) --- bigtable/bigtable.go | 2 +- bigtable/metrics.go | 4 +++ bigtable/metrics_test.go | 59 ++++++++++++++++++++++++++++++++++++---- 3 files changed, 58 insertions(+), 7 deletions(-) diff --git a/bigtable/bigtable.go b/bigtable/bigtable.go index cde8834bafd2..0748672a597e 100644 --- a/bigtable/bigtable.go +++ b/bigtable/bigtable.go @@ -1605,7 +1605,7 @@ func gaxInvokeWithRecorder(ctx context.Context, mt *builtinMetricsTracer, method f func(ctx context.Context, headerMD, trailerMD *metadata.MD, _ gax.CallSettings) error, opts ...gax.CallOption) error { attemptHeaderMD := metadata.New(nil) attempTrailerMD := metadata.New(nil) - mt.method = method + mt.setMethod(method) var callWrapper func(context.Context, gax.CallSettings) error if !mt.builtInEnabled { diff --git a/bigtable/metrics.go b/bigtable/metrics.go index 5a3b817abf7c..b7ce660ba62c 100644 --- a/bigtable/metrics.go +++ b/bigtable/metrics.go @@ -293,6 +293,10 @@ type builtinMetricsTracer struct { currOp opTracer } +func (b *builtinMetricsTracer) setMethod(m string) { + b.method = "Bigtable." + m +} + // opTracer is used to record metrics for the entire operation, including retries. // Operation is a logical unit that represents a single method invocation on client. // The method might require multiple attempts/rpcs and backoff logic to complete diff --git a/bigtable/metrics_test.go b/bigtable/metrics_test.go index bb78829c027d..4ce4e5ddd51b 100644 --- a/bigtable/metrics_test.go +++ b/bigtable/metrics_test.go @@ -22,6 +22,7 @@ import ( "encoding/base64" "fmt" "io" + "slices" "sort" "strings" "sync" @@ -166,17 +167,17 @@ func TestNewBuiltinMetricsTracerFactory(t *testing.T) { }{ { desc: "should create a new tracer factory with default meter provider", - config: ClientConfig{}, + config: ClientConfig{AppProfile: appProfile}, wantBuiltinEnabled: true, wantCreateTSCallsCount: 2, }, { desc: "should create a new tracer factory with noop meter provider", - config: ClientConfig{MetricsProvider: NoopMetricsProvider{}}, + config: ClientConfig{MetricsProvider: NoopMetricsProvider{}, AppProfile: appProfile}, }, { desc: "should not create instruments when BIGTABLE_EMULATOR_HOST is set", - config: ClientConfig{}, + config: ClientConfig{AppProfile: appProfile}, setEmulator: true, }, } @@ -201,9 +202,8 @@ func TestNewBuiltinMetricsTracerFactory(t *testing.T) { t.Errorf("builtinEnabled: got: %v, want: %v", gotClient.metricsTracerFactory.enabled, test.wantBuiltinEnabled) } - if diff := testutil.Diff(gotClient.metricsTracerFactory.clientAttributes, wantClientAttributes, - cmpopts.IgnoreUnexported(attribute.KeyValue{}, attribute.Value{})); diff != "" { - t.Errorf("clientAttributes: got=-, want=+ \n%v", diff) + if !equalsKeyValue(gotClient.metricsTracerFactory.clientAttributes, wantClientAttributes) { + t.Errorf("clientAttributes: got: %+v, want: %+v", gotClient.metricsTracerFactory.clientAttributes, wantClientAttributes) } // Check instruments @@ -265,7 +265,26 @@ func TestNewBuiltinMetricsTracerFactory(t *testing.T) { for _, gotCreateTSCall := range gotCreateTSCalls { gotMetricTypes := []string{} for _, ts := range gotCreateTSCall.TimeSeries { + // ts.Metric.Type is of the form "bigtable.googleapis.com/internal/client/server_latencies" gotMetricTypes = append(gotMetricTypes, ts.Metric.Type) + + // Assert "streaming" metric label is correct + gotStreaming, gotStreamingExists := ts.Metric.Labels[metricLabelKeyStreamingOperation] + splitMetricType := strings.Split(ts.Metric.Type, "/") + internalMetricName := splitMetricType[len(splitMetricType)-1] // server_latencies + wantStreamingExists := slices.Contains(metricsDetails[internalMetricName].additionalAttrs, metricLabelKeyStreamingOperation) + if wantStreamingExists && (!gotStreamingExists || gotStreaming != "true") { + t.Errorf("Metric label key: %s, value: got: %v, want: %v", metricLabelKeyStreamingOperation, gotStreaming, "true") + } + if !wantStreamingExists && gotStreamingExists { + t.Errorf("Metric label key: %s exists, value: got: %v, want: %v", metricLabelKeyStreamingOperation, gotStreamingExists, wantStreamingExists) + } + + // Assert "method" metric label is correct + wantMethod := "Bigtable.ReadRows" + if gotLabel, ok := ts.Metric.Labels[metricLabelKeyMethod]; !ok || gotLabel != wantMethod { + t.Errorf("Metric label key: %s, value: got: %v, want: %v", metricLabelKeyMethod, gotLabel, wantMethod) + } } sort.Strings(gotMetricTypes) if !testutil.Equal(gotMetricTypes, wantMetricTypesGCM) { @@ -289,6 +308,34 @@ func setMockErrorHandler(t *testing.T, mockErrorHandler *MockErrorHandler) { }) } +func equalsKeyValue(gotAttrs, wantAttrs []attribute.KeyValue) bool { + if len(gotAttrs) != len(wantAttrs) { + return false + } + + gotJSONVals, err := keyValueToKeyJSONValue(gotAttrs) + if err != nil { + return false + } + wantJSONVals, err := keyValueToKeyJSONValue(wantAttrs) + if err != nil { + return false + } + return testutil.Equal(gotJSONVals, wantJSONVals) +} + +func keyValueToKeyJSONValue(attrs []attribute.KeyValue) (map[string]string, error) { + keyJSONVal := map[string]string{} + for _, attr := range attrs { + jsonVal, err := attr.Value.MarshalJSON() + if err != nil { + return nil, err + } + keyJSONVal[string(attr.Key)] = string(jsonVal) + } + return keyJSONVal, nil +} + func TestExporterLogs(t *testing.T) { ctx := context.Background() project := "test-project" From 8ebcc6d276fc881c3914b5a7af3265a04e718e45 Mon Sep 17 00:00:00 2001 From: "gcf-owl-bot[bot]" <78513119+gcf-owl-bot[bot]@users.noreply.github.com> Date: Mon, 30 Dec 2024 18:32:22 +0000 Subject: [PATCH 05/16] docs(batch): fix broken references in comments (#11316) - [ ] Regenerate this pull request now. PiperOrigin-RevId: 710060918 Source-Link: https://togithub.com/googleapis/googleapis/commit/f7314d1e02e7651b33985c65c2d268de7fbacc1e Source-Link: https://togithub.com/googleapis/googleapis-gen/commit/2dee5f1a153a1a447abccefe8aa81f692407724a Copy-Tag: eyJwIjoiLmdpdGh1Yi8uT3dsQm90LnlhbWwiLCJoIjoiMmRlZTVmMWExNTNhMWE0NDdhYmNjZWZlOGFhODFmNjkyNDA3NzI0YSJ9 BEGIN_NESTED_COMMIT feat(dataplex): A new field `force` is added to message `.google.cloud.dataplex.v1.DeleteDataScanRequest` docs(dataplex): miscellaneous doc updates PiperOrigin-RevId: 709139776 Source-Link: https://togithub.com/googleapis/googleapis/commit/9e966149c59f47f6305d66c98e2a9e7d9c26a2eb Source-Link: https://togithub.com/googleapis/googleapis-gen/commit/ef1103d3dc3d293694e12fc83d9aa116196160d4 Copy-Tag: eyJwIjoiLmdpdGh1Yi8uT3dsQm90LnlhbWwiLCJoIjoiZWYxMTAzZDNkYzNkMjkzNjk0ZTEyZmM4M2Q5YWExMTYxOTYxNjBkNCJ9 END_NESTED_COMMIT BEGIN_NESTED_COMMIT feat(aiplatform): add Model Garden deploy API docs(aiplatform): A comment for field `labels` in message `.google.cloud.aiplatform.v1beta1.PublisherModel` is changed PiperOrigin-RevId: 708446642 Source-Link: https://togithub.com/googleapis/googleapis/commit/960afb319265a0c1e109e39153563b3d2b21440c Source-Link: https://togithub.com/googleapis/googleapis-gen/commit/736b3d6b65dbb692245cb86218817f1351907cb4 Copy-Tag: eyJwIjoiLmdpdGh1Yi8uT3dsQm90LnlhbWwiLCJoIjoiNzM2YjNkNmI2NWRiYjY5MjI0NWNiODYyMTg4MTdmMTM1MTkwN2NiNCJ9 END_NESTED_COMMIT BEGIN_NESTED_COMMIT feat(gkemulticloud): added support for optionally disabling built-in GKE metrics feat(gkemulticloud): added tag bindings support for Attached Clusters docs(gkemulticloud): updated comments of existing fields PiperOrigin-RevId: 708397945 Source-Link: https://togithub.com/googleapis/googleapis/commit/09b3c838b7758dc3fc1dbcc9dc6d3d5516beb544 Source-Link: https://togithub.com/googleapis/googleapis-gen/commit/822c2acaf7af07dfbb7f86ce2e2e0f2e744b72e5 Copy-Tag: eyJwIjoiLmdpdGh1Yi8uT3dsQm90LnlhbWwiLCJoIjoiODIyYzJhY2FmN2FmMDdkZmJiN2Y4NmNlMmUyZTBmMmU3NDRiNzJlNSJ9 END_NESTED_COMMIT BEGIN_NESTED_COMMIT feat(shopping/css): UpdateCssProduct is added to CssProductInput proto docs(shopping/css): Mark `freshness_time` as deprecated docs : Mark `feed_id` as deprecated docs(shopping/css): A comment for field `page_size` in message `.google.shopping.css.v1.ListChildAccountsRequest` is changed docs(shopping/css): A comment for field `low_price` in message `.google.shopping.css.v1.Attributes` is changed docs(shopping/css): A comment for field `high_price` in message `.google.shopping.css.v1.Attributes` is changed docs(shopping/css): A comment for field `number_of_offers` in message `.google.shopping.css.v1.Attributes` is changed docs(shopping/css): A comment for field `headline_offer_price` in message `.google.shopping.css.v1.Attributes` is changed docs(shopping/css): A comment for field `headline_offer_shipping_price` in message `.google.shopping.css.v1.Attributes` is changed docs(shopping/css): A comment for field `approved_countries` in message `.google.shopping.css.v1.CssProductStatus` is changed docs(shopping/css): A comment for field `pending_countries` in message `.google.shopping.css.v1.CssProductStatus` is changed docs(shopping/css): A comment for field `disapproved_countries` in message `.google.shopping.css.v1.CssProductStatus` is changed docs(shopping/css): A comment for field `servability` in message `.google.shopping.css.v1.CssProductStatus` is changed docs(shopping/css): A comment for field `applicable_countries` in message `.google.shopping.css.v1.CssProductStatus` is changed docs(shopping/css): A comment for field `feed_id` in message`.google.shopping.css.v1.InsertCssProductInputRequest` is changed docs(shopping/css): A comment for message `CssProduct` is changed PiperOrigin-RevId: 708397816 Source-Link: https://togithub.com/googleapis/googleapis/commit/892e72fb31d9c063f9b992bfd923730094233ed0 Source-Link: https://togithub.com/googleapis/googleapis-gen/commit/09992f0d945beb092122fa1bdf453f5321bc0f8c Copy-Tag: eyJwIjoiLmdpdGh1Yi8uT3dsQm90LnlhbWwiLCJoIjoiMDk5OTJmMGQ5NDViZWIwOTIxMjJmYTFiZGY0NTNmNTMyMWJjMGY4YyJ9 END_NESTED_COMMIT BEGIN_NESTED_COMMIT feat(speech): expand the set of supported explicit audio encodings docs(speech): updated ExplicitDecodingConfig documentation to reflect changes related to newly supported encodings PiperOrigin-RevId: 708316885 Source-Link: https://togithub.com/googleapis/googleapis/commit/bf2a7ca1d46894df9ebccf5ad6338cbe9e21d9a8 Source-Link: https://togithub.com/googleapis/googleapis-gen/commit/4989c73469fea28e5181e961a83affff70b843b4 Copy-Tag: eyJwIjoiLmdpdGh1Yi8uT3dsQm90LnlhbWwiLCJoIjoiNDk4OWM3MzQ2OWZlYTI4ZTUxODFlOTYxYTgzYWZmZmY3MGI4NDNiNCJ9 END_NESTED_COMMIT BEGIN_NESTED_COMMIT docs(servicehealth): update documentation for various messages PiperOrigin-RevId: 707746489 Source-Link: https://togithub.com/googleapis/googleapis/commit/09d410360ef6b9d92bda174d5b213a921546ee99 Source-Link: https://togithub.com/googleapis/googleapis-gen/commit/63936c204dd0e8ae326c37dfaffd9873b5635946 Copy-Tag: eyJwIjoiLmdpdGh1Yi8uT3dsQm90LnlhbWwiLCJoIjoiNjM5MzZjMjA0ZGQwZThhZTMyNmMzN2RmYWZmZDk4NzNiNTYzNTk0NiJ9 END_NESTED_COMMIT BEGIN_NESTED_COMMIT chore(shopping/merchant/reviews): Configure clients for google-shopping-merchant-reviews PiperOrigin-RevId: 707702887 Source-Link: https://togithub.com/googleapis/googleapis/commit/020c281c3fb4efb3623b060bdbc16535898fb573 Source-Link: https://togithub.com/googleapis/googleapis-gen/commit/3d1d96e95d74db7f0e8d157780ce1e66639e5192 Copy-Tag: eyJwIjoiLmdpdGh1Yi8uT3dsQm90LnlhbWwiLCJoIjoiM2QxZDk2ZTk1ZDc0ZGI3ZjBlOGQxNTc3ODBjZTFlNjY2MzllNTE5MiJ9 END_NESTED_COMMIT --- .../aiplatformpb/model_garden_service.pb.go | 663 ++++- .../aiplatformpb/publisher_model.pb.go | 430 +-- aiplatform/apiv1beta1/auxiliary.go | 64 + aiplatform/apiv1beta1/gapic_metadata.json | 10 + aiplatform/apiv1beta1/model_garden_client.go | 223 +- .../model_garden_client_example_test.go | 30 + batch/apiv1/batchpb/batch.pb.go | 7 +- dataplex/apiv1/dataplexpb/catalog.pb.go | 14 +- dataplex/apiv1/dataplexpb/datascans.pb.go | 963 +++---- .../gkemulticloudpb/attached_resources.pb.go | 275 +- .../gkemulticloudpb/attached_service.pb.go | 1 + .../gkemulticloudpb/common_resources.pb.go | 225 +- .../DeployPublisherModel/main.go | 58 + ...adata.google.cloud.aiplatform.v1beta1.json | 46 + ...google.cloud.contactcenterinsights.v1.json | 2 +- ..._metadata.google.cloud.datacatalog.v1.json | 2 +- ...data.google.cloud.datacatalog.v1beta1.json | 2 +- ...a.google.cloud.datacatalog.lineage.v1.json | 2 +- ...t_metadata.google.cloud.dialogflow.v2.json | 2 +- ...adata.google.cloud.dialogflow.v2beta1.json | 2 +- ...etadata.google.cloud.dialogflow.cx.v3.json | 2 +- ...ta.google.cloud.dialogflow.cx.v3beta1.json | 2 +- .../snippet_metadata.google.cloud.kms.v1.json | 2 +- ...etadata.google.cloud.kms.inventory.v1.json | 2 +- ..._metadata.google.cloud.memorystore.v1.json | 2 +- ...adata.google.cloud.memorystore.v1beta.json | 2 +- .../UpdateCssProductInput/main.go | 53 + ...ippet_metadata.google.shopping.css.v1.json | 48 +- ...gle.shopping.merchant.accounts.v1beta.json | 2 +- ....shopping.merchant.conversions.v1beta.json | 2 +- ....shopping.merchant.datasources.v1beta.json | 2 +- ....shopping.merchant.inventories.v1beta.json | 2 +- ...a.google.shopping.merchant.lfp.v1beta.json | 2 +- ...hopping.merchant.notifications.v1beta.json | 2 +- ...gle.shopping.merchant.products.v1beta.json | 2 +- ...e.shopping.merchant.promotions.v1beta.json | 2 +- ...google.shopping.merchant.quota.v1beta.json | 2 +- ...ogle.shopping.merchant.reports.v1beta.json | 2 +- ...ogle.shopping.merchant.reviews.v1beta.json | 2 +- .../servicehealthpb/event_resources.pb.go | 19 +- .../css/apiv1/css_product_inputs_client.go | 105 +- .../css_product_inputs_client_example_test.go | 25 + shopping/css/apiv1/csspb/accounts.pb.go | 4 +- .../css/apiv1/csspb/css_product_common.pb.go | 20 +- .../css/apiv1/csspb/css_product_inputs.pb.go | 329 ++- shopping/css/apiv1/csspb/css_products.pb.go | 2 +- shopping/css/apiv1/gapic_metadata.json | 10 + .../apiv1beta/reviewspb/merchantreviews.pb.go | 12 +- .../reviewspb/merchantreviews_common.pb.go | 14 +- .../apiv1beta/reviewspb/productreviews.pb.go | 13 +- .../reviewspb/productreviews_common.pb.go | 14 +- speech/apiv2/speechpb/cloud_speech.pb.go | 2346 +++++++++-------- 52 files changed, 3755 insertions(+), 2314 deletions(-) create mode 100644 internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/DeployPublisherModel/main.go create mode 100644 internal/generated/snippets/shopping/css/apiv1/CssProductInputsClient/UpdateCssProductInput/main.go diff --git a/aiplatform/apiv1beta1/aiplatformpb/model_garden_service.pb.go b/aiplatform/apiv1beta1/aiplatformpb/model_garden_service.pb.go index b57a26f199b3..39da14e3492a 100755 --- a/aiplatform/apiv1beta1/aiplatformpb/model_garden_service.pb.go +++ b/aiplatform/apiv1beta1/aiplatformpb/model_garden_service.pb.go @@ -25,6 +25,7 @@ import ( reflect "reflect" sync "sync" + longrunningpb "cloud.google.com/go/longrunning/autogen/longrunningpb" _ "google.golang.org/genproto/googleapis/api/annotations" grpc "google.golang.org/grpc" codes "google.golang.org/grpc/codes" @@ -364,6 +365,268 @@ func (x *ListPublisherModelsResponse) GetNextPageToken() string { return "" } +// Request message for +// [ModelGardenService.DeployPublisherModel][google.cloud.aiplatform.v1beta1.ModelGardenService.DeployPublisherModel]. +type DeployPublisherModelRequest struct { + state protoimpl.MessageState + sizeCache protoimpl.SizeCache + unknownFields protoimpl.UnknownFields + + // Required. The name of the PublisherModel resource. + // Format: + // `publishers/{publisher}/models/{publisher_model}@{version_id}`, or + // `publishers/hf-{hugging-face-author}/models/{hugging-face-model-name}@001` + // or Hugging Face model ID like `google/gemma-2-2b-it`. + Model string `protobuf:"bytes,1,opt,name=model,proto3" json:"model,omitempty"` + // Required. The resource name of the Location to deploy the model in. + // Format: `projects/{project}/locations/{location}` + Destination string `protobuf:"bytes,2,opt,name=destination,proto3" json:"destination,omitempty"` + // Optional. The user-specified display name of the endpoint. If not set, a + // default name will be used. + EndpointDisplayName string `protobuf:"bytes,3,opt,name=endpoint_display_name,json=endpointDisplayName,proto3" json:"endpoint_display_name,omitempty"` + // Optional. The dedicated resources to use for the endpoint. If not set, the + // default resources will be used. + DedicatedResources *DedicatedResources `protobuf:"bytes,4,opt,name=dedicated_resources,json=dedicatedResources,proto3" json:"dedicated_resources,omitempty"` + // Optional. The user-specified display name of the uploaded model. If not + // set, a default name will be used. + ModelDisplayName string `protobuf:"bytes,5,opt,name=model_display_name,json=modelDisplayName,proto3" json:"model_display_name,omitempty"` + // Optional. The Hugging Face read access token used to access the model + // artifacts of gated models. + HuggingFaceAccessToken string `protobuf:"bytes,6,opt,name=hugging_face_access_token,json=huggingFaceAccessToken,proto3" json:"hugging_face_access_token,omitempty"` + // Optional. Whether the user accepts the End User License Agreement (EULA) + // for the model. + AcceptEula bool `protobuf:"varint,7,opt,name=accept_eula,json=acceptEula,proto3" json:"accept_eula,omitempty"` +} + +func (x *DeployPublisherModelRequest) Reset() { + *x = DeployPublisherModelRequest{} + mi := &file_google_cloud_aiplatform_v1beta1_model_garden_service_proto_msgTypes[3] + ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) + ms.StoreMessageInfo(mi) +} + +func (x *DeployPublisherModelRequest) String() string { + return protoimpl.X.MessageStringOf(x) +} + +func (*DeployPublisherModelRequest) ProtoMessage() {} + +func (x *DeployPublisherModelRequest) ProtoReflect() protoreflect.Message { + mi := &file_google_cloud_aiplatform_v1beta1_model_garden_service_proto_msgTypes[3] + if x != nil { + ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) + if ms.LoadMessageInfo() == nil { + ms.StoreMessageInfo(mi) + } + return ms + } + return mi.MessageOf(x) +} + +// Deprecated: Use DeployPublisherModelRequest.ProtoReflect.Descriptor instead. +func (*DeployPublisherModelRequest) Descriptor() ([]byte, []int) { + return file_google_cloud_aiplatform_v1beta1_model_garden_service_proto_rawDescGZIP(), []int{3} +} + +func (x *DeployPublisherModelRequest) GetModel() string { + if x != nil { + return x.Model + } + return "" +} + +func (x *DeployPublisherModelRequest) GetDestination() string { + if x != nil { + return x.Destination + } + return "" +} + +func (x *DeployPublisherModelRequest) GetEndpointDisplayName() string { + if x != nil { + return x.EndpointDisplayName + } + return "" +} + +func (x *DeployPublisherModelRequest) GetDedicatedResources() *DedicatedResources { + if x != nil { + return x.DedicatedResources + } + return nil +} + +func (x *DeployPublisherModelRequest) GetModelDisplayName() string { + if x != nil { + return x.ModelDisplayName + } + return "" +} + +func (x *DeployPublisherModelRequest) GetHuggingFaceAccessToken() string { + if x != nil { + return x.HuggingFaceAccessToken + } + return "" +} + +func (x *DeployPublisherModelRequest) GetAcceptEula() bool { + if x != nil { + return x.AcceptEula + } + return false +} + +// Response message for +// [ModelGardenService.DeployPublisherModel][google.cloud.aiplatform.v1beta1.ModelGardenService.DeployPublisherModel]. +type DeployPublisherModelResponse struct { + state protoimpl.MessageState + sizeCache protoimpl.SizeCache + unknownFields protoimpl.UnknownFields + + // Output only. The name of the PublisherModel resource. + // Format: + // `publishers/{publisher}/models/{publisher_model}@{version_id}`, or + // `publishers/hf-{hugging-face-author}/models/{hugging-face-model-name}@001` + PublisherModel string `protobuf:"bytes,1,opt,name=publisher_model,json=publisherModel,proto3" json:"publisher_model,omitempty"` + // Output only. The name of the Endpoint created. + // Format: `projects/{project}/locations/{location}/endpoints/{endpoint}` + Endpoint string `protobuf:"bytes,2,opt,name=endpoint,proto3" json:"endpoint,omitempty"` + // Output only. The name of the Model created. + // Format: `projects/{project}/locations/{location}/models/{model}` + Model string `protobuf:"bytes,3,opt,name=model,proto3" json:"model,omitempty"` +} + +func (x *DeployPublisherModelResponse) Reset() { + *x = DeployPublisherModelResponse{} + mi := &file_google_cloud_aiplatform_v1beta1_model_garden_service_proto_msgTypes[4] + ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) + ms.StoreMessageInfo(mi) +} + +func (x *DeployPublisherModelResponse) String() string { + return protoimpl.X.MessageStringOf(x) +} + +func (*DeployPublisherModelResponse) ProtoMessage() {} + +func (x *DeployPublisherModelResponse) ProtoReflect() protoreflect.Message { + mi := &file_google_cloud_aiplatform_v1beta1_model_garden_service_proto_msgTypes[4] + if x != nil { + ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) + if ms.LoadMessageInfo() == nil { + ms.StoreMessageInfo(mi) + } + return ms + } + return mi.MessageOf(x) +} + +// Deprecated: Use DeployPublisherModelResponse.ProtoReflect.Descriptor instead. +func (*DeployPublisherModelResponse) Descriptor() ([]byte, []int) { + return file_google_cloud_aiplatform_v1beta1_model_garden_service_proto_rawDescGZIP(), []int{4} +} + +func (x *DeployPublisherModelResponse) GetPublisherModel() string { + if x != nil { + return x.PublisherModel + } + return "" +} + +func (x *DeployPublisherModelResponse) GetEndpoint() string { + if x != nil { + return x.Endpoint + } + return "" +} + +func (x *DeployPublisherModelResponse) GetModel() string { + if x != nil { + return x.Model + } + return "" +} + +// Runtime operation information for +// [ModelGardenService.DeployPublisherModel][google.cloud.aiplatform.v1beta1.ModelGardenService.DeployPublisherModel]. +type DeployPublisherModelOperationMetadata struct { + state protoimpl.MessageState + sizeCache protoimpl.SizeCache + unknownFields protoimpl.UnknownFields + + // The operation generic information. + GenericMetadata *GenericOperationMetadata `protobuf:"bytes,1,opt,name=generic_metadata,json=genericMetadata,proto3" json:"generic_metadata,omitempty"` + // Output only. The name of the PublisherModel resource. + // Format: + // `publishers/{publisher}/models/{publisher_model}@{version_id}`, or + // `publishers/hf-{hugging-face-author}/models/{hugging-face-model-name}@001` + PublisherModel string `protobuf:"bytes,2,opt,name=publisher_model,json=publisherModel,proto3" json:"publisher_model,omitempty"` + // Output only. The resource name of the Location to deploy the model in. + // Format: `projects/{project}/locations/{location}` + Destination string `protobuf:"bytes,3,opt,name=destination,proto3" json:"destination,omitempty"` + // Output only. The project number where the deploy model request is sent. + ProjectNumber int64 `protobuf:"varint,4,opt,name=project_number,json=projectNumber,proto3" json:"project_number,omitempty"` +} + +func (x *DeployPublisherModelOperationMetadata) Reset() { + *x = DeployPublisherModelOperationMetadata{} + mi := &file_google_cloud_aiplatform_v1beta1_model_garden_service_proto_msgTypes[5] + ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) + ms.StoreMessageInfo(mi) +} + +func (x *DeployPublisherModelOperationMetadata) String() string { + return protoimpl.X.MessageStringOf(x) +} + +func (*DeployPublisherModelOperationMetadata) ProtoMessage() {} + +func (x *DeployPublisherModelOperationMetadata) ProtoReflect() protoreflect.Message { + mi := &file_google_cloud_aiplatform_v1beta1_model_garden_service_proto_msgTypes[5] + if x != nil { + ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) + if ms.LoadMessageInfo() == nil { + ms.StoreMessageInfo(mi) + } + return ms + } + return mi.MessageOf(x) +} + +// Deprecated: Use DeployPublisherModelOperationMetadata.ProtoReflect.Descriptor instead. +func (*DeployPublisherModelOperationMetadata) Descriptor() ([]byte, []int) { + return file_google_cloud_aiplatform_v1beta1_model_garden_service_proto_rawDescGZIP(), []int{5} +} + +func (x *DeployPublisherModelOperationMetadata) GetGenericMetadata() *GenericOperationMetadata { + if x != nil { + return x.GenericMetadata + } + return nil +} + +func (x *DeployPublisherModelOperationMetadata) GetPublisherModel() string { + if x != nil { + return x.PublisherModel + } + return "" +} + +func (x *DeployPublisherModelOperationMetadata) GetDestination() string { + if x != nil { + return x.Destination + } + return "" +} + +func (x *DeployPublisherModelOperationMetadata) GetProjectNumber() int64 { + if x != nil { + return x.ProjectNumber + } + return 0 +} + var File_google_cloud_aiplatform_v1beta1_model_garden_service_proto protoreflect.FileDescriptor var file_google_cloud_aiplatform_v1beta1_model_garden_service_proto_rawDesc = []byte{ @@ -380,119 +643,211 @@ var file_google_cloud_aiplatform_v1beta1_model_garden_service_proto_rawDesc = [] 0x2f, 0x66, 0x69, 0x65, 0x6c, 0x64, 0x5f, 0x62, 0x65, 0x68, 0x61, 0x76, 0x69, 0x6f, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x19, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x61, 0x70, 0x69, 0x2f, 0x72, 0x65, 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, - 0x1a, 0x35, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2f, 0x61, + 0x1a, 0x37, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2f, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2f, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, - 0x31, 0x2f, 0x70, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x5f, 0x6d, 0x6f, 0x64, 0x65, - 0x6c, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x22, 0xc3, 0x02, 0x0a, 0x18, 0x47, 0x65, 0x74, 0x50, - 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x52, 0x65, 0x71, - 0x75, 0x65, 0x73, 0x74, 0x12, 0x44, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, - 0x28, 0x09, 0x42, 0x30, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x2a, 0x0a, 0x28, 0x61, 0x69, 0x70, 0x6c, - 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, - 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, - 0x6f, 0x64, 0x65, 0x6c, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x28, 0x0a, 0x0d, 0x6c, 0x61, - 0x6e, 0x67, 0x75, 0x61, 0x67, 0x65, 0x5f, 0x63, 0x6f, 0x64, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, - 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0c, 0x6c, 0x61, 0x6e, 0x67, 0x75, 0x61, 0x67, 0x65, - 0x43, 0x6f, 0x64, 0x65, 0x12, 0x4c, 0x0a, 0x04, 0x76, 0x69, 0x65, 0x77, 0x18, 0x03, 0x20, 0x01, - 0x28, 0x0e, 0x32, 0x33, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, - 0x64, 0x2e, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x76, 0x31, 0x62, - 0x65, 0x74, 0x61, 0x31, 0x2e, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, - 0x64, 0x65, 0x6c, 0x56, 0x69, 0x65, 0x77, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x04, 0x76, 0x69, - 0x65, 0x77, 0x12, 0x36, 0x0a, 0x15, 0x69, 0x73, 0x5f, 0x68, 0x75, 0x67, 0x67, 0x69, 0x6e, 0x67, - 0x5f, 0x66, 0x61, 0x63, 0x65, 0x5f, 0x6d, 0x6f, 0x64, 0x65, 0x6c, 0x18, 0x05, 0x20, 0x01, 0x28, - 0x08, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x12, 0x69, 0x73, 0x48, 0x75, 0x67, 0x67, 0x69, 0x6e, - 0x67, 0x46, 0x61, 0x63, 0x65, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x12, 0x31, 0x0a, 0x12, 0x68, 0x75, - 0x67, 0x67, 0x69, 0x6e, 0x67, 0x5f, 0x66, 0x61, 0x63, 0x65, 0x5f, 0x74, 0x6f, 0x6b, 0x65, 0x6e, - 0x18, 0x06, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x10, 0x68, 0x75, 0x67, - 0x67, 0x69, 0x6e, 0x67, 0x46, 0x61, 0x63, 0x65, 0x54, 0x6f, 0x6b, 0x65, 0x6e, 0x22, 0xe5, 0x02, - 0x0a, 0x1a, 0x4c, 0x69, 0x73, 0x74, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, - 0x6f, 0x64, 0x65, 0x6c, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x1b, 0x0a, 0x06, - 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, - 0x02, 0x52, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x12, 0x1b, 0x0a, 0x06, 0x66, 0x69, 0x6c, - 0x74, 0x65, 0x72, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x06, - 0x66, 0x69, 0x6c, 0x74, 0x65, 0x72, 0x12, 0x20, 0x0a, 0x09, 0x70, 0x61, 0x67, 0x65, 0x5f, 0x73, - 0x69, 0x7a, 0x65, 0x18, 0x03, 0x20, 0x01, 0x28, 0x05, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x08, - 0x70, 0x61, 0x67, 0x65, 0x53, 0x69, 0x7a, 0x65, 0x12, 0x22, 0x0a, 0x0a, 0x70, 0x61, 0x67, 0x65, - 0x5f, 0x74, 0x6f, 0x6b, 0x65, 0x6e, 0x18, 0x04, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, - 0x01, 0x52, 0x09, 0x70, 0x61, 0x67, 0x65, 0x54, 0x6f, 0x6b, 0x65, 0x6e, 0x12, 0x4c, 0x0a, 0x04, - 0x76, 0x69, 0x65, 0x77, 0x18, 0x05, 0x20, 0x01, 0x28, 0x0e, 0x32, 0x33, 0x2e, 0x67, 0x6f, 0x6f, - 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, - 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x50, 0x75, 0x62, - 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x56, 0x69, 0x65, 0x77, 0x42, - 0x03, 0xe0, 0x41, 0x01, 0x52, 0x04, 0x76, 0x69, 0x65, 0x77, 0x12, 0x1e, 0x0a, 0x08, 0x6f, 0x72, - 0x64, 0x65, 0x72, 0x5f, 0x62, 0x79, 0x18, 0x06, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, - 0x01, 0x52, 0x07, 0x6f, 0x72, 0x64, 0x65, 0x72, 0x42, 0x79, 0x12, 0x28, 0x0a, 0x0d, 0x6c, 0x61, - 0x6e, 0x67, 0x75, 0x61, 0x67, 0x65, 0x5f, 0x63, 0x6f, 0x64, 0x65, 0x18, 0x07, 0x20, 0x01, 0x28, - 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0c, 0x6c, 0x61, 0x6e, 0x67, 0x75, 0x61, 0x67, 0x65, - 0x43, 0x6f, 0x64, 0x65, 0x12, 0x2f, 0x0a, 0x11, 0x6c, 0x69, 0x73, 0x74, 0x5f, 0x61, 0x6c, 0x6c, - 0x5f, 0x76, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x73, 0x18, 0x08, 0x20, 0x01, 0x28, 0x08, 0x42, - 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0f, 0x6c, 0x69, 0x73, 0x74, 0x41, 0x6c, 0x6c, 0x56, 0x65, 0x72, - 0x73, 0x69, 0x6f, 0x6e, 0x73, 0x22, 0xa1, 0x01, 0x0a, 0x1b, 0x4c, 0x69, 0x73, 0x74, 0x50, 0x75, - 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x73, 0x52, 0x65, 0x73, - 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x5a, 0x0a, 0x10, 0x70, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, - 0x65, 0x72, 0x5f, 0x6d, 0x6f, 0x64, 0x65, 0x6c, 0x73, 0x18, 0x01, 0x20, 0x03, 0x28, 0x0b, 0x32, - 0x2f, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x61, - 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, - 0x31, 0x2e, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, - 0x52, 0x0f, 0x70, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, - 0x73, 0x12, 0x26, 0x0a, 0x0f, 0x6e, 0x65, 0x78, 0x74, 0x5f, 0x70, 0x61, 0x67, 0x65, 0x5f, 0x74, - 0x6f, 0x6b, 0x65, 0x6e, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0d, 0x6e, 0x65, 0x78, 0x74, - 0x50, 0x61, 0x67, 0x65, 0x54, 0x6f, 0x6b, 0x65, 0x6e, 0x2a, 0xa1, 0x01, 0x0a, 0x12, 0x50, 0x75, - 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x56, 0x69, 0x65, 0x77, - 0x12, 0x24, 0x0a, 0x20, 0x50, 0x55, 0x42, 0x4c, 0x49, 0x53, 0x48, 0x45, 0x52, 0x5f, 0x4d, 0x4f, - 0x44, 0x45, 0x4c, 0x5f, 0x56, 0x49, 0x45, 0x57, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, - 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x1e, 0x0a, 0x1a, 0x50, 0x55, 0x42, 0x4c, 0x49, 0x53, - 0x48, 0x45, 0x52, 0x5f, 0x4d, 0x4f, 0x44, 0x45, 0x4c, 0x5f, 0x56, 0x49, 0x45, 0x57, 0x5f, 0x42, - 0x41, 0x53, 0x49, 0x43, 0x10, 0x01, 0x12, 0x1d, 0x0a, 0x19, 0x50, 0x55, 0x42, 0x4c, 0x49, 0x53, - 0x48, 0x45, 0x52, 0x5f, 0x4d, 0x4f, 0x44, 0x45, 0x4c, 0x5f, 0x56, 0x49, 0x45, 0x57, 0x5f, 0x46, - 0x55, 0x4c, 0x4c, 0x10, 0x02, 0x12, 0x26, 0x0a, 0x22, 0x50, 0x55, 0x42, 0x4c, 0x49, 0x53, 0x48, - 0x45, 0x52, 0x5f, 0x4d, 0x4f, 0x44, 0x45, 0x4c, 0x5f, 0x56, 0x45, 0x52, 0x53, 0x49, 0x4f, 0x4e, - 0x5f, 0x56, 0x49, 0x45, 0x57, 0x5f, 0x42, 0x41, 0x53, 0x49, 0x43, 0x10, 0x03, 0x32, 0xe6, 0x03, - 0x0a, 0x12, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x47, 0x61, 0x72, 0x64, 0x65, 0x6e, 0x53, 0x65, 0x72, - 0x76, 0x69, 0x63, 0x65, 0x12, 0xb5, 0x01, 0x0a, 0x11, 0x47, 0x65, 0x74, 0x50, 0x75, 0x62, 0x6c, - 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x12, 0x39, 0x2e, 0x67, 0x6f, 0x6f, - 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, - 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x47, 0x65, 0x74, - 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x52, 0x65, - 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x2f, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, - 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, - 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, - 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x22, 0x34, 0xda, 0x41, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x82, - 0xd3, 0xe4, 0x93, 0x02, 0x27, 0x12, 0x25, 0x2f, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, - 0x7b, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x73, - 0x2f, 0x2a, 0x2f, 0x6d, 0x6f, 0x64, 0x65, 0x6c, 0x73, 0x2f, 0x2a, 0x7d, 0x12, 0xc8, 0x01, 0x0a, - 0x13, 0x4c, 0x69, 0x73, 0x74, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, - 0x64, 0x65, 0x6c, 0x73, 0x12, 0x3b, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, - 0x6f, 0x75, 0x64, 0x2e, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x76, - 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x4c, 0x69, 0x73, 0x74, 0x50, 0x75, 0x62, 0x6c, 0x69, - 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, - 0x74, 0x1a, 0x3c, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, + 0x31, 0x2f, 0x6d, 0x61, 0x63, 0x68, 0x69, 0x6e, 0x65, 0x5f, 0x72, 0x65, 0x73, 0x6f, 0x75, 0x72, + 0x63, 0x65, 0x73, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x2f, 0x67, 0x6f, 0x6f, 0x67, 0x6c, + 0x65, 0x2f, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2f, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, + 0x72, 0x6d, 0x2f, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x6f, 0x70, 0x65, 0x72, 0x61, + 0x74, 0x69, 0x6f, 0x6e, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x35, 0x67, 0x6f, 0x6f, 0x67, + 0x6c, 0x65, 0x2f, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2f, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, + 0x6f, 0x72, 0x6d, 0x2f, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x70, 0x75, 0x62, 0x6c, + 0x69, 0x73, 0x68, 0x65, 0x72, 0x5f, 0x6d, 0x6f, 0x64, 0x65, 0x6c, 0x2e, 0x70, 0x72, 0x6f, 0x74, + 0x6f, 0x1a, 0x23, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x6c, 0x6f, 0x6e, 0x67, 0x72, 0x75, + 0x6e, 0x6e, 0x69, 0x6e, 0x67, 0x2f, 0x6f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, + 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x22, 0xc3, 0x02, 0x0a, 0x18, 0x47, 0x65, 0x74, 0x50, 0x75, + 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x52, 0x65, 0x71, 0x75, + 0x65, 0x73, 0x74, 0x12, 0x44, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, + 0x09, 0x42, 0x30, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x2a, 0x0a, 0x28, 0x61, 0x69, 0x70, 0x6c, 0x61, + 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, + 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, + 0x64, 0x65, 0x6c, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x28, 0x0a, 0x0d, 0x6c, 0x61, 0x6e, + 0x67, 0x75, 0x61, 0x67, 0x65, 0x5f, 0x63, 0x6f, 0x64, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, + 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0c, 0x6c, 0x61, 0x6e, 0x67, 0x75, 0x61, 0x67, 0x65, 0x43, + 0x6f, 0x64, 0x65, 0x12, 0x4c, 0x0a, 0x04, 0x76, 0x69, 0x65, 0x77, 0x18, 0x03, 0x20, 0x01, 0x28, + 0x0e, 0x32, 0x33, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x76, 0x31, 0x62, 0x65, - 0x74, 0x61, 0x31, 0x2e, 0x4c, 0x69, 0x73, 0x74, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, - 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x73, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, - 0x36, 0xda, 0x41, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x27, - 0x12, 0x25, 0x2f, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, - 0x6e, 0x74, 0x3d, 0x70, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x73, 0x2f, 0x2a, 0x7d, - 0x2f, 0x6d, 0x6f, 0x64, 0x65, 0x6c, 0x73, 0x1a, 0x4d, 0xca, 0x41, 0x19, 0x61, 0x69, 0x70, 0x6c, - 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, - 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0xd2, 0x41, 0x2e, 0x68, 0x74, 0x74, 0x70, 0x73, 0x3a, 0x2f, 0x2f, - 0x77, 0x77, 0x77, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, - 0x6f, 0x6d, 0x2f, 0x61, 0x75, 0x74, 0x68, 0x2f, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2d, 0x70, 0x6c, - 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x42, 0xee, 0x01, 0x0a, 0x23, 0x63, 0x6f, 0x6d, 0x2e, 0x67, + 0x74, 0x61, 0x31, 0x2e, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, + 0x65, 0x6c, 0x56, 0x69, 0x65, 0x77, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x04, 0x76, 0x69, 0x65, + 0x77, 0x12, 0x36, 0x0a, 0x15, 0x69, 0x73, 0x5f, 0x68, 0x75, 0x67, 0x67, 0x69, 0x6e, 0x67, 0x5f, + 0x66, 0x61, 0x63, 0x65, 0x5f, 0x6d, 0x6f, 0x64, 0x65, 0x6c, 0x18, 0x05, 0x20, 0x01, 0x28, 0x08, + 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x12, 0x69, 0x73, 0x48, 0x75, 0x67, 0x67, 0x69, 0x6e, 0x67, + 0x46, 0x61, 0x63, 0x65, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x12, 0x31, 0x0a, 0x12, 0x68, 0x75, 0x67, + 0x67, 0x69, 0x6e, 0x67, 0x5f, 0x66, 0x61, 0x63, 0x65, 0x5f, 0x74, 0x6f, 0x6b, 0x65, 0x6e, 0x18, + 0x06, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x10, 0x68, 0x75, 0x67, 0x67, + 0x69, 0x6e, 0x67, 0x46, 0x61, 0x63, 0x65, 0x54, 0x6f, 0x6b, 0x65, 0x6e, 0x22, 0xe5, 0x02, 0x0a, + 0x1a, 0x4c, 0x69, 0x73, 0x74, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, + 0x64, 0x65, 0x6c, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x1b, 0x0a, 0x06, 0x70, + 0x61, 0x72, 0x65, 0x6e, 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x02, + 0x52, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x12, 0x1b, 0x0a, 0x06, 0x66, 0x69, 0x6c, 0x74, + 0x65, 0x72, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x06, 0x66, + 0x69, 0x6c, 0x74, 0x65, 0x72, 0x12, 0x20, 0x0a, 0x09, 0x70, 0x61, 0x67, 0x65, 0x5f, 0x73, 0x69, + 0x7a, 0x65, 0x18, 0x03, 0x20, 0x01, 0x28, 0x05, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x08, 0x70, + 0x61, 0x67, 0x65, 0x53, 0x69, 0x7a, 0x65, 0x12, 0x22, 0x0a, 0x0a, 0x70, 0x61, 0x67, 0x65, 0x5f, + 0x74, 0x6f, 0x6b, 0x65, 0x6e, 0x18, 0x04, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, + 0x52, 0x09, 0x70, 0x61, 0x67, 0x65, 0x54, 0x6f, 0x6b, 0x65, 0x6e, 0x12, 0x4c, 0x0a, 0x04, 0x76, + 0x69, 0x65, 0x77, 0x18, 0x05, 0x20, 0x01, 0x28, 0x0e, 0x32, 0x33, 0x2e, 0x67, 0x6f, 0x6f, 0x67, + 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, + 0x6f, 0x72, 0x6d, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x50, 0x75, 0x62, 0x6c, + 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x56, 0x69, 0x65, 0x77, 0x42, 0x03, + 0xe0, 0x41, 0x01, 0x52, 0x04, 0x76, 0x69, 0x65, 0x77, 0x12, 0x1e, 0x0a, 0x08, 0x6f, 0x72, 0x64, + 0x65, 0x72, 0x5f, 0x62, 0x79, 0x18, 0x06, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, + 0x52, 0x07, 0x6f, 0x72, 0x64, 0x65, 0x72, 0x42, 0x79, 0x12, 0x28, 0x0a, 0x0d, 0x6c, 0x61, 0x6e, + 0x67, 0x75, 0x61, 0x67, 0x65, 0x5f, 0x63, 0x6f, 0x64, 0x65, 0x18, 0x07, 0x20, 0x01, 0x28, 0x09, + 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0c, 0x6c, 0x61, 0x6e, 0x67, 0x75, 0x61, 0x67, 0x65, 0x43, + 0x6f, 0x64, 0x65, 0x12, 0x2f, 0x0a, 0x11, 0x6c, 0x69, 0x73, 0x74, 0x5f, 0x61, 0x6c, 0x6c, 0x5f, + 0x76, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x73, 0x18, 0x08, 0x20, 0x01, 0x28, 0x08, 0x42, 0x03, + 0xe0, 0x41, 0x01, 0x52, 0x0f, 0x6c, 0x69, 0x73, 0x74, 0x41, 0x6c, 0x6c, 0x56, 0x65, 0x72, 0x73, + 0x69, 0x6f, 0x6e, 0x73, 0x22, 0xa1, 0x01, 0x0a, 0x1b, 0x4c, 0x69, 0x73, 0x74, 0x50, 0x75, 0x62, + 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x73, 0x52, 0x65, 0x73, 0x70, + 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x5a, 0x0a, 0x10, 0x70, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, + 0x72, 0x5f, 0x6d, 0x6f, 0x64, 0x65, 0x6c, 0x73, 0x18, 0x01, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x2f, + 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x61, 0x69, + 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, + 0x2e, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x52, + 0x0f, 0x70, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x73, + 0x12, 0x26, 0x0a, 0x0f, 0x6e, 0x65, 0x78, 0x74, 0x5f, 0x70, 0x61, 0x67, 0x65, 0x5f, 0x74, 0x6f, + 0x6b, 0x65, 0x6e, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0d, 0x6e, 0x65, 0x78, 0x74, 0x50, + 0x61, 0x67, 0x65, 0x54, 0x6f, 0x6b, 0x65, 0x6e, 0x22, 0xc2, 0x03, 0x0a, 0x1b, 0x44, 0x65, 0x70, + 0x6c, 0x6f, 0x79, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, + 0x6c, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x19, 0x0a, 0x05, 0x6d, 0x6f, 0x64, 0x65, + 0x6c, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x05, 0x6d, 0x6f, + 0x64, 0x65, 0x6c, 0x12, 0x4b, 0x0a, 0x0b, 0x64, 0x65, 0x73, 0x74, 0x69, 0x6e, 0x61, 0x74, 0x69, + 0x6f, 0x6e, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x42, 0x29, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x23, + 0x0a, 0x21, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2e, 0x67, 0x6f, 0x6f, 0x67, + 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x4c, 0x6f, 0x63, 0x61, 0x74, + 0x69, 0x6f, 0x6e, 0x52, 0x0b, 0x64, 0x65, 0x73, 0x74, 0x69, 0x6e, 0x61, 0x74, 0x69, 0x6f, 0x6e, + 0x12, 0x37, 0x0a, 0x15, 0x65, 0x6e, 0x64, 0x70, 0x6f, 0x69, 0x6e, 0x74, 0x5f, 0x64, 0x69, 0x73, + 0x70, 0x6c, 0x61, 0x79, 0x5f, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x42, + 0x03, 0xe0, 0x41, 0x01, 0x52, 0x13, 0x65, 0x6e, 0x64, 0x70, 0x6f, 0x69, 0x6e, 0x74, 0x44, 0x69, + 0x73, 0x70, 0x6c, 0x61, 0x79, 0x4e, 0x61, 0x6d, 0x65, 0x12, 0x69, 0x0a, 0x13, 0x64, 0x65, 0x64, + 0x69, 0x63, 0x61, 0x74, 0x65, 0x64, 0x5f, 0x72, 0x65, 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, 0x73, + 0x18, 0x04, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x33, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, + 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, + 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x44, 0x65, 0x64, 0x69, 0x63, 0x61, 0x74, + 0x65, 0x64, 0x52, 0x65, 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, 0x73, 0x42, 0x03, 0xe0, 0x41, 0x01, + 0x52, 0x12, 0x64, 0x65, 0x64, 0x69, 0x63, 0x61, 0x74, 0x65, 0x64, 0x52, 0x65, 0x73, 0x6f, 0x75, + 0x72, 0x63, 0x65, 0x73, 0x12, 0x31, 0x0a, 0x12, 0x6d, 0x6f, 0x64, 0x65, 0x6c, 0x5f, 0x64, 0x69, + 0x73, 0x70, 0x6c, 0x61, 0x79, 0x5f, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x05, 0x20, 0x01, 0x28, 0x09, + 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x10, 0x6d, 0x6f, 0x64, 0x65, 0x6c, 0x44, 0x69, 0x73, 0x70, + 0x6c, 0x61, 0x79, 0x4e, 0x61, 0x6d, 0x65, 0x12, 0x3e, 0x0a, 0x19, 0x68, 0x75, 0x67, 0x67, 0x69, + 0x6e, 0x67, 0x5f, 0x66, 0x61, 0x63, 0x65, 0x5f, 0x61, 0x63, 0x63, 0x65, 0x73, 0x73, 0x5f, 0x74, + 0x6f, 0x6b, 0x65, 0x6e, 0x18, 0x06, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, + 0x16, 0x68, 0x75, 0x67, 0x67, 0x69, 0x6e, 0x67, 0x46, 0x61, 0x63, 0x65, 0x41, 0x63, 0x63, 0x65, + 0x73, 0x73, 0x54, 0x6f, 0x6b, 0x65, 0x6e, 0x12, 0x24, 0x0a, 0x0b, 0x61, 0x63, 0x63, 0x65, 0x70, + 0x74, 0x5f, 0x65, 0x75, 0x6c, 0x61, 0x18, 0x07, 0x20, 0x01, 0x28, 0x08, 0x42, 0x03, 0xe0, 0x41, + 0x01, 0x52, 0x0a, 0x61, 0x63, 0x63, 0x65, 0x70, 0x74, 0x45, 0x75, 0x6c, 0x61, 0x22, 0x80, 0x02, + 0x0a, 0x1c, 0x44, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, + 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x59, + 0x0a, 0x0f, 0x70, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x5f, 0x6d, 0x6f, 0x64, 0x65, + 0x6c, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x30, 0xe0, 0x41, 0x03, 0xfa, 0x41, 0x2a, 0x0a, + 0x28, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, + 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x50, 0x75, 0x62, 0x6c, 0x69, + 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x52, 0x0e, 0x70, 0x75, 0x62, 0x6c, 0x69, + 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x12, 0x46, 0x0a, 0x08, 0x65, 0x6e, 0x64, + 0x70, 0x6f, 0x69, 0x6e, 0x74, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x42, 0x2a, 0xe0, 0x41, 0x03, + 0xfa, 0x41, 0x24, 0x0a, 0x22, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, + 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x45, + 0x6e, 0x64, 0x70, 0x6f, 0x69, 0x6e, 0x74, 0x52, 0x08, 0x65, 0x6e, 0x64, 0x70, 0x6f, 0x69, 0x6e, + 0x74, 0x12, 0x3d, 0x0a, 0x05, 0x6d, 0x6f, 0x64, 0x65, 0x6c, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, + 0x42, 0x27, 0xe0, 0x41, 0x03, 0xfa, 0x41, 0x21, 0x0a, 0x1f, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, + 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, + 0x63, 0x6f, 0x6d, 0x2f, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x52, 0x05, 0x6d, 0x6f, 0x64, 0x65, 0x6c, + 0x22, 0xe1, 0x02, 0x0a, 0x25, 0x44, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x50, 0x75, 0x62, 0x6c, 0x69, + 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, + 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x12, 0x64, 0x0a, 0x10, 0x67, 0x65, + 0x6e, 0x65, 0x72, 0x69, 0x63, 0x5f, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x18, 0x01, + 0x20, 0x01, 0x28, 0x0b, 0x32, 0x39, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, + 0x6f, 0x75, 0x64, 0x2e, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x76, + 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x47, 0x65, 0x6e, 0x65, 0x72, 0x69, 0x63, 0x4f, 0x70, + 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x52, + 0x0f, 0x67, 0x65, 0x6e, 0x65, 0x72, 0x69, 0x63, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, + 0x12, 0x59, 0x0a, 0x0f, 0x70, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x5f, 0x6d, 0x6f, + 0x64, 0x65, 0x6c, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x42, 0x30, 0xe0, 0x41, 0x03, 0xfa, 0x41, + 0x2a, 0x0a, 0x28, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x67, 0x6f, + 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x50, 0x75, 0x62, + 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x52, 0x0e, 0x70, 0x75, 0x62, + 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x12, 0x4b, 0x0a, 0x0b, 0x64, + 0x65, 0x73, 0x74, 0x69, 0x6e, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, + 0x42, 0x29, 0xe0, 0x41, 0x03, 0xfa, 0x41, 0x23, 0x0a, 0x21, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, + 0x6f, 0x6e, 0x73, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, + 0x6f, 0x6d, 0x2f, 0x4c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x0b, 0x64, 0x65, 0x73, + 0x74, 0x69, 0x6e, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x12, 0x2a, 0x0a, 0x0e, 0x70, 0x72, 0x6f, 0x6a, + 0x65, 0x63, 0x74, 0x5f, 0x6e, 0x75, 0x6d, 0x62, 0x65, 0x72, 0x18, 0x04, 0x20, 0x01, 0x28, 0x03, + 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x0d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x4e, 0x75, + 0x6d, 0x62, 0x65, 0x72, 0x2a, 0xa1, 0x01, 0x0a, 0x12, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, + 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x56, 0x69, 0x65, 0x77, 0x12, 0x24, 0x0a, 0x20, 0x50, + 0x55, 0x42, 0x4c, 0x49, 0x53, 0x48, 0x45, 0x52, 0x5f, 0x4d, 0x4f, 0x44, 0x45, 0x4c, 0x5f, 0x56, + 0x49, 0x45, 0x57, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, + 0x00, 0x12, 0x1e, 0x0a, 0x1a, 0x50, 0x55, 0x42, 0x4c, 0x49, 0x53, 0x48, 0x45, 0x52, 0x5f, 0x4d, + 0x4f, 0x44, 0x45, 0x4c, 0x5f, 0x56, 0x49, 0x45, 0x57, 0x5f, 0x42, 0x41, 0x53, 0x49, 0x43, 0x10, + 0x01, 0x12, 0x1d, 0x0a, 0x19, 0x50, 0x55, 0x42, 0x4c, 0x49, 0x53, 0x48, 0x45, 0x52, 0x5f, 0x4d, + 0x4f, 0x44, 0x45, 0x4c, 0x5f, 0x56, 0x49, 0x45, 0x57, 0x5f, 0x46, 0x55, 0x4c, 0x4c, 0x10, 0x02, + 0x12, 0x26, 0x0a, 0x22, 0x50, 0x55, 0x42, 0x4c, 0x49, 0x53, 0x48, 0x45, 0x52, 0x5f, 0x4d, 0x4f, + 0x44, 0x45, 0x4c, 0x5f, 0x56, 0x45, 0x52, 0x53, 0x49, 0x4f, 0x4e, 0x5f, 0x56, 0x49, 0x45, 0x57, + 0x5f, 0x42, 0x41, 0x53, 0x49, 0x43, 0x10, 0x03, 0x32, 0xe6, 0x05, 0x0a, 0x12, 0x4d, 0x6f, 0x64, + 0x65, 0x6c, 0x47, 0x61, 0x72, 0x64, 0x65, 0x6e, 0x53, 0x65, 0x72, 0x76, 0x69, 0x63, 0x65, 0x12, + 0xb5, 0x01, 0x0a, 0x11, 0x47, 0x65, 0x74, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, + 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x12, 0x39, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, + 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, + 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x47, 0x65, 0x74, 0x50, 0x75, 0x62, 0x6c, 0x69, + 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, + 0x1a, 0x2f, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, + 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, + 0x61, 0x31, 0x2e, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, + 0x6c, 0x22, 0x34, 0xda, 0x41, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x27, + 0x12, 0x25, 0x2f, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x6e, 0x61, 0x6d, 0x65, + 0x3d, 0x70, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x73, 0x2f, 0x2a, 0x2f, 0x6d, 0x6f, + 0x64, 0x65, 0x6c, 0x73, 0x2f, 0x2a, 0x7d, 0x12, 0xc8, 0x01, 0x0a, 0x13, 0x4c, 0x69, 0x73, 0x74, + 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x73, 0x12, + 0x3b, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x61, + 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, + 0x31, 0x2e, 0x4c, 0x69, 0x73, 0x74, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, + 0x6f, 0x64, 0x65, 0x6c, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x3c, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x61, 0x69, 0x70, 0x6c, - 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x42, 0x17, - 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x47, 0x61, 0x72, 0x64, 0x65, 0x6e, 0x53, 0x65, 0x72, 0x76, 0x69, - 0x63, 0x65, 0x50, 0x72, 0x6f, 0x74, 0x6f, 0x50, 0x01, 0x5a, 0x43, 0x63, 0x6c, 0x6f, 0x75, 0x64, - 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x67, 0x6f, 0x2f, 0x61, - 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2f, 0x61, 0x70, 0x69, 0x76, 0x31, 0x62, - 0x65, 0x74, 0x61, 0x31, 0x2f, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x70, - 0x62, 0x3b, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x70, 0x62, 0xaa, 0x02, - 0x1f, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x41, 0x49, - 0x50, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x56, 0x31, 0x42, 0x65, 0x74, 0x61, 0x31, - 0xca, 0x02, 0x1f, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x5c, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x5c, - 0x41, 0x49, 0x50, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x5c, 0x56, 0x31, 0x62, 0x65, 0x74, - 0x61, 0x31, 0xea, 0x02, 0x22, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x3a, 0x3a, 0x43, 0x6c, 0x6f, - 0x75, 0x64, 0x3a, 0x3a, 0x41, 0x49, 0x50, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x3a, 0x3a, - 0x56, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, + 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x4c, + 0x69, 0x73, 0x74, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, + 0x6c, 0x73, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x36, 0xda, 0x41, 0x06, 0x70, + 0x61, 0x72, 0x65, 0x6e, 0x74, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x27, 0x12, 0x25, 0x2f, 0x76, 0x31, + 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x75, + 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x6d, 0x6f, 0x64, 0x65, + 0x6c, 0x73, 0x12, 0xfd, 0x01, 0x0a, 0x14, 0x44, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x50, 0x75, 0x62, + 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x12, 0x3c, 0x2e, 0x67, 0x6f, + 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x61, 0x69, 0x70, 0x6c, 0x61, + 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x44, 0x65, + 0x70, 0x6c, 0x6f, 0x79, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, + 0x65, 0x6c, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, + 0x6c, 0x65, 0x2e, 0x6c, 0x6f, 0x6e, 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, 0x67, 0x2e, 0x4f, + 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x22, 0x87, 0x01, 0xca, 0x41, 0x45, 0x0a, 0x1c, + 0x44, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, + 0x6f, 0x64, 0x65, 0x6c, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x25, 0x44, 0x65, + 0x70, 0x6c, 0x6f, 0x79, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, + 0x65, 0x6c, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, + 0x61, 0x74, 0x61, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x39, 0x3a, 0x01, 0x2a, 0x22, 0x34, 0x2f, 0x76, + 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x64, 0x65, 0x73, 0x74, 0x69, 0x6e, 0x61, 0x74, + 0x69, 0x6f, 0x6e, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, + 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x7d, 0x3a, 0x64, 0x65, 0x70, 0x6c, + 0x6f, 0x79, 0x1a, 0x4d, 0xca, 0x41, 0x19, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, + 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, + 0xd2, 0x41, 0x2e, 0x68, 0x74, 0x74, 0x70, 0x73, 0x3a, 0x2f, 0x2f, 0x77, 0x77, 0x77, 0x2e, 0x67, + 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x61, 0x75, + 0x74, 0x68, 0x2f, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2d, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, + 0x6d, 0x42, 0xee, 0x01, 0x0a, 0x23, 0x63, 0x6f, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, + 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, + 0x6d, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x42, 0x17, 0x4d, 0x6f, 0x64, 0x65, 0x6c, + 0x47, 0x61, 0x72, 0x64, 0x65, 0x6e, 0x53, 0x65, 0x72, 0x76, 0x69, 0x63, 0x65, 0x50, 0x72, 0x6f, + 0x74, 0x6f, 0x50, 0x01, 0x5a, 0x43, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x67, 0x6f, 0x6f, 0x67, + 0x6c, 0x65, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x67, 0x6f, 0x2f, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, + 0x66, 0x6f, 0x72, 0x6d, 0x2f, 0x61, 0x70, 0x69, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, + 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x70, 0x62, 0x3b, 0x61, 0x69, 0x70, + 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x70, 0x62, 0xaa, 0x02, 0x1f, 0x47, 0x6f, 0x6f, 0x67, + 0x6c, 0x65, 0x2e, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x41, 0x49, 0x50, 0x6c, 0x61, 0x74, 0x66, + 0x6f, 0x72, 0x6d, 0x2e, 0x56, 0x31, 0x42, 0x65, 0x74, 0x61, 0x31, 0xca, 0x02, 0x1f, 0x47, 0x6f, + 0x6f, 0x67, 0x6c, 0x65, 0x5c, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x5c, 0x41, 0x49, 0x50, 0x6c, 0x61, + 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x5c, 0x56, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0xea, 0x02, 0x22, + 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x3a, 0x3a, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x3a, 0x3a, 0x41, + 0x49, 0x50, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x3a, 0x3a, 0x56, 0x31, 0x62, 0x65, 0x74, + 0x61, 0x31, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, } var ( @@ -508,27 +863,37 @@ func file_google_cloud_aiplatform_v1beta1_model_garden_service_proto_rawDescGZIP } var file_google_cloud_aiplatform_v1beta1_model_garden_service_proto_enumTypes = make([]protoimpl.EnumInfo, 1) -var file_google_cloud_aiplatform_v1beta1_model_garden_service_proto_msgTypes = make([]protoimpl.MessageInfo, 3) +var file_google_cloud_aiplatform_v1beta1_model_garden_service_proto_msgTypes = make([]protoimpl.MessageInfo, 6) var file_google_cloud_aiplatform_v1beta1_model_garden_service_proto_goTypes = []any{ - (PublisherModelView)(0), // 0: google.cloud.aiplatform.v1beta1.PublisherModelView - (*GetPublisherModelRequest)(nil), // 1: google.cloud.aiplatform.v1beta1.GetPublisherModelRequest - (*ListPublisherModelsRequest)(nil), // 2: google.cloud.aiplatform.v1beta1.ListPublisherModelsRequest - (*ListPublisherModelsResponse)(nil), // 3: google.cloud.aiplatform.v1beta1.ListPublisherModelsResponse - (*PublisherModel)(nil), // 4: google.cloud.aiplatform.v1beta1.PublisherModel + (PublisherModelView)(0), // 0: google.cloud.aiplatform.v1beta1.PublisherModelView + (*GetPublisherModelRequest)(nil), // 1: google.cloud.aiplatform.v1beta1.GetPublisherModelRequest + (*ListPublisherModelsRequest)(nil), // 2: google.cloud.aiplatform.v1beta1.ListPublisherModelsRequest + (*ListPublisherModelsResponse)(nil), // 3: google.cloud.aiplatform.v1beta1.ListPublisherModelsResponse + (*DeployPublisherModelRequest)(nil), // 4: google.cloud.aiplatform.v1beta1.DeployPublisherModelRequest + (*DeployPublisherModelResponse)(nil), // 5: google.cloud.aiplatform.v1beta1.DeployPublisherModelResponse + (*DeployPublisherModelOperationMetadata)(nil), // 6: google.cloud.aiplatform.v1beta1.DeployPublisherModelOperationMetadata + (*PublisherModel)(nil), // 7: google.cloud.aiplatform.v1beta1.PublisherModel + (*DedicatedResources)(nil), // 8: google.cloud.aiplatform.v1beta1.DedicatedResources + (*GenericOperationMetadata)(nil), // 9: google.cloud.aiplatform.v1beta1.GenericOperationMetadata + (*longrunningpb.Operation)(nil), // 10: google.longrunning.Operation } var file_google_cloud_aiplatform_v1beta1_model_garden_service_proto_depIdxs = []int32{ - 0, // 0: google.cloud.aiplatform.v1beta1.GetPublisherModelRequest.view:type_name -> google.cloud.aiplatform.v1beta1.PublisherModelView - 0, // 1: google.cloud.aiplatform.v1beta1.ListPublisherModelsRequest.view:type_name -> google.cloud.aiplatform.v1beta1.PublisherModelView - 4, // 2: google.cloud.aiplatform.v1beta1.ListPublisherModelsResponse.publisher_models:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel - 1, // 3: google.cloud.aiplatform.v1beta1.ModelGardenService.GetPublisherModel:input_type -> google.cloud.aiplatform.v1beta1.GetPublisherModelRequest - 2, // 4: google.cloud.aiplatform.v1beta1.ModelGardenService.ListPublisherModels:input_type -> google.cloud.aiplatform.v1beta1.ListPublisherModelsRequest - 4, // 5: google.cloud.aiplatform.v1beta1.ModelGardenService.GetPublisherModel:output_type -> google.cloud.aiplatform.v1beta1.PublisherModel - 3, // 6: google.cloud.aiplatform.v1beta1.ModelGardenService.ListPublisherModels:output_type -> google.cloud.aiplatform.v1beta1.ListPublisherModelsResponse - 5, // [5:7] is the sub-list for method output_type - 3, // [3:5] is the sub-list for method input_type - 3, // [3:3] is the sub-list for extension type_name - 3, // [3:3] is the sub-list for extension extendee - 0, // [0:3] is the sub-list for field type_name + 0, // 0: google.cloud.aiplatform.v1beta1.GetPublisherModelRequest.view:type_name -> google.cloud.aiplatform.v1beta1.PublisherModelView + 0, // 1: google.cloud.aiplatform.v1beta1.ListPublisherModelsRequest.view:type_name -> google.cloud.aiplatform.v1beta1.PublisherModelView + 7, // 2: google.cloud.aiplatform.v1beta1.ListPublisherModelsResponse.publisher_models:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel + 8, // 3: google.cloud.aiplatform.v1beta1.DeployPublisherModelRequest.dedicated_resources:type_name -> google.cloud.aiplatform.v1beta1.DedicatedResources + 9, // 4: google.cloud.aiplatform.v1beta1.DeployPublisherModelOperationMetadata.generic_metadata:type_name -> google.cloud.aiplatform.v1beta1.GenericOperationMetadata + 1, // 5: google.cloud.aiplatform.v1beta1.ModelGardenService.GetPublisherModel:input_type -> google.cloud.aiplatform.v1beta1.GetPublisherModelRequest + 2, // 6: google.cloud.aiplatform.v1beta1.ModelGardenService.ListPublisherModels:input_type -> google.cloud.aiplatform.v1beta1.ListPublisherModelsRequest + 4, // 7: google.cloud.aiplatform.v1beta1.ModelGardenService.DeployPublisherModel:input_type -> google.cloud.aiplatform.v1beta1.DeployPublisherModelRequest + 7, // 8: google.cloud.aiplatform.v1beta1.ModelGardenService.GetPublisherModel:output_type -> google.cloud.aiplatform.v1beta1.PublisherModel + 3, // 9: google.cloud.aiplatform.v1beta1.ModelGardenService.ListPublisherModels:output_type -> google.cloud.aiplatform.v1beta1.ListPublisherModelsResponse + 10, // 10: google.cloud.aiplatform.v1beta1.ModelGardenService.DeployPublisherModel:output_type -> google.longrunning.Operation + 8, // [8:11] is the sub-list for method output_type + 5, // [5:8] is the sub-list for method input_type + 5, // [5:5] is the sub-list for extension type_name + 5, // [5:5] is the sub-list for extension extendee + 0, // [0:5] is the sub-list for field type_name } func init() { file_google_cloud_aiplatform_v1beta1_model_garden_service_proto_init() } @@ -536,6 +901,8 @@ func file_google_cloud_aiplatform_v1beta1_model_garden_service_proto_init() { if File_google_cloud_aiplatform_v1beta1_model_garden_service_proto != nil { return } + file_google_cloud_aiplatform_v1beta1_machine_resources_proto_init() + file_google_cloud_aiplatform_v1beta1_operation_proto_init() file_google_cloud_aiplatform_v1beta1_publisher_model_proto_init() type x struct{} out := protoimpl.TypeBuilder{ @@ -543,7 +910,7 @@ func file_google_cloud_aiplatform_v1beta1_model_garden_service_proto_init() { GoPackagePath: reflect.TypeOf(x{}).PkgPath(), RawDescriptor: file_google_cloud_aiplatform_v1beta1_model_garden_service_proto_rawDesc, NumEnums: 1, - NumMessages: 3, + NumMessages: 6, NumExtensions: 0, NumServices: 1, }, @@ -574,6 +941,8 @@ type ModelGardenServiceClient interface { GetPublisherModel(ctx context.Context, in *GetPublisherModelRequest, opts ...grpc.CallOption) (*PublisherModel, error) // Lists publisher models in Model Garden. ListPublisherModels(ctx context.Context, in *ListPublisherModelsRequest, opts ...grpc.CallOption) (*ListPublisherModelsResponse, error) + // Deploys publisher models. + DeployPublisherModel(ctx context.Context, in *DeployPublisherModelRequest, opts ...grpc.CallOption) (*longrunningpb.Operation, error) } type modelGardenServiceClient struct { @@ -602,12 +971,23 @@ func (c *modelGardenServiceClient) ListPublisherModels(ctx context.Context, in * return out, nil } +func (c *modelGardenServiceClient) DeployPublisherModel(ctx context.Context, in *DeployPublisherModelRequest, opts ...grpc.CallOption) (*longrunningpb.Operation, error) { + out := new(longrunningpb.Operation) + err := c.cc.Invoke(ctx, "/google.cloud.aiplatform.v1beta1.ModelGardenService/DeployPublisherModel", in, out, opts...) + if err != nil { + return nil, err + } + return out, nil +} + // ModelGardenServiceServer is the server API for ModelGardenService service. type ModelGardenServiceServer interface { // Gets a Model Garden publisher model. GetPublisherModel(context.Context, *GetPublisherModelRequest) (*PublisherModel, error) // Lists publisher models in Model Garden. ListPublisherModels(context.Context, *ListPublisherModelsRequest) (*ListPublisherModelsResponse, error) + // Deploys publisher models. + DeployPublisherModel(context.Context, *DeployPublisherModelRequest) (*longrunningpb.Operation, error) } // UnimplementedModelGardenServiceServer can be embedded to have forward compatible implementations. @@ -620,6 +1000,9 @@ func (*UnimplementedModelGardenServiceServer) GetPublisherModel(context.Context, func (*UnimplementedModelGardenServiceServer) ListPublisherModels(context.Context, *ListPublisherModelsRequest) (*ListPublisherModelsResponse, error) { return nil, status.Errorf(codes.Unimplemented, "method ListPublisherModels not implemented") } +func (*UnimplementedModelGardenServiceServer) DeployPublisherModel(context.Context, *DeployPublisherModelRequest) (*longrunningpb.Operation, error) { + return nil, status.Errorf(codes.Unimplemented, "method DeployPublisherModel not implemented") +} func RegisterModelGardenServiceServer(s *grpc.Server, srv ModelGardenServiceServer) { s.RegisterService(&_ModelGardenService_serviceDesc, srv) @@ -661,6 +1044,24 @@ func _ModelGardenService_ListPublisherModels_Handler(srv interface{}, ctx contex return interceptor(ctx, in, info, handler) } +func _ModelGardenService_DeployPublisherModel_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { + in := new(DeployPublisherModelRequest) + if err := dec(in); err != nil { + return nil, err + } + if interceptor == nil { + return srv.(ModelGardenServiceServer).DeployPublisherModel(ctx, in) + } + info := &grpc.UnaryServerInfo{ + Server: srv, + FullMethod: "/google.cloud.aiplatform.v1beta1.ModelGardenService/DeployPublisherModel", + } + handler := func(ctx context.Context, req interface{}) (interface{}, error) { + return srv.(ModelGardenServiceServer).DeployPublisherModel(ctx, req.(*DeployPublisherModelRequest)) + } + return interceptor(ctx, in, info, handler) +} + var _ModelGardenService_serviceDesc = grpc.ServiceDesc{ ServiceName: "google.cloud.aiplatform.v1beta1.ModelGardenService", HandlerType: (*ModelGardenServiceServer)(nil), @@ -673,6 +1074,10 @@ var _ModelGardenService_serviceDesc = grpc.ServiceDesc{ MethodName: "ListPublisherModels", Handler: _ModelGardenService_ListPublisherModels_Handler, }, + { + MethodName: "DeployPublisherModel", + Handler: _ModelGardenService_DeployPublisherModel_Handler, + }, }, Streams: []grpc.StreamDesc{}, Metadata: "google/cloud/aiplatform/v1beta1/model_garden_service.proto", diff --git a/aiplatform/apiv1beta1/aiplatformpb/publisher_model.pb.go b/aiplatform/apiv1beta1/aiplatformpb/publisher_model.pb.go index f891e3c6bcfc..5d6c229a42e3 100755 --- a/aiplatform/apiv1beta1/aiplatformpb/publisher_model.pb.go +++ b/aiplatform/apiv1beta1/aiplatformpb/publisher_model.pb.go @@ -618,6 +618,9 @@ type PublisherModel_CallToAction struct { OpenGenie *PublisherModel_CallToAction_RegionalResourceReferences `protobuf:"bytes,6,opt,name=open_genie,json=openGenie,proto3" json:"open_genie,omitempty"` // Optional. Deploy the PublisherModel to Vertex Endpoint. Deploy *PublisherModel_CallToAction_Deploy `protobuf:"bytes,7,opt,name=deploy,proto3" json:"deploy,omitempty"` + // Optional. Multiple setups to deploy the PublisherModel to Vertex + // Endpoint. + MultiDeployVertex *PublisherModel_CallToAction_DeployVertex `protobuf:"bytes,16,opt,name=multi_deploy_vertex,json=multiDeployVertex,proto3" json:"multi_deploy_vertex,omitempty"` // Optional. Deploy PublisherModel to Google Kubernetes Engine. DeployGke *PublisherModel_CallToAction_DeployGke `protobuf:"bytes,14,opt,name=deploy_gke,json=deployGke,proto3" json:"deploy_gke,omitempty"` // Optional. Open in Generation AI Studio. @@ -721,6 +724,13 @@ func (x *PublisherModel_CallToAction) GetDeploy() *PublisherModel_CallToAction_D return nil } +func (x *PublisherModel_CallToAction) GetMultiDeployVertex() *PublisherModel_CallToAction_DeployVertex { + if x != nil { + return x.MultiDeployVertex + } + return nil +} + func (x *PublisherModel_CallToAction) GetDeployGke() *PublisherModel_CallToAction_DeployGke { if x != nil { return x.DeployGke @@ -983,6 +993,53 @@ func (x *PublisherModel_CallToAction_OpenFineTuningPipelines) GetFineTuningPipel return nil } +// Multiple setups to deploy the PublisherModel. +type PublisherModel_CallToAction_DeployVertex struct { + state protoimpl.MessageState + sizeCache protoimpl.SizeCache + unknownFields protoimpl.UnknownFields + + // Optional. One click deployment configurations. + MultiDeployVertex []*PublisherModel_CallToAction_Deploy `protobuf:"bytes,1,rep,name=multi_deploy_vertex,json=multiDeployVertex,proto3" json:"multi_deploy_vertex,omitempty"` +} + +func (x *PublisherModel_CallToAction_DeployVertex) Reset() { + *x = PublisherModel_CallToAction_DeployVertex{} + mi := &file_google_cloud_aiplatform_v1beta1_publisher_model_proto_msgTypes[9] + ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) + ms.StoreMessageInfo(mi) +} + +func (x *PublisherModel_CallToAction_DeployVertex) String() string { + return protoimpl.X.MessageStringOf(x) +} + +func (*PublisherModel_CallToAction_DeployVertex) ProtoMessage() {} + +func (x *PublisherModel_CallToAction_DeployVertex) ProtoReflect() protoreflect.Message { + mi := &file_google_cloud_aiplatform_v1beta1_publisher_model_proto_msgTypes[9] + if x != nil { + ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) + if ms.LoadMessageInfo() == nil { + ms.StoreMessageInfo(mi) + } + return ms + } + return mi.MessageOf(x) +} + +// Deprecated: Use PublisherModel_CallToAction_DeployVertex.ProtoReflect.Descriptor instead. +func (*PublisherModel_CallToAction_DeployVertex) Descriptor() ([]byte, []int) { + return file_google_cloud_aiplatform_v1beta1_publisher_model_proto_rawDescGZIP(), []int{0, 3, 4} +} + +func (x *PublisherModel_CallToAction_DeployVertex) GetMultiDeployVertex() []*PublisherModel_CallToAction_Deploy { + if x != nil { + return x.MultiDeployVertex + } + return nil +} + // Model metadata that is needed for UploadModel or // DeployModel/CreateEndpoint requests. type PublisherModel_CallToAction_Deploy struct { @@ -1024,7 +1081,7 @@ type PublisherModel_CallToAction_Deploy struct { func (x *PublisherModel_CallToAction_Deploy) Reset() { *x = PublisherModel_CallToAction_Deploy{} - mi := &file_google_cloud_aiplatform_v1beta1_publisher_model_proto_msgTypes[9] + mi := &file_google_cloud_aiplatform_v1beta1_publisher_model_proto_msgTypes[10] ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) ms.StoreMessageInfo(mi) } @@ -1036,7 +1093,7 @@ func (x *PublisherModel_CallToAction_Deploy) String() string { func (*PublisherModel_CallToAction_Deploy) ProtoMessage() {} func (x *PublisherModel_CallToAction_Deploy) ProtoReflect() protoreflect.Message { - mi := &file_google_cloud_aiplatform_v1beta1_publisher_model_proto_msgTypes[9] + mi := &file_google_cloud_aiplatform_v1beta1_publisher_model_proto_msgTypes[10] if x != nil { ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) if ms.LoadMessageInfo() == nil { @@ -1049,7 +1106,7 @@ func (x *PublisherModel_CallToAction_Deploy) ProtoReflect() protoreflect.Message // Deprecated: Use PublisherModel_CallToAction_Deploy.ProtoReflect.Descriptor instead. func (*PublisherModel_CallToAction_Deploy) Descriptor() ([]byte, []int) { - return file_google_cloud_aiplatform_v1beta1_publisher_model_proto_rawDescGZIP(), []int{0, 3, 4} + return file_google_cloud_aiplatform_v1beta1_publisher_model_proto_rawDescGZIP(), []int{0, 3, 5} } func (m *PublisherModel_CallToAction_Deploy) GetPredictionResources() isPublisherModel_CallToAction_Deploy_PredictionResources { @@ -1180,7 +1237,7 @@ type PublisherModel_CallToAction_DeployGke struct { func (x *PublisherModel_CallToAction_DeployGke) Reset() { *x = PublisherModel_CallToAction_DeployGke{} - mi := &file_google_cloud_aiplatform_v1beta1_publisher_model_proto_msgTypes[10] + mi := &file_google_cloud_aiplatform_v1beta1_publisher_model_proto_msgTypes[11] ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) ms.StoreMessageInfo(mi) } @@ -1192,7 +1249,7 @@ func (x *PublisherModel_CallToAction_DeployGke) String() string { func (*PublisherModel_CallToAction_DeployGke) ProtoMessage() {} func (x *PublisherModel_CallToAction_DeployGke) ProtoReflect() protoreflect.Message { - mi := &file_google_cloud_aiplatform_v1beta1_publisher_model_proto_msgTypes[10] + mi := &file_google_cloud_aiplatform_v1beta1_publisher_model_proto_msgTypes[11] if x != nil { ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) if ms.LoadMessageInfo() == nil { @@ -1205,7 +1262,7 @@ func (x *PublisherModel_CallToAction_DeployGke) ProtoReflect() protoreflect.Mess // Deprecated: Use PublisherModel_CallToAction_DeployGke.ProtoReflect.Descriptor instead. func (*PublisherModel_CallToAction_DeployGke) Descriptor() ([]byte, []int) { - return file_google_cloud_aiplatform_v1beta1_publisher_model_proto_rawDescGZIP(), []int{0, 3, 5} + return file_google_cloud_aiplatform_v1beta1_publisher_model_proto_rawDescGZIP(), []int{0, 3, 6} } func (x *PublisherModel_CallToAction_DeployGke) GetGkeYamlConfigs() []string { @@ -1222,8 +1279,8 @@ type PublisherModel_CallToAction_Deploy_DeployMetadata struct { sizeCache protoimpl.SizeCache unknownFields protoimpl.UnknownFields - // Optional. Labels for the deployment. For managing deployment config - // like verifying, source of deployment config, etc. + // Optional. Labels for the deployment config. For managing deployment + // config like verifying, source of deployment config, etc. Labels map[string]string `protobuf:"bytes,1,rep,name=labels,proto3" json:"labels,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` // Optional. Sample request for deployed endpoint. SampleRequest string `protobuf:"bytes,2,opt,name=sample_request,json=sampleRequest,proto3" json:"sample_request,omitempty"` @@ -1231,7 +1288,7 @@ type PublisherModel_CallToAction_Deploy_DeployMetadata struct { func (x *PublisherModel_CallToAction_Deploy_DeployMetadata) Reset() { *x = PublisherModel_CallToAction_Deploy_DeployMetadata{} - mi := &file_google_cloud_aiplatform_v1beta1_publisher_model_proto_msgTypes[12] + mi := &file_google_cloud_aiplatform_v1beta1_publisher_model_proto_msgTypes[13] ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) ms.StoreMessageInfo(mi) } @@ -1243,7 +1300,7 @@ func (x *PublisherModel_CallToAction_Deploy_DeployMetadata) String() string { func (*PublisherModel_CallToAction_Deploy_DeployMetadata) ProtoMessage() {} func (x *PublisherModel_CallToAction_Deploy_DeployMetadata) ProtoReflect() protoreflect.Message { - mi := &file_google_cloud_aiplatform_v1beta1_publisher_model_proto_msgTypes[12] + mi := &file_google_cloud_aiplatform_v1beta1_publisher_model_proto_msgTypes[13] if x != nil { ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) if ms.LoadMessageInfo() == nil { @@ -1256,7 +1313,7 @@ func (x *PublisherModel_CallToAction_Deploy_DeployMetadata) ProtoReflect() proto // Deprecated: Use PublisherModel_CallToAction_Deploy_DeployMetadata.ProtoReflect.Descriptor instead. func (*PublisherModel_CallToAction_Deploy_DeployMetadata) Descriptor() ([]byte, []int) { - return file_google_cloud_aiplatform_v1beta1_publisher_model_proto_rawDescGZIP(), []int{0, 3, 4, 0} + return file_google_cloud_aiplatform_v1beta1_publisher_model_proto_rawDescGZIP(), []int{0, 3, 5, 0} } func (x *PublisherModel_CallToAction_Deploy_DeployMetadata) GetLabels() map[string]string { @@ -1291,7 +1348,7 @@ var file_google_cloud_aiplatform_v1beta1_publisher_model_proto_rawDesc = []byte{ 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, 0x73, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x2b, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2f, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2f, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x6d, - 0x6f, 0x64, 0x65, 0x6c, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x22, 0x92, 0x2d, 0x0a, 0x0e, 0x50, + 0x6f, 0x64, 0x65, 0x6c, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x22, 0x9d, 0x2f, 0x0a, 0x0e, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x12, 0x17, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x25, 0x0a, 0x0a, 0x76, 0x65, 0x72, 0x73, 0x69, 0x6f, @@ -1366,8 +1423,8 @@ var file_google_cloud_aiplatform_v1beta1_publisher_model_proto_rawDesc = []byte{ 0x74, 0x69, 0x6f, 0x6e, 0x12, 0x19, 0x0a, 0x05, 0x74, 0x69, 0x74, 0x6c, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x05, 0x74, 0x69, 0x74, 0x6c, 0x65, 0x12, 0x1d, 0x0a, 0x07, 0x63, 0x6f, 0x6e, 0x74, 0x65, 0x6e, 0x74, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, - 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x07, 0x63, 0x6f, 0x6e, 0x74, 0x65, 0x6e, 0x74, 0x1a, 0xd5, - 0x1f, 0x0a, 0x0c, 0x43, 0x61, 0x6c, 0x6c, 0x54, 0x6f, 0x41, 0x63, 0x74, 0x69, 0x6f, 0x6e, 0x12, + 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x07, 0x63, 0x6f, 0x6e, 0x74, 0x65, 0x6e, 0x74, 0x1a, 0xe0, + 0x21, 0x0a, 0x0c, 0x43, 0x61, 0x6c, 0x6c, 0x54, 0x6f, 0x41, 0x63, 0x74, 0x69, 0x6f, 0x6e, 0x12, 0x71, 0x0a, 0x0d, 0x76, 0x69, 0x65, 0x77, 0x5f, 0x72, 0x65, 0x73, 0x74, 0x5f, 0x61, 0x70, 0x69, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x48, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, @@ -1443,7 +1500,15 @@ var file_google_cloud_aiplatform_v1beta1_publisher_model_proto_rawDesc = []byte{ 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x2e, 0x43, 0x61, 0x6c, 0x6c, 0x54, 0x6f, 0x41, 0x63, 0x74, 0x69, 0x6f, 0x6e, 0x2e, 0x44, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x06, - 0x64, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x12, 0x6a, 0x0a, 0x0a, 0x64, 0x65, 0x70, 0x6c, 0x6f, 0x79, + 0x64, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x12, 0x7e, 0x0a, 0x13, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x5f, + 0x64, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x5f, 0x76, 0x65, 0x72, 0x74, 0x65, 0x78, 0x18, 0x10, 0x20, + 0x01, 0x28, 0x0b, 0x32, 0x49, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, + 0x75, 0x64, 0x2e, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x76, 0x31, + 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, + 0x6f, 0x64, 0x65, 0x6c, 0x2e, 0x43, 0x61, 0x6c, 0x6c, 0x54, 0x6f, 0x41, 0x63, 0x74, 0x69, 0x6f, + 0x6e, 0x2e, 0x44, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x56, 0x65, 0x72, 0x74, 0x65, 0x78, 0x42, 0x03, + 0xe0, 0x41, 0x01, 0x52, 0x11, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x44, 0x65, 0x70, 0x6c, 0x6f, 0x79, + 0x56, 0x65, 0x72, 0x74, 0x65, 0x78, 0x12, 0x6a, 0x0a, 0x0a, 0x64, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x5f, 0x67, 0x6b, 0x65, 0x18, 0x0e, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x46, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x50, 0x75, 0x62, @@ -1542,133 +1607,141 @@ var file_google_cloud_aiplatform_v1beta1_publisher_model_proto_rawDesc = []byte{ 0x69, 0x6f, 0x6e, 0x61, 0x6c, 0x52, 0x65, 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, 0x52, 0x65, 0x66, 0x65, 0x72, 0x65, 0x6e, 0x63, 0x65, 0x73, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x13, 0x66, 0x69, 0x6e, 0x65, 0x54, 0x75, 0x6e, 0x69, 0x6e, 0x67, 0x50, 0x69, 0x70, 0x65, 0x6c, 0x69, 0x6e, 0x65, - 0x73, 0x1a, 0xf4, 0x08, 0x0a, 0x06, 0x44, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x12, 0x66, 0x0a, 0x13, - 0x64, 0x65, 0x64, 0x69, 0x63, 0x61, 0x74, 0x65, 0x64, 0x5f, 0x72, 0x65, 0x73, 0x6f, 0x75, 0x72, - 0x63, 0x65, 0x73, 0x18, 0x05, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x33, 0x2e, 0x67, 0x6f, 0x6f, 0x67, - 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, - 0x6f, 0x72, 0x6d, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x44, 0x65, 0x64, 0x69, - 0x63, 0x61, 0x74, 0x65, 0x64, 0x52, 0x65, 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, 0x73, 0x48, 0x00, - 0x52, 0x12, 0x64, 0x65, 0x64, 0x69, 0x63, 0x61, 0x74, 0x65, 0x64, 0x52, 0x65, 0x73, 0x6f, 0x75, - 0x72, 0x63, 0x65, 0x73, 0x12, 0x66, 0x0a, 0x13, 0x61, 0x75, 0x74, 0x6f, 0x6d, 0x61, 0x74, 0x69, - 0x63, 0x5f, 0x72, 0x65, 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, 0x73, 0x18, 0x06, 0x20, 0x01, 0x28, - 0x0b, 0x32, 0x33, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, - 0x2e, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x76, 0x31, 0x62, 0x65, - 0x74, 0x61, 0x31, 0x2e, 0x41, 0x75, 0x74, 0x6f, 0x6d, 0x61, 0x74, 0x69, 0x63, 0x52, 0x65, 0x73, - 0x6f, 0x75, 0x72, 0x63, 0x65, 0x73, 0x48, 0x00, 0x52, 0x12, 0x61, 0x75, 0x74, 0x6f, 0x6d, 0x61, - 0x74, 0x69, 0x63, 0x52, 0x65, 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, 0x73, 0x12, 0x2b, 0x0a, 0x10, - 0x73, 0x68, 0x61, 0x72, 0x65, 0x64, 0x5f, 0x72, 0x65, 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, 0x73, - 0x18, 0x07, 0x20, 0x01, 0x28, 0x09, 0x48, 0x00, 0x52, 0x0f, 0x73, 0x68, 0x61, 0x72, 0x65, 0x64, - 0x52, 0x65, 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, 0x73, 0x12, 0x31, 0x0a, 0x12, 0x6d, 0x6f, 0x64, - 0x65, 0x6c, 0x5f, 0x64, 0x69, 0x73, 0x70, 0x6c, 0x61, 0x79, 0x5f, 0x6e, 0x61, 0x6d, 0x65, 0x18, - 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x10, 0x6d, 0x6f, 0x64, 0x65, - 0x6c, 0x44, 0x69, 0x73, 0x70, 0x6c, 0x61, 0x79, 0x4e, 0x61, 0x6d, 0x65, 0x12, 0x6d, 0x0a, 0x15, - 0x6c, 0x61, 0x72, 0x67, 0x65, 0x5f, 0x6d, 0x6f, 0x64, 0x65, 0x6c, 0x5f, 0x72, 0x65, 0x66, 0x65, - 0x72, 0x65, 0x6e, 0x63, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x34, 0x2e, 0x67, 0x6f, - 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x61, 0x69, 0x70, 0x6c, 0x61, - 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x4c, 0x61, - 0x72, 0x67, 0x65, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x52, 0x65, 0x66, 0x65, 0x72, 0x65, 0x6e, 0x63, - 0x65, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x13, 0x6c, 0x61, 0x72, 0x67, 0x65, 0x4d, 0x6f, 0x64, - 0x65, 0x6c, 0x52, 0x65, 0x66, 0x65, 0x72, 0x65, 0x6e, 0x63, 0x65, 0x12, 0x5f, 0x0a, 0x0e, 0x63, - 0x6f, 0x6e, 0x74, 0x61, 0x69, 0x6e, 0x65, 0x72, 0x5f, 0x73, 0x70, 0x65, 0x63, 0x18, 0x03, 0x20, - 0x01, 0x28, 0x0b, 0x32, 0x33, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, - 0x75, 0x64, 0x2e, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x76, 0x31, - 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x43, 0x6f, 0x6e, 0x74, 0x61, - 0x69, 0x6e, 0x65, 0x72, 0x53, 0x70, 0x65, 0x63, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0d, 0x63, - 0x6f, 0x6e, 0x74, 0x61, 0x69, 0x6e, 0x65, 0x72, 0x53, 0x70, 0x65, 0x63, 0x12, 0x26, 0x0a, 0x0c, - 0x61, 0x72, 0x74, 0x69, 0x66, 0x61, 0x63, 0x74, 0x5f, 0x75, 0x72, 0x69, 0x18, 0x04, 0x20, 0x01, - 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0b, 0x61, 0x72, 0x74, 0x69, 0x66, 0x61, 0x63, - 0x74, 0x55, 0x72, 0x69, 0x12, 0x32, 0x0a, 0x10, 0x64, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x5f, 0x74, - 0x61, 0x73, 0x6b, 0x5f, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x0a, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, - 0xe0, 0x41, 0x01, 0x48, 0x01, 0x52, 0x0e, 0x64, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x54, 0x61, 0x73, - 0x6b, 0x4e, 0x61, 0x6d, 0x65, 0x88, 0x01, 0x01, 0x12, 0x85, 0x01, 0x0a, 0x0f, 0x64, 0x65, 0x70, - 0x6c, 0x6f, 0x79, 0x5f, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x18, 0x0b, 0x20, 0x01, - 0x28, 0x0b, 0x32, 0x52, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, - 0x64, 0x2e, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x76, 0x31, 0x62, - 0x65, 0x74, 0x61, 0x31, 0x2e, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, - 0x64, 0x65, 0x6c, 0x2e, 0x43, 0x61, 0x6c, 0x6c, 0x54, 0x6f, 0x41, 0x63, 0x74, 0x69, 0x6f, 0x6e, - 0x2e, 0x44, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x2e, 0x44, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x4d, 0x65, - 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x48, 0x02, 0x52, 0x0e, 0x64, - 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x88, 0x01, 0x01, - 0x12, 0x19, 0x0a, 0x05, 0x74, 0x69, 0x74, 0x6c, 0x65, 0x18, 0x08, 0x20, 0x01, 0x28, 0x09, 0x42, - 0x03, 0xe0, 0x41, 0x02, 0x52, 0x05, 0x74, 0x69, 0x74, 0x6c, 0x65, 0x12, 0x33, 0x0a, 0x13, 0x70, - 0x75, 0x62, 0x6c, 0x69, 0x63, 0x5f, 0x61, 0x72, 0x74, 0x69, 0x66, 0x61, 0x63, 0x74, 0x5f, 0x75, - 0x72, 0x69, 0x18, 0x09, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x11, 0x70, - 0x75, 0x62, 0x6c, 0x69, 0x63, 0x41, 0x72, 0x74, 0x69, 0x66, 0x61, 0x63, 0x74, 0x55, 0x72, 0x69, - 0x1a, 0xf4, 0x01, 0x0a, 0x0e, 0x44, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x4d, 0x65, 0x74, 0x61, 0x64, - 0x61, 0x74, 0x61, 0x12, 0x7b, 0x0a, 0x06, 0x6c, 0x61, 0x62, 0x65, 0x6c, 0x73, 0x18, 0x01, 0x20, - 0x03, 0x28, 0x0b, 0x32, 0x5e, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, - 0x75, 0x64, 0x2e, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x76, 0x31, - 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, - 0x6f, 0x64, 0x65, 0x6c, 0x2e, 0x43, 0x61, 0x6c, 0x6c, 0x54, 0x6f, 0x41, 0x63, 0x74, 0x69, 0x6f, - 0x6e, 0x2e, 0x44, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x2e, 0x44, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x4d, - 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x2e, 0x4c, 0x61, 0x62, 0x65, 0x6c, 0x73, 0x45, 0x6e, - 0x74, 0x72, 0x79, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x06, 0x6c, 0x61, 0x62, 0x65, 0x6c, 0x73, - 0x12, 0x2a, 0x0a, 0x0e, 0x73, 0x61, 0x6d, 0x70, 0x6c, 0x65, 0x5f, 0x72, 0x65, 0x71, 0x75, 0x65, - 0x73, 0x74, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0d, 0x73, - 0x61, 0x6d, 0x70, 0x6c, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x39, 0x0a, 0x0b, - 0x4c, 0x61, 0x62, 0x65, 0x6c, 0x73, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, 0x03, 0x6b, - 0x65, 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x14, 0x0a, - 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, 0x61, - 0x6c, 0x75, 0x65, 0x3a, 0x02, 0x38, 0x01, 0x42, 0x16, 0x0a, 0x14, 0x70, 0x72, 0x65, 0x64, 0x69, - 0x63, 0x74, 0x69, 0x6f, 0x6e, 0x5f, 0x72, 0x65, 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, 0x73, 0x42, - 0x13, 0x0a, 0x11, 0x5f, 0x64, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x5f, 0x74, 0x61, 0x73, 0x6b, 0x5f, - 0x6e, 0x61, 0x6d, 0x65, 0x42, 0x12, 0x0a, 0x10, 0x5f, 0x64, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x5f, - 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x1a, 0x3a, 0x0a, 0x09, 0x44, 0x65, 0x70, 0x6c, - 0x6f, 0x79, 0x47, 0x6b, 0x65, 0x12, 0x2d, 0x0a, 0x10, 0x67, 0x6b, 0x65, 0x5f, 0x79, 0x61, 0x6d, - 0x6c, 0x5f, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x73, 0x18, 0x01, 0x20, 0x03, 0x28, 0x09, 0x42, - 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0e, 0x67, 0x6b, 0x65, 0x59, 0x61, 0x6d, 0x6c, 0x43, 0x6f, 0x6e, - 0x66, 0x69, 0x67, 0x73, 0x42, 0x11, 0x0a, 0x0f, 0x5f, 0x6f, 0x70, 0x65, 0x6e, 0x5f, 0x6e, 0x6f, - 0x74, 0x65, 0x62, 0x6f, 0x6f, 0x6b, 0x73, 0x42, 0x1d, 0x0a, 0x1b, 0x5f, 0x6f, 0x70, 0x65, 0x6e, - 0x5f, 0x66, 0x69, 0x6e, 0x65, 0x5f, 0x74, 0x75, 0x6e, 0x69, 0x6e, 0x67, 0x5f, 0x70, 0x69, 0x70, - 0x65, 0x6c, 0x69, 0x6e, 0x65, 0x73, 0x22, 0xdb, 0x01, 0x0a, 0x12, 0x4f, 0x70, 0x65, 0x6e, 0x53, - 0x6f, 0x75, 0x72, 0x63, 0x65, 0x43, 0x61, 0x74, 0x65, 0x67, 0x6f, 0x72, 0x79, 0x12, 0x24, 0x0a, - 0x20, 0x4f, 0x50, 0x45, 0x4e, 0x5f, 0x53, 0x4f, 0x55, 0x52, 0x43, 0x45, 0x5f, 0x43, 0x41, 0x54, - 0x45, 0x47, 0x4f, 0x52, 0x59, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, - 0x44, 0x10, 0x00, 0x12, 0x0f, 0x0a, 0x0b, 0x50, 0x52, 0x4f, 0x50, 0x52, 0x49, 0x45, 0x54, 0x41, - 0x52, 0x59, 0x10, 0x01, 0x12, 0x2b, 0x0a, 0x27, 0x47, 0x4f, 0x4f, 0x47, 0x4c, 0x45, 0x5f, 0x4f, - 0x57, 0x4e, 0x45, 0x44, 0x5f, 0x4f, 0x53, 0x53, 0x5f, 0x57, 0x49, 0x54, 0x48, 0x5f, 0x47, 0x4f, - 0x4f, 0x47, 0x4c, 0x45, 0x5f, 0x43, 0x48, 0x45, 0x43, 0x4b, 0x50, 0x4f, 0x49, 0x4e, 0x54, 0x10, - 0x02, 0x12, 0x30, 0x0a, 0x2c, 0x54, 0x48, 0x49, 0x52, 0x44, 0x5f, 0x50, 0x41, 0x52, 0x54, 0x59, - 0x5f, 0x4f, 0x57, 0x4e, 0x45, 0x44, 0x5f, 0x4f, 0x53, 0x53, 0x5f, 0x57, 0x49, 0x54, 0x48, 0x5f, - 0x47, 0x4f, 0x4f, 0x47, 0x4c, 0x45, 0x5f, 0x43, 0x48, 0x45, 0x43, 0x4b, 0x50, 0x4f, 0x49, 0x4e, - 0x54, 0x10, 0x03, 0x12, 0x14, 0x0a, 0x10, 0x47, 0x4f, 0x4f, 0x47, 0x4c, 0x45, 0x5f, 0x4f, 0x57, - 0x4e, 0x45, 0x44, 0x5f, 0x4f, 0x53, 0x53, 0x10, 0x04, 0x12, 0x19, 0x0a, 0x15, 0x54, 0x48, 0x49, - 0x52, 0x44, 0x5f, 0x50, 0x41, 0x52, 0x54, 0x59, 0x5f, 0x4f, 0x57, 0x4e, 0x45, 0x44, 0x5f, 0x4f, - 0x53, 0x53, 0x10, 0x05, 0x22, 0x6e, 0x0a, 0x0b, 0x4c, 0x61, 0x75, 0x6e, 0x63, 0x68, 0x53, 0x74, - 0x61, 0x67, 0x65, 0x12, 0x1c, 0x0a, 0x18, 0x4c, 0x41, 0x55, 0x4e, 0x43, 0x48, 0x5f, 0x53, 0x54, - 0x41, 0x47, 0x45, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, - 0x00, 0x12, 0x10, 0x0a, 0x0c, 0x45, 0x58, 0x50, 0x45, 0x52, 0x49, 0x4d, 0x45, 0x4e, 0x54, 0x41, - 0x4c, 0x10, 0x01, 0x12, 0x13, 0x0a, 0x0f, 0x50, 0x52, 0x49, 0x56, 0x41, 0x54, 0x45, 0x5f, 0x50, - 0x52, 0x45, 0x56, 0x49, 0x45, 0x57, 0x10, 0x02, 0x12, 0x12, 0x0a, 0x0e, 0x50, 0x55, 0x42, 0x4c, - 0x49, 0x43, 0x5f, 0x50, 0x52, 0x45, 0x56, 0x49, 0x45, 0x57, 0x10, 0x03, 0x12, 0x06, 0x0a, 0x02, - 0x47, 0x41, 0x10, 0x04, 0x22, 0x63, 0x0a, 0x0c, 0x56, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x53, - 0x74, 0x61, 0x74, 0x65, 0x12, 0x1d, 0x0a, 0x19, 0x56, 0x45, 0x52, 0x53, 0x49, 0x4f, 0x4e, 0x5f, - 0x53, 0x54, 0x41, 0x54, 0x45, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, - 0x44, 0x10, 0x00, 0x12, 0x18, 0x0a, 0x14, 0x56, 0x45, 0x52, 0x53, 0x49, 0x4f, 0x4e, 0x5f, 0x53, - 0x54, 0x41, 0x54, 0x45, 0x5f, 0x53, 0x54, 0x41, 0x42, 0x4c, 0x45, 0x10, 0x01, 0x12, 0x1a, 0x0a, - 0x16, 0x56, 0x45, 0x52, 0x53, 0x49, 0x4f, 0x4e, 0x5f, 0x53, 0x54, 0x41, 0x54, 0x45, 0x5f, 0x55, - 0x4e, 0x53, 0x54, 0x41, 0x42, 0x4c, 0x45, 0x10, 0x02, 0x3a, 0x54, 0xea, 0x41, 0x51, 0x0a, 0x28, - 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, - 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, - 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x12, 0x25, 0x70, 0x75, 0x62, 0x6c, 0x69, 0x73, - 0x68, 0x65, 0x72, 0x73, 0x2f, 0x7b, 0x70, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x7d, - 0x2f, 0x6d, 0x6f, 0x64, 0x65, 0x6c, 0x73, 0x2f, 0x7b, 0x6d, 0x6f, 0x64, 0x65, 0x6c, 0x7d, 0x42, - 0xea, 0x01, 0x0a, 0x23, 0x63, 0x6f, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, - 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, - 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x42, 0x13, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, - 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x50, 0x72, 0x6f, 0x74, 0x6f, 0x50, 0x01, 0x5a, 0x43, - 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6f, 0x6d, - 0x2f, 0x67, 0x6f, 0x2f, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2f, 0x61, - 0x70, 0x69, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, - 0x66, 0x6f, 0x72, 0x6d, 0x70, 0x62, 0x3b, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, - 0x6d, 0x70, 0x62, 0xaa, 0x02, 0x1f, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x43, 0x6c, 0x6f, - 0x75, 0x64, 0x2e, 0x41, 0x49, 0x50, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x56, 0x31, - 0x42, 0x65, 0x74, 0x61, 0x31, 0xca, 0x02, 0x1f, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x5c, 0x43, - 0x6c, 0x6f, 0x75, 0x64, 0x5c, 0x41, 0x49, 0x50, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x5c, - 0x56, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0xea, 0x02, 0x22, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, - 0x3a, 0x3a, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x3a, 0x3a, 0x41, 0x49, 0x50, 0x6c, 0x61, 0x74, 0x66, - 0x6f, 0x72, 0x6d, 0x3a, 0x3a, 0x56, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x62, 0x06, 0x70, 0x72, - 0x6f, 0x74, 0x6f, 0x33, + 0x73, 0x1a, 0x88, 0x01, 0x0a, 0x0c, 0x44, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x56, 0x65, 0x72, 0x74, + 0x65, 0x78, 0x12, 0x78, 0x0a, 0x13, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x5f, 0x64, 0x65, 0x70, 0x6c, + 0x6f, 0x79, 0x5f, 0x76, 0x65, 0x72, 0x74, 0x65, 0x78, 0x18, 0x01, 0x20, 0x03, 0x28, 0x0b, 0x32, + 0x43, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x61, + 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, + 0x31, 0x2e, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, + 0x2e, 0x43, 0x61, 0x6c, 0x6c, 0x54, 0x6f, 0x41, 0x63, 0x74, 0x69, 0x6f, 0x6e, 0x2e, 0x44, 0x65, + 0x70, 0x6c, 0x6f, 0x79, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x11, 0x6d, 0x75, 0x6c, 0x74, 0x69, + 0x44, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x56, 0x65, 0x72, 0x74, 0x65, 0x78, 0x1a, 0xf4, 0x08, 0x0a, + 0x06, 0x44, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x12, 0x66, 0x0a, 0x13, 0x64, 0x65, 0x64, 0x69, 0x63, + 0x61, 0x74, 0x65, 0x64, 0x5f, 0x72, 0x65, 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, 0x73, 0x18, 0x05, + 0x20, 0x01, 0x28, 0x0b, 0x32, 0x33, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, + 0x6f, 0x75, 0x64, 0x2e, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x76, + 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x44, 0x65, 0x64, 0x69, 0x63, 0x61, 0x74, 0x65, 0x64, + 0x52, 0x65, 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, 0x73, 0x48, 0x00, 0x52, 0x12, 0x64, 0x65, 0x64, + 0x69, 0x63, 0x61, 0x74, 0x65, 0x64, 0x52, 0x65, 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, 0x73, 0x12, + 0x66, 0x0a, 0x13, 0x61, 0x75, 0x74, 0x6f, 0x6d, 0x61, 0x74, 0x69, 0x63, 0x5f, 0x72, 0x65, 0x73, + 0x6f, 0x75, 0x72, 0x63, 0x65, 0x73, 0x18, 0x06, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x33, 0x2e, 0x67, + 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x61, 0x69, 0x70, 0x6c, + 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x41, + 0x75, 0x74, 0x6f, 0x6d, 0x61, 0x74, 0x69, 0x63, 0x52, 0x65, 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, + 0x73, 0x48, 0x00, 0x52, 0x12, 0x61, 0x75, 0x74, 0x6f, 0x6d, 0x61, 0x74, 0x69, 0x63, 0x52, 0x65, + 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, 0x73, 0x12, 0x2b, 0x0a, 0x10, 0x73, 0x68, 0x61, 0x72, 0x65, + 0x64, 0x5f, 0x72, 0x65, 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, 0x73, 0x18, 0x07, 0x20, 0x01, 0x28, + 0x09, 0x48, 0x00, 0x52, 0x0f, 0x73, 0x68, 0x61, 0x72, 0x65, 0x64, 0x52, 0x65, 0x73, 0x6f, 0x75, + 0x72, 0x63, 0x65, 0x73, 0x12, 0x31, 0x0a, 0x12, 0x6d, 0x6f, 0x64, 0x65, 0x6c, 0x5f, 0x64, 0x69, + 0x73, 0x70, 0x6c, 0x61, 0x79, 0x5f, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, + 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x10, 0x6d, 0x6f, 0x64, 0x65, 0x6c, 0x44, 0x69, 0x73, 0x70, + 0x6c, 0x61, 0x79, 0x4e, 0x61, 0x6d, 0x65, 0x12, 0x6d, 0x0a, 0x15, 0x6c, 0x61, 0x72, 0x67, 0x65, + 0x5f, 0x6d, 0x6f, 0x64, 0x65, 0x6c, 0x5f, 0x72, 0x65, 0x66, 0x65, 0x72, 0x65, 0x6e, 0x63, 0x65, + 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x34, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, + 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, + 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x4c, 0x61, 0x72, 0x67, 0x65, 0x4d, 0x6f, + 0x64, 0x65, 0x6c, 0x52, 0x65, 0x66, 0x65, 0x72, 0x65, 0x6e, 0x63, 0x65, 0x42, 0x03, 0xe0, 0x41, + 0x01, 0x52, 0x13, 0x6c, 0x61, 0x72, 0x67, 0x65, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x52, 0x65, 0x66, + 0x65, 0x72, 0x65, 0x6e, 0x63, 0x65, 0x12, 0x5f, 0x0a, 0x0e, 0x63, 0x6f, 0x6e, 0x74, 0x61, 0x69, + 0x6e, 0x65, 0x72, 0x5f, 0x73, 0x70, 0x65, 0x63, 0x18, 0x03, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x33, + 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x61, 0x69, + 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, + 0x2e, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x43, 0x6f, 0x6e, 0x74, 0x61, 0x69, 0x6e, 0x65, 0x72, 0x53, + 0x70, 0x65, 0x63, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0d, 0x63, 0x6f, 0x6e, 0x74, 0x61, 0x69, + 0x6e, 0x65, 0x72, 0x53, 0x70, 0x65, 0x63, 0x12, 0x26, 0x0a, 0x0c, 0x61, 0x72, 0x74, 0x69, 0x66, + 0x61, 0x63, 0x74, 0x5f, 0x75, 0x72, 0x69, 0x18, 0x04, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, + 0x41, 0x01, 0x52, 0x0b, 0x61, 0x72, 0x74, 0x69, 0x66, 0x61, 0x63, 0x74, 0x55, 0x72, 0x69, 0x12, + 0x32, 0x0a, 0x10, 0x64, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x5f, 0x74, 0x61, 0x73, 0x6b, 0x5f, 0x6e, + 0x61, 0x6d, 0x65, 0x18, 0x0a, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x48, 0x01, + 0x52, 0x0e, 0x64, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x54, 0x61, 0x73, 0x6b, 0x4e, 0x61, 0x6d, 0x65, + 0x88, 0x01, 0x01, 0x12, 0x85, 0x01, 0x0a, 0x0f, 0x64, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x5f, 0x6d, + 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x18, 0x0b, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x52, 0x2e, + 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x61, 0x69, 0x70, + 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, + 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x2e, 0x43, + 0x61, 0x6c, 0x6c, 0x54, 0x6f, 0x41, 0x63, 0x74, 0x69, 0x6f, 0x6e, 0x2e, 0x44, 0x65, 0x70, 0x6c, + 0x6f, 0x79, 0x2e, 0x44, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, + 0x61, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x48, 0x02, 0x52, 0x0e, 0x64, 0x65, 0x70, 0x6c, 0x6f, 0x79, + 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x88, 0x01, 0x01, 0x12, 0x19, 0x0a, 0x05, 0x74, + 0x69, 0x74, 0x6c, 0x65, 0x18, 0x08, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, + 0x05, 0x74, 0x69, 0x74, 0x6c, 0x65, 0x12, 0x33, 0x0a, 0x13, 0x70, 0x75, 0x62, 0x6c, 0x69, 0x63, + 0x5f, 0x61, 0x72, 0x74, 0x69, 0x66, 0x61, 0x63, 0x74, 0x5f, 0x75, 0x72, 0x69, 0x18, 0x09, 0x20, + 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x11, 0x70, 0x75, 0x62, 0x6c, 0x69, 0x63, + 0x41, 0x72, 0x74, 0x69, 0x66, 0x61, 0x63, 0x74, 0x55, 0x72, 0x69, 0x1a, 0xf4, 0x01, 0x0a, 0x0e, + 0x44, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x12, 0x7b, + 0x0a, 0x06, 0x6c, 0x61, 0x62, 0x65, 0x6c, 0x73, 0x18, 0x01, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x5e, + 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x61, 0x69, + 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, + 0x2e, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, 0x65, 0x6c, 0x2e, + 0x43, 0x61, 0x6c, 0x6c, 0x54, 0x6f, 0x41, 0x63, 0x74, 0x69, 0x6f, 0x6e, 0x2e, 0x44, 0x65, 0x70, + 0x6c, 0x6f, 0x79, 0x2e, 0x44, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, + 0x74, 0x61, 0x2e, 0x4c, 0x61, 0x62, 0x65, 0x6c, 0x73, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x42, 0x03, + 0xe0, 0x41, 0x01, 0x52, 0x06, 0x6c, 0x61, 0x62, 0x65, 0x6c, 0x73, 0x12, 0x2a, 0x0a, 0x0e, 0x73, + 0x61, 0x6d, 0x70, 0x6c, 0x65, 0x5f, 0x72, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x18, 0x02, 0x20, + 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0d, 0x73, 0x61, 0x6d, 0x70, 0x6c, 0x65, + 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x39, 0x0a, 0x0b, 0x4c, 0x61, 0x62, 0x65, 0x6c, + 0x73, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, 0x03, 0x6b, 0x65, 0x79, 0x18, 0x01, 0x20, + 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x14, 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, + 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x3a, 0x02, + 0x38, 0x01, 0x42, 0x16, 0x0a, 0x14, 0x70, 0x72, 0x65, 0x64, 0x69, 0x63, 0x74, 0x69, 0x6f, 0x6e, + 0x5f, 0x72, 0x65, 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, 0x73, 0x42, 0x13, 0x0a, 0x11, 0x5f, 0x64, + 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x5f, 0x74, 0x61, 0x73, 0x6b, 0x5f, 0x6e, 0x61, 0x6d, 0x65, 0x42, + 0x12, 0x0a, 0x10, 0x5f, 0x64, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x5f, 0x6d, 0x65, 0x74, 0x61, 0x64, + 0x61, 0x74, 0x61, 0x1a, 0x3a, 0x0a, 0x09, 0x44, 0x65, 0x70, 0x6c, 0x6f, 0x79, 0x47, 0x6b, 0x65, + 0x12, 0x2d, 0x0a, 0x10, 0x67, 0x6b, 0x65, 0x5f, 0x79, 0x61, 0x6d, 0x6c, 0x5f, 0x63, 0x6f, 0x6e, + 0x66, 0x69, 0x67, 0x73, 0x18, 0x01, 0x20, 0x03, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, + 0x0e, 0x67, 0x6b, 0x65, 0x59, 0x61, 0x6d, 0x6c, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x73, 0x42, + 0x11, 0x0a, 0x0f, 0x5f, 0x6f, 0x70, 0x65, 0x6e, 0x5f, 0x6e, 0x6f, 0x74, 0x65, 0x62, 0x6f, 0x6f, + 0x6b, 0x73, 0x42, 0x1d, 0x0a, 0x1b, 0x5f, 0x6f, 0x70, 0x65, 0x6e, 0x5f, 0x66, 0x69, 0x6e, 0x65, + 0x5f, 0x74, 0x75, 0x6e, 0x69, 0x6e, 0x67, 0x5f, 0x70, 0x69, 0x70, 0x65, 0x6c, 0x69, 0x6e, 0x65, + 0x73, 0x22, 0xdb, 0x01, 0x0a, 0x12, 0x4f, 0x70, 0x65, 0x6e, 0x53, 0x6f, 0x75, 0x72, 0x63, 0x65, + 0x43, 0x61, 0x74, 0x65, 0x67, 0x6f, 0x72, 0x79, 0x12, 0x24, 0x0a, 0x20, 0x4f, 0x50, 0x45, 0x4e, + 0x5f, 0x53, 0x4f, 0x55, 0x52, 0x43, 0x45, 0x5f, 0x43, 0x41, 0x54, 0x45, 0x47, 0x4f, 0x52, 0x59, + 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x0f, + 0x0a, 0x0b, 0x50, 0x52, 0x4f, 0x50, 0x52, 0x49, 0x45, 0x54, 0x41, 0x52, 0x59, 0x10, 0x01, 0x12, + 0x2b, 0x0a, 0x27, 0x47, 0x4f, 0x4f, 0x47, 0x4c, 0x45, 0x5f, 0x4f, 0x57, 0x4e, 0x45, 0x44, 0x5f, + 0x4f, 0x53, 0x53, 0x5f, 0x57, 0x49, 0x54, 0x48, 0x5f, 0x47, 0x4f, 0x4f, 0x47, 0x4c, 0x45, 0x5f, + 0x43, 0x48, 0x45, 0x43, 0x4b, 0x50, 0x4f, 0x49, 0x4e, 0x54, 0x10, 0x02, 0x12, 0x30, 0x0a, 0x2c, + 0x54, 0x48, 0x49, 0x52, 0x44, 0x5f, 0x50, 0x41, 0x52, 0x54, 0x59, 0x5f, 0x4f, 0x57, 0x4e, 0x45, + 0x44, 0x5f, 0x4f, 0x53, 0x53, 0x5f, 0x57, 0x49, 0x54, 0x48, 0x5f, 0x47, 0x4f, 0x4f, 0x47, 0x4c, + 0x45, 0x5f, 0x43, 0x48, 0x45, 0x43, 0x4b, 0x50, 0x4f, 0x49, 0x4e, 0x54, 0x10, 0x03, 0x12, 0x14, + 0x0a, 0x10, 0x47, 0x4f, 0x4f, 0x47, 0x4c, 0x45, 0x5f, 0x4f, 0x57, 0x4e, 0x45, 0x44, 0x5f, 0x4f, + 0x53, 0x53, 0x10, 0x04, 0x12, 0x19, 0x0a, 0x15, 0x54, 0x48, 0x49, 0x52, 0x44, 0x5f, 0x50, 0x41, + 0x52, 0x54, 0x59, 0x5f, 0x4f, 0x57, 0x4e, 0x45, 0x44, 0x5f, 0x4f, 0x53, 0x53, 0x10, 0x05, 0x22, + 0x6e, 0x0a, 0x0b, 0x4c, 0x61, 0x75, 0x6e, 0x63, 0x68, 0x53, 0x74, 0x61, 0x67, 0x65, 0x12, 0x1c, + 0x0a, 0x18, 0x4c, 0x41, 0x55, 0x4e, 0x43, 0x48, 0x5f, 0x53, 0x54, 0x41, 0x47, 0x45, 0x5f, 0x55, + 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x10, 0x0a, 0x0c, + 0x45, 0x58, 0x50, 0x45, 0x52, 0x49, 0x4d, 0x45, 0x4e, 0x54, 0x41, 0x4c, 0x10, 0x01, 0x12, 0x13, + 0x0a, 0x0f, 0x50, 0x52, 0x49, 0x56, 0x41, 0x54, 0x45, 0x5f, 0x50, 0x52, 0x45, 0x56, 0x49, 0x45, + 0x57, 0x10, 0x02, 0x12, 0x12, 0x0a, 0x0e, 0x50, 0x55, 0x42, 0x4c, 0x49, 0x43, 0x5f, 0x50, 0x52, + 0x45, 0x56, 0x49, 0x45, 0x57, 0x10, 0x03, 0x12, 0x06, 0x0a, 0x02, 0x47, 0x41, 0x10, 0x04, 0x22, + 0x63, 0x0a, 0x0c, 0x56, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x53, 0x74, 0x61, 0x74, 0x65, 0x12, + 0x1d, 0x0a, 0x19, 0x56, 0x45, 0x52, 0x53, 0x49, 0x4f, 0x4e, 0x5f, 0x53, 0x54, 0x41, 0x54, 0x45, + 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x18, + 0x0a, 0x14, 0x56, 0x45, 0x52, 0x53, 0x49, 0x4f, 0x4e, 0x5f, 0x53, 0x54, 0x41, 0x54, 0x45, 0x5f, + 0x53, 0x54, 0x41, 0x42, 0x4c, 0x45, 0x10, 0x01, 0x12, 0x1a, 0x0a, 0x16, 0x56, 0x45, 0x52, 0x53, + 0x49, 0x4f, 0x4e, 0x5f, 0x53, 0x54, 0x41, 0x54, 0x45, 0x5f, 0x55, 0x4e, 0x53, 0x54, 0x41, 0x42, + 0x4c, 0x45, 0x10, 0x02, 0x3a, 0x54, 0xea, 0x41, 0x51, 0x0a, 0x28, 0x61, 0x69, 0x70, 0x6c, 0x61, + 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, + 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, + 0x64, 0x65, 0x6c, 0x12, 0x25, 0x70, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x73, 0x2f, + 0x7b, 0x70, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x7d, 0x2f, 0x6d, 0x6f, 0x64, 0x65, + 0x6c, 0x73, 0x2f, 0x7b, 0x6d, 0x6f, 0x64, 0x65, 0x6c, 0x7d, 0x42, 0xea, 0x01, 0x0a, 0x23, 0x63, + 0x6f, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, + 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, + 0x61, 0x31, 0x42, 0x13, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x65, 0x72, 0x4d, 0x6f, 0x64, + 0x65, 0x6c, 0x50, 0x72, 0x6f, 0x74, 0x6f, 0x50, 0x01, 0x5a, 0x43, 0x63, 0x6c, 0x6f, 0x75, 0x64, + 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x67, 0x6f, 0x2f, 0x61, + 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2f, 0x61, 0x70, 0x69, 0x76, 0x31, 0x62, + 0x65, 0x74, 0x61, 0x31, 0x2f, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x70, + 0x62, 0x3b, 0x61, 0x69, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x70, 0x62, 0xaa, 0x02, + 0x1f, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x41, 0x49, + 0x50, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2e, 0x56, 0x31, 0x42, 0x65, 0x74, 0x61, 0x31, + 0xca, 0x02, 0x1f, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x5c, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x5c, + 0x41, 0x49, 0x50, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x5c, 0x56, 0x31, 0x62, 0x65, 0x74, + 0x61, 0x31, 0xea, 0x02, 0x22, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x3a, 0x3a, 0x43, 0x6c, 0x6f, + 0x75, 0x64, 0x3a, 0x3a, 0x41, 0x49, 0x50, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x3a, 0x3a, + 0x56, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, } var ( @@ -1684,7 +1757,7 @@ func file_google_cloud_aiplatform_v1beta1_publisher_model_proto_rawDescGZIP() [] } var file_google_cloud_aiplatform_v1beta1_publisher_model_proto_enumTypes = make([]protoimpl.EnumInfo, 3) -var file_google_cloud_aiplatform_v1beta1_publisher_model_proto_msgTypes = make([]protoimpl.MessageInfo, 14) +var file_google_cloud_aiplatform_v1beta1_publisher_model_proto_msgTypes = make([]protoimpl.MessageInfo, 15) var file_google_cloud_aiplatform_v1beta1_publisher_model_proto_goTypes = []any{ (PublisherModel_OpenSourceCategory)(0), // 0: google.cloud.aiplatform.v1beta1.PublisherModel.OpenSourceCategory (PublisherModel_LaunchStage)(0), // 1: google.cloud.aiplatform.v1beta1.PublisherModel.LaunchStage @@ -1698,16 +1771,17 @@ var file_google_cloud_aiplatform_v1beta1_publisher_model_proto_goTypes = []any{ (*PublisherModel_CallToAction_ViewRestApi)(nil), // 9: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.ViewRestApi (*PublisherModel_CallToAction_OpenNotebooks)(nil), // 10: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.OpenNotebooks (*PublisherModel_CallToAction_OpenFineTuningPipelines)(nil), // 11: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.OpenFineTuningPipelines - (*PublisherModel_CallToAction_Deploy)(nil), // 12: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.Deploy - (*PublisherModel_CallToAction_DeployGke)(nil), // 13: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.DeployGke - nil, // 14: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.RegionalResourceReferences.ReferencesEntry - (*PublisherModel_CallToAction_Deploy_DeployMetadata)(nil), // 15: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.Deploy.DeployMetadata - nil, // 16: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.Deploy.DeployMetadata.LabelsEntry - (*PredictSchemata)(nil), // 17: google.cloud.aiplatform.v1beta1.PredictSchemata - (*DedicatedResources)(nil), // 18: google.cloud.aiplatform.v1beta1.DedicatedResources - (*AutomaticResources)(nil), // 19: google.cloud.aiplatform.v1beta1.AutomaticResources - (*LargeModelReference)(nil), // 20: google.cloud.aiplatform.v1beta1.LargeModelReference - (*ModelContainerSpec)(nil), // 21: google.cloud.aiplatform.v1beta1.ModelContainerSpec + (*PublisherModel_CallToAction_DeployVertex)(nil), // 12: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.DeployVertex + (*PublisherModel_CallToAction_Deploy)(nil), // 13: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.Deploy + (*PublisherModel_CallToAction_DeployGke)(nil), // 14: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.DeployGke + nil, // 15: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.RegionalResourceReferences.ReferencesEntry + (*PublisherModel_CallToAction_Deploy_DeployMetadata)(nil), // 16: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.Deploy.DeployMetadata + nil, // 17: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.Deploy.DeployMetadata.LabelsEntry + (*PredictSchemata)(nil), // 18: google.cloud.aiplatform.v1beta1.PredictSchemata + (*DedicatedResources)(nil), // 19: google.cloud.aiplatform.v1beta1.DedicatedResources + (*AutomaticResources)(nil), // 20: google.cloud.aiplatform.v1beta1.AutomaticResources + (*LargeModelReference)(nil), // 21: google.cloud.aiplatform.v1beta1.LargeModelReference + (*ModelContainerSpec)(nil), // 22: google.cloud.aiplatform.v1beta1.ModelContainerSpec } var file_google_cloud_aiplatform_v1beta1_publisher_model_proto_depIdxs = []int32{ 0, // 0: google.cloud.aiplatform.v1beta1.PublisherModel.open_source_category:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.OpenSourceCategory @@ -1715,7 +1789,7 @@ var file_google_cloud_aiplatform_v1beta1_publisher_model_proto_depIdxs = []int32 7, // 2: google.cloud.aiplatform.v1beta1.PublisherModel.supported_actions:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction 1, // 3: google.cloud.aiplatform.v1beta1.PublisherModel.launch_stage:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.LaunchStage 2, // 4: google.cloud.aiplatform.v1beta1.PublisherModel.version_state:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.VersionState - 17, // 5: google.cloud.aiplatform.v1beta1.PublisherModel.predict_schemata:type_name -> google.cloud.aiplatform.v1beta1.PredictSchemata + 18, // 5: google.cloud.aiplatform.v1beta1.PublisherModel.predict_schemata:type_name -> google.cloud.aiplatform.v1beta1.PredictSchemata 4, // 6: google.cloud.aiplatform.v1beta1.PublisherModel.Parent.reference:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.ResourceReference 9, // 7: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.view_rest_api:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.ViewRestApi 8, // 8: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.open_notebook:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.RegionalResourceReferences @@ -1725,27 +1799,29 @@ var file_google_cloud_aiplatform_v1beta1_publisher_model_proto_depIdxs = []int32 11, // 12: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.open_fine_tuning_pipelines:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.OpenFineTuningPipelines 8, // 13: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.open_prompt_tuning_pipeline:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.RegionalResourceReferences 8, // 14: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.open_genie:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.RegionalResourceReferences - 12, // 15: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.deploy:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.Deploy - 13, // 16: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.deploy_gke:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.DeployGke - 8, // 17: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.open_generation_ai_studio:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.RegionalResourceReferences - 8, // 18: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.request_access:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.RegionalResourceReferences - 8, // 19: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.open_evaluation_pipeline:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.RegionalResourceReferences - 14, // 20: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.RegionalResourceReferences.references:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.RegionalResourceReferences.ReferencesEntry - 6, // 21: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.ViewRestApi.documentations:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.Documentation - 8, // 22: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.OpenNotebooks.notebooks:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.RegionalResourceReferences - 8, // 23: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.OpenFineTuningPipelines.fine_tuning_pipelines:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.RegionalResourceReferences - 18, // 24: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.Deploy.dedicated_resources:type_name -> google.cloud.aiplatform.v1beta1.DedicatedResources - 19, // 25: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.Deploy.automatic_resources:type_name -> google.cloud.aiplatform.v1beta1.AutomaticResources - 20, // 26: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.Deploy.large_model_reference:type_name -> google.cloud.aiplatform.v1beta1.LargeModelReference - 21, // 27: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.Deploy.container_spec:type_name -> google.cloud.aiplatform.v1beta1.ModelContainerSpec - 15, // 28: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.Deploy.deploy_metadata:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.Deploy.DeployMetadata - 4, // 29: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.RegionalResourceReferences.ReferencesEntry.value:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.ResourceReference - 16, // 30: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.Deploy.DeployMetadata.labels:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.Deploy.DeployMetadata.LabelsEntry - 31, // [31:31] is the sub-list for method output_type - 31, // [31:31] is the sub-list for method input_type - 31, // [31:31] is the sub-list for extension type_name - 31, // [31:31] is the sub-list for extension extendee - 0, // [0:31] is the sub-list for field type_name + 13, // 15: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.deploy:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.Deploy + 12, // 16: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.multi_deploy_vertex:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.DeployVertex + 14, // 17: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.deploy_gke:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.DeployGke + 8, // 18: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.open_generation_ai_studio:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.RegionalResourceReferences + 8, // 19: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.request_access:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.RegionalResourceReferences + 8, // 20: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.open_evaluation_pipeline:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.RegionalResourceReferences + 15, // 21: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.RegionalResourceReferences.references:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.RegionalResourceReferences.ReferencesEntry + 6, // 22: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.ViewRestApi.documentations:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.Documentation + 8, // 23: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.OpenNotebooks.notebooks:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.RegionalResourceReferences + 8, // 24: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.OpenFineTuningPipelines.fine_tuning_pipelines:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.RegionalResourceReferences + 13, // 25: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.DeployVertex.multi_deploy_vertex:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.Deploy + 19, // 26: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.Deploy.dedicated_resources:type_name -> google.cloud.aiplatform.v1beta1.DedicatedResources + 20, // 27: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.Deploy.automatic_resources:type_name -> google.cloud.aiplatform.v1beta1.AutomaticResources + 21, // 28: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.Deploy.large_model_reference:type_name -> google.cloud.aiplatform.v1beta1.LargeModelReference + 22, // 29: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.Deploy.container_spec:type_name -> google.cloud.aiplatform.v1beta1.ModelContainerSpec + 16, // 30: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.Deploy.deploy_metadata:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.Deploy.DeployMetadata + 4, // 31: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.RegionalResourceReferences.ReferencesEntry.value:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.ResourceReference + 17, // 32: google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.Deploy.DeployMetadata.labels:type_name -> google.cloud.aiplatform.v1beta1.PublisherModel.CallToAction.Deploy.DeployMetadata.LabelsEntry + 33, // [33:33] is the sub-list for method output_type + 33, // [33:33] is the sub-list for method input_type + 33, // [33:33] is the sub-list for extension type_name + 33, // [33:33] is the sub-list for extension extendee + 0, // [0:33] is the sub-list for field type_name } func init() { file_google_cloud_aiplatform_v1beta1_publisher_model_proto_init() } @@ -1763,7 +1839,7 @@ func file_google_cloud_aiplatform_v1beta1_publisher_model_proto_init() { } file_google_cloud_aiplatform_v1beta1_publisher_model_proto_msgTypes[4].OneofWrappers = []any{} file_google_cloud_aiplatform_v1beta1_publisher_model_proto_msgTypes[5].OneofWrappers = []any{} - file_google_cloud_aiplatform_v1beta1_publisher_model_proto_msgTypes[9].OneofWrappers = []any{ + file_google_cloud_aiplatform_v1beta1_publisher_model_proto_msgTypes[10].OneofWrappers = []any{ (*PublisherModel_CallToAction_Deploy_DedicatedResources)(nil), (*PublisherModel_CallToAction_Deploy_AutomaticResources)(nil), (*PublisherModel_CallToAction_Deploy_SharedResources)(nil), @@ -1774,7 +1850,7 @@ func file_google_cloud_aiplatform_v1beta1_publisher_model_proto_init() { GoPackagePath: reflect.TypeOf(x{}).PkgPath(), RawDescriptor: file_google_cloud_aiplatform_v1beta1_publisher_model_proto_rawDesc, NumEnums: 3, - NumMessages: 14, + NumMessages: 15, NumExtensions: 0, NumServices: 0, }, diff --git a/aiplatform/apiv1beta1/auxiliary.go b/aiplatform/apiv1beta1/auxiliary.go index e0541e667841..3e0183787ce2 100755 --- a/aiplatform/apiv1beta1/auxiliary.go +++ b/aiplatform/apiv1beta1/auxiliary.go @@ -4472,6 +4472,70 @@ func (op *DeployModelOperation) Name() string { return op.lro.Name() } +// DeployPublisherModelOperation manages a long-running operation from DeployPublisherModel. +type DeployPublisherModelOperation struct { + lro *longrunning.Operation + pollPath string +} + +// Wait blocks until the long-running operation is completed, returning the response and any errors encountered. +// +// See documentation of Poll for error-handling information. +func (op *DeployPublisherModelOperation) Wait(ctx context.Context, opts ...gax.CallOption) (*aiplatformpb.DeployPublisherModelResponse, error) { + opts = append([]gax.CallOption{gax.WithPath(op.pollPath)}, opts...) + var resp aiplatformpb.DeployPublisherModelResponse + if err := op.lro.WaitWithInterval(ctx, &resp, time.Minute, opts...); err != nil { + return nil, err + } + return &resp, nil +} + +// Poll fetches the latest state of the long-running operation. +// +// Poll also fetches the latest metadata, which can be retrieved by Metadata. +// +// If Poll fails, the error is returned and op is unmodified. If Poll succeeds and +// the operation has completed with failure, the error is returned and op.Done will return true. +// If Poll succeeds and the operation has completed successfully, +// op.Done will return true, and the response of the operation is returned. +// If Poll succeeds and the operation has not completed, the returned response and error are both nil. +func (op *DeployPublisherModelOperation) Poll(ctx context.Context, opts ...gax.CallOption) (*aiplatformpb.DeployPublisherModelResponse, error) { + opts = append([]gax.CallOption{gax.WithPath(op.pollPath)}, opts...) + var resp aiplatformpb.DeployPublisherModelResponse + if err := op.lro.Poll(ctx, &resp, opts...); err != nil { + return nil, err + } + if !op.Done() { + return nil, nil + } + return &resp, nil +} + +// Metadata returns metadata associated with the long-running operation. +// Metadata itself does not contact the server, but Poll does. +// To get the latest metadata, call this method after a successful call to Poll. +// If the metadata is not available, the returned metadata and error are both nil. +func (op *DeployPublisherModelOperation) Metadata() (*aiplatformpb.DeployPublisherModelOperationMetadata, error) { + var meta aiplatformpb.DeployPublisherModelOperationMetadata + if err := op.lro.Metadata(&meta); err == longrunning.ErrNoMetadata { + return nil, nil + } else if err != nil { + return nil, err + } + return &meta, nil +} + +// Done reports whether the long-running operation has completed. +func (op *DeployPublisherModelOperation) Done() bool { + return op.lro.Done() +} + +// Name returns the name of the long-running operation. +// The name is assigned by the server and is unique within the service from which the operation is created. +func (op *DeployPublisherModelOperation) Name() string { + return op.lro.Name() +} + // ExportDataOperation manages a long-running operation from ExportData. type ExportDataOperation struct { lro *longrunning.Operation diff --git a/aiplatform/apiv1beta1/gapic_metadata.json b/aiplatform/apiv1beta1/gapic_metadata.json index 963be89d07ef..816715ceaad4 100644 --- a/aiplatform/apiv1beta1/gapic_metadata.json +++ b/aiplatform/apiv1beta1/gapic_metadata.json @@ -4270,6 +4270,11 @@ "DeleteOperation" ] }, + "DeployPublisherModel": { + "methods": [ + "DeployPublisherModel" + ] + }, "GetIamPolicy": { "methods": [ "GetIamPolicy" @@ -4335,6 +4340,11 @@ "DeleteOperation" ] }, + "DeployPublisherModel": { + "methods": [ + "DeployPublisherModel" + ] + }, "GetIamPolicy": { "methods": [ "GetIamPolicy" diff --git a/aiplatform/apiv1beta1/model_garden_client.go b/aiplatform/apiv1beta1/model_garden_client.go index 761a7e2d57af..97c7e1f18c0b 100755 --- a/aiplatform/apiv1beta1/model_garden_client.go +++ b/aiplatform/apiv1beta1/model_garden_client.go @@ -27,6 +27,8 @@ import ( aiplatformpb "cloud.google.com/go/aiplatform/apiv1beta1/aiplatformpb" iampb "cloud.google.com/go/iam/apiv1/iampb" + "cloud.google.com/go/longrunning" + lroauto "cloud.google.com/go/longrunning/autogen" longrunningpb "cloud.google.com/go/longrunning/autogen/longrunningpb" gax "github.com/googleapis/gax-go/v2" "google.golang.org/api/iterator" @@ -44,18 +46,19 @@ var newModelGardenClientHook clientHook // ModelGardenCallOptions contains the retry settings for each method of ModelGardenClient. type ModelGardenCallOptions struct { - GetPublisherModel []gax.CallOption - ListPublisherModels []gax.CallOption - GetLocation []gax.CallOption - ListLocations []gax.CallOption - GetIamPolicy []gax.CallOption - SetIamPolicy []gax.CallOption - TestIamPermissions []gax.CallOption - CancelOperation []gax.CallOption - DeleteOperation []gax.CallOption - GetOperation []gax.CallOption - ListOperations []gax.CallOption - WaitOperation []gax.CallOption + GetPublisherModel []gax.CallOption + ListPublisherModels []gax.CallOption + DeployPublisherModel []gax.CallOption + GetLocation []gax.CallOption + ListLocations []gax.CallOption + GetIamPolicy []gax.CallOption + SetIamPolicy []gax.CallOption + TestIamPermissions []gax.CallOption + CancelOperation []gax.CallOption + DeleteOperation []gax.CallOption + GetOperation []gax.CallOption + ListOperations []gax.CallOption + WaitOperation []gax.CallOption } func defaultModelGardenGRPCClientOptions() []option.ClientOption { @@ -75,35 +78,37 @@ func defaultModelGardenGRPCClientOptions() []option.ClientOption { func defaultModelGardenCallOptions() *ModelGardenCallOptions { return &ModelGardenCallOptions{ - GetPublisherModel: []gax.CallOption{}, - ListPublisherModels: []gax.CallOption{}, - GetLocation: []gax.CallOption{}, - ListLocations: []gax.CallOption{}, - GetIamPolicy: []gax.CallOption{}, - SetIamPolicy: []gax.CallOption{}, - TestIamPermissions: []gax.CallOption{}, - CancelOperation: []gax.CallOption{}, - DeleteOperation: []gax.CallOption{}, - GetOperation: []gax.CallOption{}, - ListOperations: []gax.CallOption{}, - WaitOperation: []gax.CallOption{}, + GetPublisherModel: []gax.CallOption{}, + ListPublisherModels: []gax.CallOption{}, + DeployPublisherModel: []gax.CallOption{}, + GetLocation: []gax.CallOption{}, + ListLocations: []gax.CallOption{}, + GetIamPolicy: []gax.CallOption{}, + SetIamPolicy: []gax.CallOption{}, + TestIamPermissions: []gax.CallOption{}, + CancelOperation: []gax.CallOption{}, + DeleteOperation: []gax.CallOption{}, + GetOperation: []gax.CallOption{}, + ListOperations: []gax.CallOption{}, + WaitOperation: []gax.CallOption{}, } } func defaultModelGardenRESTCallOptions() *ModelGardenCallOptions { return &ModelGardenCallOptions{ - GetPublisherModel: []gax.CallOption{}, - ListPublisherModels: []gax.CallOption{}, - GetLocation: []gax.CallOption{}, - ListLocations: []gax.CallOption{}, - GetIamPolicy: []gax.CallOption{}, - SetIamPolicy: []gax.CallOption{}, - TestIamPermissions: []gax.CallOption{}, - CancelOperation: []gax.CallOption{}, - DeleteOperation: []gax.CallOption{}, - GetOperation: []gax.CallOption{}, - ListOperations: []gax.CallOption{}, - WaitOperation: []gax.CallOption{}, + GetPublisherModel: []gax.CallOption{}, + ListPublisherModels: []gax.CallOption{}, + DeployPublisherModel: []gax.CallOption{}, + GetLocation: []gax.CallOption{}, + ListLocations: []gax.CallOption{}, + GetIamPolicy: []gax.CallOption{}, + SetIamPolicy: []gax.CallOption{}, + TestIamPermissions: []gax.CallOption{}, + CancelOperation: []gax.CallOption{}, + DeleteOperation: []gax.CallOption{}, + GetOperation: []gax.CallOption{}, + ListOperations: []gax.CallOption{}, + WaitOperation: []gax.CallOption{}, } } @@ -114,6 +119,8 @@ type internalModelGardenClient interface { Connection() *grpc.ClientConn GetPublisherModel(context.Context, *aiplatformpb.GetPublisherModelRequest, ...gax.CallOption) (*aiplatformpb.PublisherModel, error) ListPublisherModels(context.Context, *aiplatformpb.ListPublisherModelsRequest, ...gax.CallOption) *PublisherModelIterator + DeployPublisherModel(context.Context, *aiplatformpb.DeployPublisherModelRequest, ...gax.CallOption) (*DeployPublisherModelOperation, error) + DeployPublisherModelOperation(name string) *DeployPublisherModelOperation GetLocation(context.Context, *locationpb.GetLocationRequest, ...gax.CallOption) (*locationpb.Location, error) ListLocations(context.Context, *locationpb.ListLocationsRequest, ...gax.CallOption) *LocationIterator GetIamPolicy(context.Context, *iampb.GetIamPolicyRequest, ...gax.CallOption) (*iampb.Policy, error) @@ -136,6 +143,11 @@ type ModelGardenClient struct { // The call options for this service. CallOptions *ModelGardenCallOptions + + // LROClient is used internally to handle long-running operations. + // It is exposed so that its CallOptions can be modified if required. + // Users should not Close this client. + LROClient *lroauto.OperationsClient } // Wrapper methods routed to the internal client. @@ -171,6 +183,17 @@ func (c *ModelGardenClient) ListPublisherModels(ctx context.Context, req *aiplat return c.internalClient.ListPublisherModels(ctx, req, opts...) } +// DeployPublisherModel deploys publisher models. +func (c *ModelGardenClient) DeployPublisherModel(ctx context.Context, req *aiplatformpb.DeployPublisherModelRequest, opts ...gax.CallOption) (*DeployPublisherModelOperation, error) { + return c.internalClient.DeployPublisherModel(ctx, req, opts...) +} + +// DeployPublisherModelOperation returns a new DeployPublisherModelOperation from a given name. +// The name must be that of a previously created DeployPublisherModelOperation, possibly from a different process. +func (c *ModelGardenClient) DeployPublisherModelOperation(name string) *DeployPublisherModelOperation { + return c.internalClient.DeployPublisherModelOperation(name) +} + // GetLocation gets information about a location. func (c *ModelGardenClient) GetLocation(ctx context.Context, req *locationpb.GetLocationRequest, opts ...gax.CallOption) (*locationpb.Location, error) { return c.internalClient.GetLocation(ctx, req, opts...) @@ -245,6 +268,11 @@ type modelGardenGRPCClient struct { // The gRPC API client. modelGardenClient aiplatformpb.ModelGardenServiceClient + // LROClient is used internally to handle long-running operations. + // It is exposed so that its CallOptions can be modified if required. + // Users should not Close this client. + LROClient **lroauto.OperationsClient + operationsClient longrunningpb.OperationsClient iamPolicyClient iampb.IAMPolicyClient @@ -290,6 +318,17 @@ func NewModelGardenClient(ctx context.Context, opts ...option.ClientOption) (*Mo client.internalClient = c + client.LROClient, err = lroauto.NewOperationsClient(ctx, gtransport.WithConnPool(connPool)) + if err != nil { + // This error "should not happen", since we are just reusing old connection pool + // and never actually need to dial. + // If this does happen, we could leak connp. However, we cannot close conn: + // If the user invoked the constructor with option.WithGRPCConn, + // we would close a connection that's still in use. + // TODO: investigate error conditions. + return nil, err + } + c.LROClient = &client.LROClient return &client, nil } @@ -326,6 +365,11 @@ type modelGardenRESTClient struct { // The http client. httpClient *http.Client + // LROClient is used internally to handle long-running operations. + // It is exposed so that its CallOptions can be modified if required. + // Users should not Close this client. + LROClient **lroauto.OperationsClient + // The x-goog-* headers to be sent with each request. xGoogHeaders []string @@ -354,6 +398,16 @@ func NewModelGardenRESTClient(ctx context.Context, opts ...option.ClientOption) } c.setGoogleClientInfo() + lroOpts := []option.ClientOption{ + option.WithHTTPClient(httpClient), + option.WithEndpoint(endpoint), + } + opClient, err := lroauto.NewOperationsRESTClient(ctx, lroOpts...) + if err != nil { + return nil, err + } + c.LROClient = &opClient + return &ModelGardenClient{internalClient: c, CallOptions: callOpts}, nil } @@ -458,6 +512,26 @@ func (c *modelGardenGRPCClient) ListPublisherModels(ctx context.Context, req *ai return it } +func (c *modelGardenGRPCClient) DeployPublisherModel(ctx context.Context, req *aiplatformpb.DeployPublisherModelRequest, opts ...gax.CallOption) (*DeployPublisherModelOperation, error) { + hds := []string{"x-goog-request-params", fmt.Sprintf("%s=%v", "destination", url.QueryEscape(req.GetDestination()))} + + hds = append(c.xGoogHeaders, hds...) + ctx = gax.InsertMetadataIntoOutgoingContext(ctx, hds...) + opts = append((*c.CallOptions).DeployPublisherModel[0:len((*c.CallOptions).DeployPublisherModel):len((*c.CallOptions).DeployPublisherModel)], opts...) + var resp *longrunningpb.Operation + err := gax.Invoke(ctx, func(ctx context.Context, settings gax.CallSettings) error { + var err error + resp, err = executeRPC(ctx, c.modelGardenClient.DeployPublisherModel, req, settings.GRPC, c.logger, "DeployPublisherModel") + return err + }, opts...) + if err != nil { + return nil, err + } + return &DeployPublisherModelOperation{ + lro: longrunning.InternalNewOperation(*c.LROClient, resp), + }, nil +} + func (c *modelGardenGRPCClient) GetLocation(ctx context.Context, req *locationpb.GetLocationRequest, opts ...gax.CallOption) (*locationpb.Location, error) { hds := []string{"x-goog-request-params", fmt.Sprintf("%s=%v", "name", url.QueryEscape(req.GetName()))} @@ -841,6 +915,65 @@ func (c *modelGardenRESTClient) ListPublisherModels(ctx context.Context, req *ai return it } +// DeployPublisherModel deploys publisher models. +func (c *modelGardenRESTClient) DeployPublisherModel(ctx context.Context, req *aiplatformpb.DeployPublisherModelRequest, opts ...gax.CallOption) (*DeployPublisherModelOperation, error) { + m := protojson.MarshalOptions{AllowPartial: true, UseEnumNumbers: true} + jsonReq, err := m.Marshal(req) + if err != nil { + return nil, err + } + + baseUrl, err := url.Parse(c.endpoint) + if err != nil { + return nil, err + } + baseUrl.Path += fmt.Sprintf("/v1beta1/%v:deploy", req.GetDestination()) + + params := url.Values{} + params.Add("$alt", "json;enum-encoding=int") + + baseUrl.RawQuery = params.Encode() + + // Build HTTP headers from client and context metadata. + hds := []string{"x-goog-request-params", fmt.Sprintf("%s=%v", "destination", url.QueryEscape(req.GetDestination()))} + + hds = append(c.xGoogHeaders, hds...) + hds = append(hds, "Content-Type", "application/json") + headers := gax.BuildHeaders(ctx, hds...) + unm := protojson.UnmarshalOptions{AllowPartial: true, DiscardUnknown: true} + resp := &longrunningpb.Operation{} + e := gax.Invoke(ctx, func(ctx context.Context, settings gax.CallSettings) error { + if settings.Path != "" { + baseUrl.Path = settings.Path + } + httpReq, err := http.NewRequest("POST", baseUrl.String(), bytes.NewReader(jsonReq)) + if err != nil { + return err + } + httpReq = httpReq.WithContext(ctx) + httpReq.Header = headers + + buf, err := executeHTTPRequest(ctx, c.httpClient, httpReq, c.logger, jsonReq, "DeployPublisherModel") + if err != nil { + return err + } + if err := unm.Unmarshal(buf, resp); err != nil { + return err + } + + return nil + }, opts...) + if e != nil { + return nil, e + } + + override := fmt.Sprintf("/ui/%s", resp.GetName()) + return &DeployPublisherModelOperation{ + lro: longrunning.InternalNewOperation(*c.LROClient, resp), + pollPath: override, + }, nil +} + // GetLocation gets information about a location. func (c *modelGardenRESTClient) GetLocation(ctx context.Context, req *locationpb.GetLocationRequest, opts ...gax.CallOption) (*locationpb.Location, error) { baseUrl, err := url.Parse(c.endpoint) @@ -1408,3 +1541,21 @@ func (c *modelGardenRESTClient) WaitOperation(ctx context.Context, req *longrunn } return resp, nil } + +// DeployPublisherModelOperation returns a new DeployPublisherModelOperation from a given name. +// The name must be that of a previously created DeployPublisherModelOperation, possibly from a different process. +func (c *modelGardenGRPCClient) DeployPublisherModelOperation(name string) *DeployPublisherModelOperation { + return &DeployPublisherModelOperation{ + lro: longrunning.InternalNewOperation(*c.LROClient, &longrunningpb.Operation{Name: name}), + } +} + +// DeployPublisherModelOperation returns a new DeployPublisherModelOperation from a given name. +// The name must be that of a previously created DeployPublisherModelOperation, possibly from a different process. +func (c *modelGardenRESTClient) DeployPublisherModelOperation(name string) *DeployPublisherModelOperation { + override := fmt.Sprintf("/ui/%s", name) + return &DeployPublisherModelOperation{ + lro: longrunning.InternalNewOperation(*c.LROClient, &longrunningpb.Operation{Name: name}), + pollPath: override, + } +} diff --git a/aiplatform/apiv1beta1/model_garden_client_example_test.go b/aiplatform/apiv1beta1/model_garden_client_example_test.go index 1794d2d47972..5b11e67f5a8d 100644 --- a/aiplatform/apiv1beta1/model_garden_client_example_test.go +++ b/aiplatform/apiv1beta1/model_garden_client_example_test.go @@ -61,6 +61,36 @@ func ExampleNewModelGardenRESTClient() { _ = c } +func ExampleModelGardenClient_DeployPublisherModel() { + ctx := context.Background() + // This snippet has been automatically generated and should be regarded as a code template only. + // It will require modifications to work: + // - It may require correct/in-range values for request initialization. + // - It may require specifying regional endpoints when creating the service client as shown in: + // https://pkg.go.dev/cloud.google.com/go#hdr-Client_Options + c, err := aiplatform.NewModelGardenClient(ctx) + if err != nil { + // TODO: Handle error. + } + defer c.Close() + + req := &aiplatformpb.DeployPublisherModelRequest{ + // TODO: Fill request struct fields. + // See https://pkg.go.dev/cloud.google.com/go/aiplatform/apiv1beta1/aiplatformpb#DeployPublisherModelRequest. + } + op, err := c.DeployPublisherModel(ctx, req) + if err != nil { + // TODO: Handle error. + } + + resp, err := op.Wait(ctx) + if err != nil { + // TODO: Handle error. + } + // TODO: Use resp. + _ = resp +} + func ExampleModelGardenClient_GetPublisherModel() { ctx := context.Background() // This snippet has been automatically generated and should be regarded as a code template only. diff --git a/batch/apiv1/batchpb/batch.pb.go b/batch/apiv1/batchpb/batch.pb.go index 20206a1af555..d9947c43c8bc 100755 --- a/batch/apiv1/batchpb/batch.pb.go +++ b/batch/apiv1/batchpb/batch.pb.go @@ -619,9 +619,10 @@ type OperationMetadata struct { StatusMessage string `protobuf:"bytes,5,opt,name=status_message,json=statusMessage,proto3" json:"status_message,omitempty"` // Output only. Identifies whether the user has requested cancellation // of the operation. Operations that have successfully been cancelled - // have [Operation.error][] value with a - // [google.rpc.Status.code][google.rpc.Status.code] of 1, corresponding to - // `Code.CANCELLED`. + // have + // [google.longrunning.Operation.error][google.longrunning.Operation.error] + // value with a [google.rpc.Status.code][google.rpc.Status.code] of 1, + // corresponding to `Code.CANCELLED`. RequestedCancellation bool `protobuf:"varint,6,opt,name=requested_cancellation,json=requestedCancellation,proto3" json:"requested_cancellation,omitempty"` // Output only. API version used to start the operation. ApiVersion string `protobuf:"bytes,7,opt,name=api_version,json=apiVersion,proto3" json:"api_version,omitempty"` diff --git a/dataplex/apiv1/dataplexpb/catalog.pb.go b/dataplex/apiv1/dataplexpb/catalog.pb.go index 415135fc3543..f59857af3415 100755 --- a/dataplex/apiv1/dataplexpb/catalog.pb.go +++ b/dataplex/apiv1/dataplexpb/catalog.pb.go @@ -2619,7 +2619,7 @@ type UpdateEntryRequest struct { // specified path. For example, to attach an aspect to a field that is // specified by the `schema` aspect, the path should have the format // `Schema.`. - // * `*` - matches aspects of the given type for all + // * `@*` - matches aspects of the given type for all // paths. // * `*@path` - matches aspects of all types on the given path. // @@ -3075,6 +3075,8 @@ type SearchEntriesRequest struct { // following form: `projects/{project}/locations/{location}`. Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"` // Required. The query against which entries in scope should be matched. + // The query syntax is defined in [Search syntax for Dataplex + // Catalog](https://cloud.google.com/dataplex/docs/search-syntax). Query string `protobuf:"bytes,2,opt,name=query,proto3" json:"query,omitempty"` // Optional. Number of results in the search page. If <=0, then defaults // to 10. Max limit for page_size is 1000. Throws an invalid argument for @@ -3084,6 +3086,10 @@ type SearchEntriesRequest struct { // this to retrieve the subsequent page. PageToken string `protobuf:"bytes,4,opt,name=page_token,json=pageToken,proto3" json:"page_token,omitempty"` // Optional. Specifies the ordering of results. + // Supported values are: + // * `relevance` (default) + // * `last_modified_timestamp` + // * `last_modified_timestamp asc` OrderBy string `protobuf:"bytes,5,opt,name=order_by,json=orderBy,proto3" json:"order_by,omitempty"` // Optional. The scope under which the search should be operating. It must // either be `organizations/` or `projects/`. If it is @@ -3349,9 +3355,9 @@ type ImportItem struct { // aspect type and are attached directly to the entry. // * `{aspect_type_reference}@{path}`: matches aspects that belong to the // specified aspect type and path. - // * `{aspect_type_reference}@*`: matches aspects that belong to the specified - // aspect type for all paths. - // + // * `@*` : matches aspects of the given type for all + // paths. + // * `*@path` : matches aspects of all types on the given path. // Replace `{aspect_type_reference}` with a reference to the aspect type, in // the format // `{project_id_or_number}.{location_id}.{aspect_type_id}`. diff --git a/dataplex/apiv1/dataplexpb/datascans.pb.go b/dataplex/apiv1/dataplexpb/datascans.pb.go index 64c74d15b7af..f4cc638d12c8 100755 --- a/dataplex/apiv1/dataplexpb/datascans.pb.go +++ b/dataplex/apiv1/dataplexpb/datascans.pb.go @@ -370,7 +370,7 @@ type UpdateDataScanRequest struct { // // Only fields specified in `update_mask` are updated. DataScan *DataScan `protobuf:"bytes,1,opt,name=data_scan,json=dataScan,proto3" json:"data_scan,omitempty"` - // Required. Mask of fields to update. + // Optional. Mask of fields to update. UpdateMask *fieldmaskpb.FieldMask `protobuf:"bytes,2,opt,name=update_mask,json=updateMask,proto3" json:"update_mask,omitempty"` // Optional. Only validate the request, but do not perform mutations. // The default is `false`. @@ -439,6 +439,10 @@ type DeleteDataScanRequest struct { // where `project` refers to a *project_id* or *project_number* and // `location_id` refers to a GCP region. Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"` + // Optional. If set to true, any child resources of this data scan will also + // be deleted. (Otherwise, the request will only work if the data scan has no + // child resources.) + Force bool `protobuf:"varint,2,opt,name=force,proto3" json:"force,omitempty"` } func (x *DeleteDataScanRequest) Reset() { @@ -478,6 +482,13 @@ func (x *DeleteDataScanRequest) GetName() string { return "" } +func (x *DeleteDataScanRequest) GetForce() bool { + if x != nil { + return x.Force + } + return false +} + // Get dataScan request. type GetDataScanRequest struct { state protoimpl.MessageState @@ -1124,8 +1135,8 @@ type DataScan struct { sizeCache protoimpl.SizeCache unknownFields protoimpl.UnknownFields - // Output only. The relative resource name of the scan, of the form: - // `projects/{project}/locations/{location_id}/dataScans/{datascan_id}`, + // Output only. Identifier. The relative resource name of the scan, of the + // form: `projects/{project}/locations/{location_id}/dataScans/{datascan_id}`, // where `project` refers to a *project_id* or *project_number* and // `location_id` refers to a GCP region. Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"` @@ -1405,7 +1416,8 @@ type DataScanJob struct { sizeCache protoimpl.SizeCache unknownFields protoimpl.UnknownFields - // Output only. The relative resource name of the DataScanJob, of the form: + // Output only. Identifier. The relative resource name of the DataScanJob, of + // the form: // `projects/{project}/locations/{location_id}/dataScans/{datascan_id}/jobs/{job_id}`, // where `project` refers to a *project_id* or *project_number* and // `location_id` refers to a GCP region. @@ -1728,9 +1740,9 @@ type DataScan_ExecutionStatus struct { sizeCache protoimpl.SizeCache unknownFields protoimpl.UnknownFields - // The time when the latest DataScanJob started. + // Optional. The time when the latest DataScanJob started. LatestJobStartTime *timestamppb.Timestamp `protobuf:"bytes,4,opt,name=latest_job_start_time,json=latestJobStartTime,proto3" json:"latest_job_start_time,omitempty"` - // The time when the latest DataScanJob ended. + // Optional. The time when the latest DataScanJob ended. LatestJobEndTime *timestamppb.Timestamp `protobuf:"bytes,5,opt,name=latest_job_end_time,json=latestJobEndTime,proto3" json:"latest_job_end_time,omitempty"` // Optional. The time when the DataScanJob execution was created. LatestJobCreateTime *timestamppb.Timestamp `protobuf:"bytes,6,opt,name=latest_job_create_time,json=latestJobCreateTime,proto3" json:"latest_job_create_time,omitempty"` @@ -1799,498 +1811,503 @@ var file_google_cloud_dataplex_v1_datascans_proto_rawDesc = []byte{ 0x74, 0x6f, 0x1a, 0x17, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x61, 0x70, 0x69, 0x2f, 0x63, 0x6c, 0x69, 0x65, 0x6e, 0x74, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x1f, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x61, 0x70, 0x69, 0x2f, 0x66, 0x69, 0x65, 0x6c, 0x64, 0x5f, 0x62, 0x65, - 0x68, 0x61, 0x76, 0x69, 0x6f, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x19, 0x67, 0x6f, - 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x61, 0x70, 0x69, 0x2f, 0x72, 0x65, 0x73, 0x6f, 0x75, 0x72, 0x63, - 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x2d, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, - 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2f, 0x76, - 0x31, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x64, 0x69, 0x73, 0x63, 0x6f, 0x76, 0x65, 0x72, 0x79, - 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x2b, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x63, - 0x6c, 0x6f, 0x75, 0x64, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2f, 0x76, 0x31, - 0x2f, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x70, 0x72, 0x6f, 0x66, 0x69, 0x6c, 0x65, 0x2e, 0x70, 0x72, + 0x68, 0x61, 0x76, 0x69, 0x6f, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x1b, 0x67, 0x6f, + 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x61, 0x70, 0x69, 0x2f, 0x66, 0x69, 0x65, 0x6c, 0x64, 0x5f, 0x69, + 0x6e, 0x66, 0x6f, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x19, 0x67, 0x6f, 0x6f, 0x67, 0x6c, + 0x65, 0x2f, 0x61, 0x70, 0x69, 0x2f, 0x72, 0x65, 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, 0x2e, 0x70, + 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x2d, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x63, 0x6c, 0x6f, + 0x75, 0x64, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2f, 0x76, 0x31, 0x2f, 0x64, + 0x61, 0x74, 0x61, 0x5f, 0x64, 0x69, 0x73, 0x63, 0x6f, 0x76, 0x65, 0x72, 0x79, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x2b, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2f, 0x76, 0x31, 0x2f, 0x64, 0x61, - 0x74, 0x61, 0x5f, 0x71, 0x75, 0x61, 0x6c, 0x69, 0x74, 0x79, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, - 0x1a, 0x29, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2f, 0x64, - 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2f, 0x76, 0x31, 0x2f, 0x70, 0x72, 0x6f, 0x63, 0x65, - 0x73, 0x73, 0x69, 0x6e, 0x67, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x28, 0x67, 0x6f, 0x6f, - 0x67, 0x6c, 0x65, 0x2f, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, - 0x65, 0x78, 0x2f, 0x76, 0x31, 0x2f, 0x72, 0x65, 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, 0x73, 0x2e, - 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x26, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x63, 0x6c, - 0x6f, 0x75, 0x64, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2f, 0x76, 0x31, 0x2f, - 0x73, 0x65, 0x72, 0x76, 0x69, 0x63, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x23, 0x67, - 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x6c, 0x6f, 0x6e, 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, - 0x67, 0x2f, 0x6f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2e, 0x70, 0x72, 0x6f, - 0x74, 0x6f, 0x1a, 0x1b, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x70, 0x72, 0x6f, 0x74, 0x6f, - 0x62, 0x75, 0x66, 0x2f, 0x65, 0x6d, 0x70, 0x74, 0x79, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, - 0x20, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, - 0x2f, 0x66, 0x69, 0x65, 0x6c, 0x64, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x2e, 0x70, 0x72, 0x6f, 0x74, - 0x6f, 0x1a, 0x1f, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, - 0x75, 0x66, 0x2f, 0x74, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x2e, 0x70, 0x72, 0x6f, - 0x74, 0x6f, 0x22, 0xf1, 0x01, 0x0a, 0x15, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x44, 0x61, 0x74, - 0x61, 0x53, 0x63, 0x61, 0x6e, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x41, 0x0a, 0x06, - 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x29, 0xe0, 0x41, - 0x02, 0xfa, 0x41, 0x23, 0x0a, 0x21, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2e, - 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x4c, - 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x12, - 0x44, 0x0a, 0x09, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x73, 0x63, 0x61, 0x6e, 0x18, 0x02, 0x20, 0x01, - 0x28, 0x0b, 0x32, 0x22, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, - 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, - 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x08, 0x64, 0x61, 0x74, - 0x61, 0x53, 0x63, 0x61, 0x6e, 0x12, 0x25, 0x0a, 0x0c, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x73, 0x63, - 0x61, 0x6e, 0x5f, 0x69, 0x64, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x02, - 0x52, 0x0a, 0x64, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x49, 0x64, 0x12, 0x28, 0x0a, 0x0d, - 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, 0x65, 0x5f, 0x6f, 0x6e, 0x6c, 0x79, 0x18, 0x04, 0x20, - 0x01, 0x28, 0x08, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0c, 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, - 0x74, 0x65, 0x4f, 0x6e, 0x6c, 0x79, 0x22, 0xc9, 0x01, 0x0a, 0x15, 0x55, 0x70, 0x64, 0x61, 0x74, - 0x65, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, - 0x12, 0x44, 0x0a, 0x09, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x73, 0x63, 0x61, 0x6e, 0x18, 0x01, 0x20, - 0x01, 0x28, 0x0b, 0x32, 0x22, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, - 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, - 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x08, 0x64, 0x61, - 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x12, 0x40, 0x0a, 0x0b, 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, - 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, - 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x46, 0x69, - 0x65, 0x6c, 0x64, 0x4d, 0x61, 0x73, 0x6b, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x0a, 0x75, 0x70, - 0x64, 0x61, 0x74, 0x65, 0x4d, 0x61, 0x73, 0x6b, 0x12, 0x28, 0x0a, 0x0d, 0x76, 0x61, 0x6c, 0x69, - 0x64, 0x61, 0x74, 0x65, 0x5f, 0x6f, 0x6e, 0x6c, 0x79, 0x18, 0x03, 0x20, 0x01, 0x28, 0x08, 0x42, - 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0c, 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, 0x65, 0x4f, 0x6e, - 0x6c, 0x79, 0x22, 0x55, 0x0a, 0x15, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x44, 0x61, 0x74, 0x61, + 0x74, 0x61, 0x5f, 0x70, 0x72, 0x6f, 0x66, 0x69, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, + 0x1a, 0x2b, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2f, 0x64, + 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2f, 0x76, 0x31, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x5f, + 0x71, 0x75, 0x61, 0x6c, 0x69, 0x74, 0x79, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x29, 0x67, + 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2f, 0x64, 0x61, 0x74, 0x61, + 0x70, 0x6c, 0x65, 0x78, 0x2f, 0x76, 0x31, 0x2f, 0x70, 0x72, 0x6f, 0x63, 0x65, 0x73, 0x73, 0x69, + 0x6e, 0x67, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x28, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, + 0x2f, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2f, + 0x76, 0x31, 0x2f, 0x72, 0x65, 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, 0x73, 0x2e, 0x70, 0x72, 0x6f, + 0x74, 0x6f, 0x1a, 0x26, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x63, 0x6c, 0x6f, 0x75, 0x64, + 0x2f, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2f, 0x76, 0x31, 0x2f, 0x73, 0x65, 0x72, + 0x76, 0x69, 0x63, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x23, 0x67, 0x6f, 0x6f, 0x67, + 0x6c, 0x65, 0x2f, 0x6c, 0x6f, 0x6e, 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, 0x67, 0x2f, 0x6f, + 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, + 0x1b, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, + 0x2f, 0x65, 0x6d, 0x70, 0x74, 0x79, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x20, 0x67, 0x6f, + 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2f, 0x66, 0x69, + 0x65, 0x6c, 0x64, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x1f, + 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2f, + 0x74, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x22, + 0xf1, 0x01, 0x0a, 0x15, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, + 0x61, 0x6e, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x41, 0x0a, 0x06, 0x70, 0x61, 0x72, + 0x65, 0x6e, 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x29, 0xe0, 0x41, 0x02, 0xfa, 0x41, + 0x23, 0x0a, 0x21, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2e, 0x67, 0x6f, 0x6f, + 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x4c, 0x6f, 0x63, 0x61, + 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x12, 0x44, 0x0a, 0x09, + 0x64, 0x61, 0x74, 0x61, 0x5f, 0x73, 0x63, 0x61, 0x6e, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, + 0x22, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, + 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x53, + 0x63, 0x61, 0x6e, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x08, 0x64, 0x61, 0x74, 0x61, 0x53, 0x63, + 0x61, 0x6e, 0x12, 0x25, 0x0a, 0x0c, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x73, 0x63, 0x61, 0x6e, 0x5f, + 0x69, 0x64, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x0a, 0x64, + 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x49, 0x64, 0x12, 0x28, 0x0a, 0x0d, 0x76, 0x61, 0x6c, + 0x69, 0x64, 0x61, 0x74, 0x65, 0x5f, 0x6f, 0x6e, 0x6c, 0x79, 0x18, 0x04, 0x20, 0x01, 0x28, 0x08, + 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0c, 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, 0x65, 0x4f, + 0x6e, 0x6c, 0x79, 0x22, 0xc9, 0x01, 0x0a, 0x15, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x44, 0x61, + 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x44, 0x0a, + 0x09, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x73, 0x63, 0x61, 0x6e, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, + 0x32, 0x22, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, + 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, + 0x53, 0x63, 0x61, 0x6e, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x08, 0x64, 0x61, 0x74, 0x61, 0x53, + 0x63, 0x61, 0x6e, 0x12, 0x40, 0x0a, 0x0b, 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, 0x5f, 0x6d, 0x61, + 0x73, 0x6b, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, + 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x46, 0x69, 0x65, 0x6c, 0x64, + 0x4d, 0x61, 0x73, 0x6b, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0a, 0x75, 0x70, 0x64, 0x61, 0x74, + 0x65, 0x4d, 0x61, 0x73, 0x6b, 0x12, 0x28, 0x0a, 0x0d, 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, + 0x65, 0x5f, 0x6f, 0x6e, 0x6c, 0x79, 0x18, 0x03, 0x20, 0x01, 0x28, 0x08, 0x42, 0x03, 0xe0, 0x41, + 0x01, 0x52, 0x0c, 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, 0x65, 0x4f, 0x6e, 0x6c, 0x79, 0x22, + 0x70, 0x0a, 0x15, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, + 0x6e, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x3c, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, + 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x28, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x22, 0x0a, 0x20, + 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, + 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, + 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x19, 0x0a, 0x05, 0x66, 0x6f, 0x72, 0x63, 0x65, 0x18, + 0x02, 0x20, 0x01, 0x28, 0x08, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x05, 0x66, 0x6f, 0x72, 0x63, + 0x65, 0x22, 0xeb, 0x01, 0x0a, 0x12, 0x47, 0x65, 0x74, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, + 0x6e, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x3c, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, + 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x28, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x22, 0x0a, 0x20, + 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, + 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, + 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x52, 0x0a, 0x04, 0x76, 0x69, 0x65, 0x77, 0x18, 0x02, + 0x20, 0x01, 0x28, 0x0e, 0x32, 0x39, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, + 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, + 0x47, 0x65, 0x74, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x52, 0x65, 0x71, 0x75, 0x65, + 0x73, 0x74, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x56, 0x69, 0x65, 0x77, 0x42, + 0x03, 0xe0, 0x41, 0x01, 0x52, 0x04, 0x76, 0x69, 0x65, 0x77, 0x22, 0x43, 0x0a, 0x0c, 0x44, 0x61, + 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x56, 0x69, 0x65, 0x77, 0x12, 0x1e, 0x0a, 0x1a, 0x44, 0x41, + 0x54, 0x41, 0x5f, 0x53, 0x43, 0x41, 0x4e, 0x5f, 0x56, 0x49, 0x45, 0x57, 0x5f, 0x55, 0x4e, 0x53, + 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x09, 0x0a, 0x05, 0x42, 0x41, + 0x53, 0x49, 0x43, 0x10, 0x01, 0x12, 0x08, 0x0a, 0x04, 0x46, 0x55, 0x4c, 0x4c, 0x10, 0x0a, 0x22, + 0xdc, 0x01, 0x0a, 0x14, 0x4c, 0x69, 0x73, 0x74, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, + 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x41, 0x0a, 0x06, 0x70, 0x61, 0x72, 0x65, + 0x6e, 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x29, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x23, + 0x0a, 0x21, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2e, 0x67, 0x6f, 0x6f, 0x67, + 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x4c, 0x6f, 0x63, 0x61, 0x74, + 0x69, 0x6f, 0x6e, 0x52, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x12, 0x20, 0x0a, 0x09, 0x70, + 0x61, 0x67, 0x65, 0x5f, 0x73, 0x69, 0x7a, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x05, 0x42, 0x03, + 0xe0, 0x41, 0x01, 0x52, 0x08, 0x70, 0x61, 0x67, 0x65, 0x53, 0x69, 0x7a, 0x65, 0x12, 0x22, 0x0a, + 0x0a, 0x70, 0x61, 0x67, 0x65, 0x5f, 0x74, 0x6f, 0x6b, 0x65, 0x6e, 0x18, 0x03, 0x20, 0x01, 0x28, + 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x09, 0x70, 0x61, 0x67, 0x65, 0x54, 0x6f, 0x6b, 0x65, + 0x6e, 0x12, 0x1b, 0x0a, 0x06, 0x66, 0x69, 0x6c, 0x74, 0x65, 0x72, 0x18, 0x04, 0x20, 0x01, 0x28, + 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x06, 0x66, 0x69, 0x6c, 0x74, 0x65, 0x72, 0x12, 0x1e, + 0x0a, 0x08, 0x6f, 0x72, 0x64, 0x65, 0x72, 0x5f, 0x62, 0x79, 0x18, 0x05, 0x20, 0x01, 0x28, 0x09, + 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x07, 0x6f, 0x72, 0x64, 0x65, 0x72, 0x42, 0x79, 0x22, 0xa4, + 0x01, 0x0a, 0x15, 0x4c, 0x69, 0x73, 0x74, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x73, + 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x41, 0x0a, 0x0a, 0x64, 0x61, 0x74, 0x61, + 0x5f, 0x73, 0x63, 0x61, 0x6e, 0x73, 0x18, 0x01, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x22, 0x2e, 0x67, + 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, + 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, + 0x52, 0x09, 0x64, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x73, 0x12, 0x26, 0x0a, 0x0f, 0x6e, + 0x65, 0x78, 0x74, 0x5f, 0x70, 0x61, 0x67, 0x65, 0x5f, 0x74, 0x6f, 0x6b, 0x65, 0x6e, 0x18, 0x02, + 0x20, 0x01, 0x28, 0x09, 0x52, 0x0d, 0x6e, 0x65, 0x78, 0x74, 0x50, 0x61, 0x67, 0x65, 0x54, 0x6f, + 0x6b, 0x65, 0x6e, 0x12, 0x20, 0x0a, 0x0b, 0x75, 0x6e, 0x72, 0x65, 0x61, 0x63, 0x68, 0x61, 0x62, + 0x6c, 0x65, 0x18, 0x03, 0x20, 0x03, 0x28, 0x09, 0x52, 0x0b, 0x75, 0x6e, 0x72, 0x65, 0x61, 0x63, + 0x68, 0x61, 0x62, 0x6c, 0x65, 0x22, 0x52, 0x0a, 0x12, 0x52, 0x75, 0x6e, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x3c, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x28, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x22, 0x0a, 0x20, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x44, 0x61, 0x74, 0x61, 0x53, - 0x63, 0x61, 0x6e, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x22, 0xeb, 0x01, 0x0a, 0x12, 0x47, 0x65, - 0x74, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, - 0x12, 0x3c, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x28, - 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x22, 0x0a, 0x20, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, - 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, - 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x52, - 0x0a, 0x04, 0x76, 0x69, 0x65, 0x77, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0e, 0x32, 0x39, 0x2e, 0x67, - 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, - 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x47, 0x65, 0x74, 0x44, 0x61, 0x74, 0x61, 0x53, - 0x63, 0x61, 0x6e, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x53, - 0x63, 0x61, 0x6e, 0x56, 0x69, 0x65, 0x77, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x04, 0x76, 0x69, - 0x65, 0x77, 0x22, 0x43, 0x0a, 0x0c, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x56, 0x69, - 0x65, 0x77, 0x12, 0x1e, 0x0a, 0x1a, 0x44, 0x41, 0x54, 0x41, 0x5f, 0x53, 0x43, 0x41, 0x4e, 0x5f, - 0x56, 0x49, 0x45, 0x57, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, - 0x10, 0x00, 0x12, 0x09, 0x0a, 0x05, 0x42, 0x41, 0x53, 0x49, 0x43, 0x10, 0x01, 0x12, 0x08, 0x0a, - 0x04, 0x46, 0x55, 0x4c, 0x4c, 0x10, 0x0a, 0x22, 0xdc, 0x01, 0x0a, 0x14, 0x4c, 0x69, 0x73, 0x74, - 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, - 0x12, 0x41, 0x0a, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, - 0x42, 0x29, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x23, 0x0a, 0x21, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, - 0x6f, 0x6e, 0x73, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, - 0x6f, 0x6d, 0x2f, 0x4c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x06, 0x70, 0x61, 0x72, - 0x65, 0x6e, 0x74, 0x12, 0x20, 0x0a, 0x09, 0x70, 0x61, 0x67, 0x65, 0x5f, 0x73, 0x69, 0x7a, 0x65, - 0x18, 0x02, 0x20, 0x01, 0x28, 0x05, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x08, 0x70, 0x61, 0x67, - 0x65, 0x53, 0x69, 0x7a, 0x65, 0x12, 0x22, 0x0a, 0x0a, 0x70, 0x61, 0x67, 0x65, 0x5f, 0x74, 0x6f, - 0x6b, 0x65, 0x6e, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x09, - 0x70, 0x61, 0x67, 0x65, 0x54, 0x6f, 0x6b, 0x65, 0x6e, 0x12, 0x1b, 0x0a, 0x06, 0x66, 0x69, 0x6c, - 0x74, 0x65, 0x72, 0x18, 0x04, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x06, - 0x66, 0x69, 0x6c, 0x74, 0x65, 0x72, 0x12, 0x1e, 0x0a, 0x08, 0x6f, 0x72, 0x64, 0x65, 0x72, 0x5f, - 0x62, 0x79, 0x18, 0x05, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x07, 0x6f, - 0x72, 0x64, 0x65, 0x72, 0x42, 0x79, 0x22, 0xa4, 0x01, 0x0a, 0x15, 0x4c, 0x69, 0x73, 0x74, 0x44, - 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x73, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, - 0x12, 0x41, 0x0a, 0x0a, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x73, 0x63, 0x61, 0x6e, 0x73, 0x18, 0x01, - 0x20, 0x03, 0x28, 0x0b, 0x32, 0x22, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, - 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, - 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x52, 0x09, 0x64, 0x61, 0x74, 0x61, 0x53, 0x63, - 0x61, 0x6e, 0x73, 0x12, 0x26, 0x0a, 0x0f, 0x6e, 0x65, 0x78, 0x74, 0x5f, 0x70, 0x61, 0x67, 0x65, - 0x5f, 0x74, 0x6f, 0x6b, 0x65, 0x6e, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0d, 0x6e, 0x65, - 0x78, 0x74, 0x50, 0x61, 0x67, 0x65, 0x54, 0x6f, 0x6b, 0x65, 0x6e, 0x12, 0x20, 0x0a, 0x0b, 0x75, - 0x6e, 0x72, 0x65, 0x61, 0x63, 0x68, 0x61, 0x62, 0x6c, 0x65, 0x18, 0x03, 0x20, 0x03, 0x28, 0x09, - 0x52, 0x0b, 0x75, 0x6e, 0x72, 0x65, 0x61, 0x63, 0x68, 0x61, 0x62, 0x6c, 0x65, 0x22, 0x52, 0x0a, - 0x12, 0x52, 0x75, 0x6e, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x52, 0x65, 0x71, 0x75, - 0x65, 0x73, 0x74, 0x12, 0x3c, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, - 0x09, 0x42, 0x28, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x22, 0x0a, 0x20, 0x64, 0x61, 0x74, 0x61, 0x70, + 0x63, 0x61, 0x6e, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x22, 0x4e, 0x0a, 0x13, 0x52, 0x75, 0x6e, + 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, + 0x12, 0x37, 0x0a, 0x03, 0x6a, 0x6f, 0x62, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x25, 0x2e, + 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, + 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, + 0x6e, 0x4a, 0x6f, 0x62, 0x52, 0x03, 0x6a, 0x6f, 0x62, 0x22, 0xfe, 0x01, 0x0a, 0x15, 0x47, 0x65, + 0x74, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x52, 0x65, 0x71, 0x75, + 0x65, 0x73, 0x74, 0x12, 0x3f, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, + 0x09, 0x42, 0x2b, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x25, 0x0a, 0x23, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, - 0x6f, 0x6d, 0x2f, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x52, 0x04, 0x6e, 0x61, 0x6d, - 0x65, 0x22, 0x4e, 0x0a, 0x13, 0x52, 0x75, 0x6e, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, - 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x37, 0x0a, 0x03, 0x6a, 0x6f, 0x62, 0x18, - 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x25, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, - 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, - 0x2e, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x52, 0x03, 0x6a, 0x6f, - 0x62, 0x22, 0xfe, 0x01, 0x0a, 0x15, 0x47, 0x65, 0x74, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, - 0x6e, 0x4a, 0x6f, 0x62, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x3f, 0x0a, 0x04, 0x6e, - 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x2b, 0xe0, 0x41, 0x02, 0xfa, 0x41, - 0x25, 0x0a, 0x23, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x67, 0x6f, 0x6f, 0x67, - 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x44, 0x61, 0x74, 0x61, 0x53, - 0x63, 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x58, 0x0a, 0x04, - 0x76, 0x69, 0x65, 0x77, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0e, 0x32, 0x3f, 0x2e, 0x67, 0x6f, 0x6f, - 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, - 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x47, 0x65, 0x74, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, - 0x6e, 0x4a, 0x6f, 0x62, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x2e, 0x44, 0x61, 0x74, 0x61, - 0x53, 0x63, 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x56, 0x69, 0x65, 0x77, 0x42, 0x03, 0xe0, 0x41, 0x01, - 0x52, 0x04, 0x76, 0x69, 0x65, 0x77, 0x22, 0x4a, 0x0a, 0x0f, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, - 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x56, 0x69, 0x65, 0x77, 0x12, 0x22, 0x0a, 0x1e, 0x44, 0x41, 0x54, - 0x41, 0x5f, 0x53, 0x43, 0x41, 0x4e, 0x5f, 0x4a, 0x4f, 0x42, 0x5f, 0x56, 0x49, 0x45, 0x57, 0x5f, - 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x09, 0x0a, - 0x05, 0x42, 0x41, 0x53, 0x49, 0x43, 0x10, 0x01, 0x12, 0x08, 0x0a, 0x04, 0x46, 0x55, 0x4c, 0x4c, - 0x10, 0x0a, 0x22, 0xbe, 0x01, 0x0a, 0x17, 0x4c, 0x69, 0x73, 0x74, 0x44, 0x61, 0x74, 0x61, 0x53, - 0x63, 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x40, - 0x0a, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x28, - 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x22, 0x0a, 0x20, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, - 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, - 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x52, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, - 0x12, 0x20, 0x0a, 0x09, 0x70, 0x61, 0x67, 0x65, 0x5f, 0x73, 0x69, 0x7a, 0x65, 0x18, 0x02, 0x20, - 0x01, 0x28, 0x05, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x08, 0x70, 0x61, 0x67, 0x65, 0x53, 0x69, - 0x7a, 0x65, 0x12, 0x22, 0x0a, 0x0a, 0x70, 0x61, 0x67, 0x65, 0x5f, 0x74, 0x6f, 0x6b, 0x65, 0x6e, - 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x09, 0x70, 0x61, 0x67, - 0x65, 0x54, 0x6f, 0x6b, 0x65, 0x6e, 0x12, 0x1b, 0x0a, 0x06, 0x66, 0x69, 0x6c, 0x74, 0x65, 0x72, - 0x18, 0x04, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x06, 0x66, 0x69, 0x6c, - 0x74, 0x65, 0x72, 0x22, 0x8f, 0x01, 0x0a, 0x18, 0x4c, 0x69, 0x73, 0x74, 0x44, 0x61, 0x74, 0x61, - 0x53, 0x63, 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, - 0x12, 0x4b, 0x0a, 0x0e, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x73, 0x63, 0x61, 0x6e, 0x5f, 0x6a, 0x6f, - 0x62, 0x73, 0x18, 0x01, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x25, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, - 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, - 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x52, - 0x0c, 0x64, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x73, 0x12, 0x26, 0x0a, - 0x0f, 0x6e, 0x65, 0x78, 0x74, 0x5f, 0x70, 0x61, 0x67, 0x65, 0x5f, 0x74, 0x6f, 0x6b, 0x65, 0x6e, - 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0d, 0x6e, 0x65, 0x78, 0x74, 0x50, 0x61, 0x67, 0x65, - 0x54, 0x6f, 0x6b, 0x65, 0x6e, 0x22, 0x3a, 0x0a, 0x1f, 0x47, 0x65, 0x6e, 0x65, 0x72, 0x61, 0x74, - 0x65, 0x44, 0x61, 0x74, 0x61, 0x51, 0x75, 0x61, 0x6c, 0x69, 0x74, 0x79, 0x52, 0x75, 0x6c, 0x65, - 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x17, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, - 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x04, 0x6e, 0x61, 0x6d, - 0x65, 0x22, 0x61, 0x0a, 0x20, 0x47, 0x65, 0x6e, 0x65, 0x72, 0x61, 0x74, 0x65, 0x44, 0x61, 0x74, - 0x61, 0x51, 0x75, 0x61, 0x6c, 0x69, 0x74, 0x79, 0x52, 0x75, 0x6c, 0x65, 0x73, 0x52, 0x65, 0x73, - 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x3d, 0x0a, 0x04, 0x72, 0x75, 0x6c, 0x65, 0x18, 0x01, 0x20, - 0x03, 0x28, 0x0b, 0x32, 0x29, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, - 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, - 0x61, 0x74, 0x61, 0x51, 0x75, 0x61, 0x6c, 0x69, 0x74, 0x79, 0x52, 0x75, 0x6c, 0x65, 0x52, 0x04, - 0x72, 0x75, 0x6c, 0x65, 0x22, 0xd3, 0x0e, 0x0a, 0x08, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, - 0x6e, 0x12, 0x17, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, - 0x03, 0xe0, 0x41, 0x03, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x15, 0x0a, 0x03, 0x75, 0x69, - 0x64, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x03, 0x75, 0x69, - 0x64, 0x12, 0x25, 0x0a, 0x0b, 0x64, 0x65, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x69, 0x6f, 0x6e, - 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0b, 0x64, 0x65, 0x73, - 0x63, 0x72, 0x69, 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x12, 0x26, 0x0a, 0x0c, 0x64, 0x69, 0x73, 0x70, - 0x6c, 0x61, 0x79, 0x5f, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x04, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, - 0xe0, 0x41, 0x01, 0x52, 0x0b, 0x64, 0x69, 0x73, 0x70, 0x6c, 0x61, 0x79, 0x4e, 0x61, 0x6d, 0x65, - 0x12, 0x4b, 0x0a, 0x06, 0x6c, 0x61, 0x62, 0x65, 0x6c, 0x73, 0x18, 0x05, 0x20, 0x03, 0x28, 0x0b, - 0x32, 0x2e, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, + 0x6f, 0x6d, 0x2f, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x52, 0x04, + 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x58, 0x0a, 0x04, 0x76, 0x69, 0x65, 0x77, 0x18, 0x02, 0x20, 0x01, + 0x28, 0x0e, 0x32, 0x3f, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, + 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x47, 0x65, + 0x74, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x52, 0x65, 0x71, 0x75, + 0x65, 0x73, 0x74, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x56, + 0x69, 0x65, 0x77, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x04, 0x76, 0x69, 0x65, 0x77, 0x22, 0x4a, + 0x0a, 0x0f, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x56, 0x69, 0x65, + 0x77, 0x12, 0x22, 0x0a, 0x1e, 0x44, 0x41, 0x54, 0x41, 0x5f, 0x53, 0x43, 0x41, 0x4e, 0x5f, 0x4a, + 0x4f, 0x42, 0x5f, 0x56, 0x49, 0x45, 0x57, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, + 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x09, 0x0a, 0x05, 0x42, 0x41, 0x53, 0x49, 0x43, 0x10, 0x01, + 0x12, 0x08, 0x0a, 0x04, 0x46, 0x55, 0x4c, 0x4c, 0x10, 0x0a, 0x22, 0xbe, 0x01, 0x0a, 0x17, 0x4c, + 0x69, 0x73, 0x74, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x73, 0x52, + 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x40, 0x0a, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, + 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x28, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x22, 0x0a, 0x20, + 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, + 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, + 0x52, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x12, 0x20, 0x0a, 0x09, 0x70, 0x61, 0x67, 0x65, + 0x5f, 0x73, 0x69, 0x7a, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x05, 0x42, 0x03, 0xe0, 0x41, 0x01, + 0x52, 0x08, 0x70, 0x61, 0x67, 0x65, 0x53, 0x69, 0x7a, 0x65, 0x12, 0x22, 0x0a, 0x0a, 0x70, 0x61, + 0x67, 0x65, 0x5f, 0x74, 0x6f, 0x6b, 0x65, 0x6e, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, + 0xe0, 0x41, 0x01, 0x52, 0x09, 0x70, 0x61, 0x67, 0x65, 0x54, 0x6f, 0x6b, 0x65, 0x6e, 0x12, 0x1b, + 0x0a, 0x06, 0x66, 0x69, 0x6c, 0x74, 0x65, 0x72, 0x18, 0x04, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, + 0xe0, 0x41, 0x01, 0x52, 0x06, 0x66, 0x69, 0x6c, 0x74, 0x65, 0x72, 0x22, 0x8f, 0x01, 0x0a, 0x18, + 0x4c, 0x69, 0x73, 0x74, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x73, + 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x4b, 0x0a, 0x0e, 0x64, 0x61, 0x74, 0x61, + 0x5f, 0x73, 0x63, 0x61, 0x6e, 0x5f, 0x6a, 0x6f, 0x62, 0x73, 0x18, 0x01, 0x20, 0x03, 0x28, 0x0b, + 0x32, 0x25, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, - 0x53, 0x63, 0x61, 0x6e, 0x2e, 0x4c, 0x61, 0x62, 0x65, 0x6c, 0x73, 0x45, 0x6e, 0x74, 0x72, 0x79, - 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x06, 0x6c, 0x61, 0x62, 0x65, 0x6c, 0x73, 0x12, 0x3a, 0x0a, - 0x05, 0x73, 0x74, 0x61, 0x74, 0x65, 0x18, 0x06, 0x20, 0x01, 0x28, 0x0e, 0x32, 0x1f, 0x2e, 0x67, - 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, - 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x53, 0x74, 0x61, 0x74, 0x65, 0x42, 0x03, 0xe0, - 0x41, 0x03, 0x52, 0x05, 0x73, 0x74, 0x61, 0x74, 0x65, 0x12, 0x40, 0x0a, 0x0b, 0x63, 0x72, 0x65, - 0x61, 0x74, 0x65, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x18, 0x07, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, - 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, - 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, - 0x0a, 0x63, 0x72, 0x65, 0x61, 0x74, 0x65, 0x54, 0x69, 0x6d, 0x65, 0x12, 0x40, 0x0a, 0x0b, 0x75, - 0x70, 0x64, 0x61, 0x74, 0x65, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x18, 0x08, 0x20, 0x01, 0x28, 0x0b, - 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, - 0x75, 0x66, 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x42, 0x03, 0xe0, 0x41, - 0x03, 0x52, 0x0a, 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, 0x54, 0x69, 0x6d, 0x65, 0x12, 0x3d, 0x0a, - 0x04, 0x64, 0x61, 0x74, 0x61, 0x18, 0x09, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x24, 0x2e, 0x67, 0x6f, + 0x53, 0x63, 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x52, 0x0c, 0x64, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, + 0x6e, 0x4a, 0x6f, 0x62, 0x73, 0x12, 0x26, 0x0a, 0x0f, 0x6e, 0x65, 0x78, 0x74, 0x5f, 0x70, 0x61, + 0x67, 0x65, 0x5f, 0x74, 0x6f, 0x6b, 0x65, 0x6e, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0d, + 0x6e, 0x65, 0x78, 0x74, 0x50, 0x61, 0x67, 0x65, 0x54, 0x6f, 0x6b, 0x65, 0x6e, 0x22, 0x3a, 0x0a, + 0x1f, 0x47, 0x65, 0x6e, 0x65, 0x72, 0x61, 0x74, 0x65, 0x44, 0x61, 0x74, 0x61, 0x51, 0x75, 0x61, + 0x6c, 0x69, 0x74, 0x79, 0x52, 0x75, 0x6c, 0x65, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, + 0x12, 0x17, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, + 0xe0, 0x41, 0x02, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x22, 0x61, 0x0a, 0x20, 0x47, 0x65, 0x6e, + 0x65, 0x72, 0x61, 0x74, 0x65, 0x44, 0x61, 0x74, 0x61, 0x51, 0x75, 0x61, 0x6c, 0x69, 0x74, 0x79, + 0x52, 0x75, 0x6c, 0x65, 0x73, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x3d, 0x0a, + 0x04, 0x72, 0x75, 0x6c, 0x65, 0x18, 0x01, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x29, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, - 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x53, 0x6f, 0x75, 0x72, 0x63, - 0x65, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x04, 0x64, 0x61, 0x74, 0x61, 0x12, 0x5c, 0x0a, 0x0e, - 0x65, 0x78, 0x65, 0x63, 0x75, 0x74, 0x69, 0x6f, 0x6e, 0x5f, 0x73, 0x70, 0x65, 0x63, 0x18, 0x0a, - 0x20, 0x01, 0x28, 0x0b, 0x32, 0x30, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, - 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, - 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x2e, 0x45, 0x78, 0x65, 0x63, 0x75, 0x74, 0x69, - 0x6f, 0x6e, 0x53, 0x70, 0x65, 0x63, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0d, 0x65, 0x78, 0x65, - 0x63, 0x75, 0x74, 0x69, 0x6f, 0x6e, 0x53, 0x70, 0x65, 0x63, 0x12, 0x62, 0x0a, 0x10, 0x65, 0x78, - 0x65, 0x63, 0x75, 0x74, 0x69, 0x6f, 0x6e, 0x5f, 0x73, 0x74, 0x61, 0x74, 0x75, 0x73, 0x18, 0x0b, - 0x20, 0x01, 0x28, 0x0b, 0x32, 0x32, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, - 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, - 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x2e, 0x45, 0x78, 0x65, 0x63, 0x75, 0x74, 0x69, - 0x6f, 0x6e, 0x53, 0x74, 0x61, 0x74, 0x75, 0x73, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x0f, 0x65, - 0x78, 0x65, 0x63, 0x75, 0x74, 0x69, 0x6f, 0x6e, 0x53, 0x74, 0x61, 0x74, 0x75, 0x73, 0x12, 0x3f, - 0x0a, 0x04, 0x74, 0x79, 0x70, 0x65, 0x18, 0x0c, 0x20, 0x01, 0x28, 0x0e, 0x32, 0x26, 0x2e, 0x67, - 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, - 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, - 0x54, 0x79, 0x70, 0x65, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x04, 0x74, 0x79, 0x70, 0x65, 0x12, - 0x57, 0x0a, 0x11, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x71, 0x75, 0x61, 0x6c, 0x69, 0x74, 0x79, 0x5f, - 0x73, 0x70, 0x65, 0x63, 0x18, 0x64, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x29, 0x2e, 0x67, 0x6f, 0x6f, - 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, - 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x51, 0x75, 0x61, 0x6c, 0x69, 0x74, - 0x79, 0x53, 0x70, 0x65, 0x63, 0x48, 0x00, 0x52, 0x0f, 0x64, 0x61, 0x74, 0x61, 0x51, 0x75, 0x61, - 0x6c, 0x69, 0x74, 0x79, 0x53, 0x70, 0x65, 0x63, 0x12, 0x57, 0x0a, 0x11, 0x64, 0x61, 0x74, 0x61, - 0x5f, 0x70, 0x72, 0x6f, 0x66, 0x69, 0x6c, 0x65, 0x5f, 0x73, 0x70, 0x65, 0x63, 0x18, 0x65, 0x20, - 0x01, 0x28, 0x0b, 0x32, 0x29, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, + 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x51, 0x75, 0x61, 0x6c, 0x69, + 0x74, 0x79, 0x52, 0x75, 0x6c, 0x65, 0x52, 0x04, 0x72, 0x75, 0x6c, 0x65, 0x22, 0xe8, 0x0e, 0x0a, + 0x08, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x12, 0x1a, 0x0a, 0x04, 0x6e, 0x61, 0x6d, + 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x06, 0xe0, 0x41, 0x03, 0xe0, 0x41, 0x08, 0x52, + 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x1d, 0x0a, 0x03, 0x75, 0x69, 0x64, 0x18, 0x02, 0x20, 0x01, + 0x28, 0x09, 0x42, 0x0b, 0xe0, 0x41, 0x03, 0xe2, 0x8c, 0xcf, 0xd7, 0x08, 0x02, 0x08, 0x01, 0x52, + 0x03, 0x75, 0x69, 0x64, 0x12, 0x25, 0x0a, 0x0b, 0x64, 0x65, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, + 0x69, 0x6f, 0x6e, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0b, + 0x64, 0x65, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x12, 0x26, 0x0a, 0x0c, 0x64, + 0x69, 0x73, 0x70, 0x6c, 0x61, 0x79, 0x5f, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x04, 0x20, 0x01, 0x28, + 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0b, 0x64, 0x69, 0x73, 0x70, 0x6c, 0x61, 0x79, 0x4e, + 0x61, 0x6d, 0x65, 0x12, 0x4b, 0x0a, 0x06, 0x6c, 0x61, 0x62, 0x65, 0x6c, 0x73, 0x18, 0x05, 0x20, + 0x03, 0x28, 0x0b, 0x32, 0x2e, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, - 0x61, 0x74, 0x61, 0x50, 0x72, 0x6f, 0x66, 0x69, 0x6c, 0x65, 0x53, 0x70, 0x65, 0x63, 0x48, 0x00, - 0x52, 0x0f, 0x64, 0x61, 0x74, 0x61, 0x50, 0x72, 0x6f, 0x66, 0x69, 0x6c, 0x65, 0x53, 0x70, 0x65, - 0x63, 0x12, 0x5d, 0x0a, 0x13, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x64, 0x69, 0x73, 0x63, 0x6f, 0x76, - 0x65, 0x72, 0x79, 0x5f, 0x73, 0x70, 0x65, 0x63, 0x18, 0x66, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x2b, - 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, - 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x44, 0x69, - 0x73, 0x63, 0x6f, 0x76, 0x65, 0x72, 0x79, 0x53, 0x70, 0x65, 0x63, 0x48, 0x00, 0x52, 0x11, 0x64, - 0x61, 0x74, 0x61, 0x44, 0x69, 0x73, 0x63, 0x6f, 0x76, 0x65, 0x72, 0x79, 0x53, 0x70, 0x65, 0x63, - 0x12, 0x63, 0x0a, 0x13, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x71, 0x75, 0x61, 0x6c, 0x69, 0x74, 0x79, - 0x5f, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x18, 0xc8, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x2b, + 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x2e, 0x4c, 0x61, 0x62, 0x65, 0x6c, 0x73, 0x45, 0x6e, + 0x74, 0x72, 0x79, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x06, 0x6c, 0x61, 0x62, 0x65, 0x6c, 0x73, + 0x12, 0x3a, 0x0a, 0x05, 0x73, 0x74, 0x61, 0x74, 0x65, 0x18, 0x06, 0x20, 0x01, 0x28, 0x0e, 0x32, + 0x1f, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, + 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x53, 0x74, 0x61, 0x74, 0x65, + 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x05, 0x73, 0x74, 0x61, 0x74, 0x65, 0x12, 0x40, 0x0a, 0x0b, + 0x63, 0x72, 0x65, 0x61, 0x74, 0x65, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x18, 0x07, 0x20, 0x01, 0x28, + 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, + 0x62, 0x75, 0x66, 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x42, 0x03, 0xe0, + 0x41, 0x03, 0x52, 0x0a, 0x63, 0x72, 0x65, 0x61, 0x74, 0x65, 0x54, 0x69, 0x6d, 0x65, 0x12, 0x40, + 0x0a, 0x0b, 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x18, 0x08, 0x20, + 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, + 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x42, + 0x03, 0xe0, 0x41, 0x03, 0x52, 0x0a, 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, 0x54, 0x69, 0x6d, 0x65, + 0x12, 0x3d, 0x0a, 0x04, 0x64, 0x61, 0x74, 0x61, 0x18, 0x09, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x24, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, - 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x51, 0x75, - 0x61, 0x6c, 0x69, 0x74, 0x79, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x42, 0x03, 0xe0, 0x41, 0x03, - 0x48, 0x01, 0x52, 0x11, 0x64, 0x61, 0x74, 0x61, 0x51, 0x75, 0x61, 0x6c, 0x69, 0x74, 0x79, 0x52, - 0x65, 0x73, 0x75, 0x6c, 0x74, 0x12, 0x63, 0x0a, 0x13, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x70, 0x72, - 0x6f, 0x66, 0x69, 0x6c, 0x65, 0x5f, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x18, 0xc9, 0x01, 0x20, - 0x01, 0x28, 0x0b, 0x32, 0x2b, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, - 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, - 0x61, 0x74, 0x61, 0x50, 0x72, 0x6f, 0x66, 0x69, 0x6c, 0x65, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, - 0x42, 0x03, 0xe0, 0x41, 0x03, 0x48, 0x01, 0x52, 0x11, 0x64, 0x61, 0x74, 0x61, 0x50, 0x72, 0x6f, - 0x66, 0x69, 0x6c, 0x65, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x12, 0x69, 0x0a, 0x15, 0x64, 0x61, - 0x74, 0x61, 0x5f, 0x64, 0x69, 0x73, 0x63, 0x6f, 0x76, 0x65, 0x72, 0x79, 0x5f, 0x72, 0x65, 0x73, - 0x75, 0x6c, 0x74, 0x18, 0xca, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x2d, 0x2e, 0x67, 0x6f, 0x6f, - 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, - 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x44, 0x69, 0x73, 0x63, 0x6f, 0x76, - 0x65, 0x72, 0x79, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x48, 0x01, - 0x52, 0x13, 0x64, 0x61, 0x74, 0x61, 0x44, 0x69, 0x73, 0x63, 0x6f, 0x76, 0x65, 0x72, 0x79, 0x52, - 0x65, 0x73, 0x75, 0x6c, 0x74, 0x1a, 0x7d, 0x0a, 0x0d, 0x45, 0x78, 0x65, 0x63, 0x75, 0x74, 0x69, - 0x6f, 0x6e, 0x53, 0x70, 0x65, 0x63, 0x12, 0x40, 0x0a, 0x07, 0x74, 0x72, 0x69, 0x67, 0x67, 0x65, - 0x72, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x21, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, + 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x53, 0x6f, + 0x75, 0x72, 0x63, 0x65, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x04, 0x64, 0x61, 0x74, 0x61, 0x12, + 0x5c, 0x0a, 0x0e, 0x65, 0x78, 0x65, 0x63, 0x75, 0x74, 0x69, 0x6f, 0x6e, 0x5f, 0x73, 0x70, 0x65, + 0x63, 0x18, 0x0a, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x30, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, + 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, + 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x2e, 0x45, 0x78, 0x65, 0x63, + 0x75, 0x74, 0x69, 0x6f, 0x6e, 0x53, 0x70, 0x65, 0x63, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0d, + 0x65, 0x78, 0x65, 0x63, 0x75, 0x74, 0x69, 0x6f, 0x6e, 0x53, 0x70, 0x65, 0x63, 0x12, 0x62, 0x0a, + 0x10, 0x65, 0x78, 0x65, 0x63, 0x75, 0x74, 0x69, 0x6f, 0x6e, 0x5f, 0x73, 0x74, 0x61, 0x74, 0x75, + 0x73, 0x18, 0x0b, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x32, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, - 0x76, 0x31, 0x2e, 0x54, 0x72, 0x69, 0x67, 0x67, 0x65, 0x72, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, - 0x07, 0x74, 0x72, 0x69, 0x67, 0x67, 0x65, 0x72, 0x12, 0x1b, 0x0a, 0x05, 0x66, 0x69, 0x65, 0x6c, - 0x64, 0x18, 0x64, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x05, 0x48, 0x00, 0x52, 0x05, - 0x66, 0x69, 0x65, 0x6c, 0x64, 0x42, 0x0d, 0x0a, 0x0b, 0x69, 0x6e, 0x63, 0x72, 0x65, 0x6d, 0x65, - 0x6e, 0x74, 0x61, 0x6c, 0x1a, 0x81, 0x02, 0x0a, 0x0f, 0x45, 0x78, 0x65, 0x63, 0x75, 0x74, 0x69, - 0x6f, 0x6e, 0x53, 0x74, 0x61, 0x74, 0x75, 0x73, 0x12, 0x4d, 0x0a, 0x15, 0x6c, 0x61, 0x74, 0x65, - 0x73, 0x74, 0x5f, 0x6a, 0x6f, 0x62, 0x5f, 0x73, 0x74, 0x61, 0x72, 0x74, 0x5f, 0x74, 0x69, 0x6d, - 0x65, 0x18, 0x04, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, + 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x2e, 0x45, 0x78, 0x65, 0x63, + 0x75, 0x74, 0x69, 0x6f, 0x6e, 0x53, 0x74, 0x61, 0x74, 0x75, 0x73, 0x42, 0x03, 0xe0, 0x41, 0x03, + 0x52, 0x0f, 0x65, 0x78, 0x65, 0x63, 0x75, 0x74, 0x69, 0x6f, 0x6e, 0x53, 0x74, 0x61, 0x74, 0x75, + 0x73, 0x12, 0x3f, 0x0a, 0x04, 0x74, 0x79, 0x70, 0x65, 0x18, 0x0c, 0x20, 0x01, 0x28, 0x0e, 0x32, + 0x26, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, + 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x53, + 0x63, 0x61, 0x6e, 0x54, 0x79, 0x70, 0x65, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x04, 0x74, 0x79, + 0x70, 0x65, 0x12, 0x57, 0x0a, 0x11, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x71, 0x75, 0x61, 0x6c, 0x69, + 0x74, 0x79, 0x5f, 0x73, 0x70, 0x65, 0x63, 0x18, 0x64, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x29, 0x2e, + 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, + 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x51, 0x75, 0x61, + 0x6c, 0x69, 0x74, 0x79, 0x53, 0x70, 0x65, 0x63, 0x48, 0x00, 0x52, 0x0f, 0x64, 0x61, 0x74, 0x61, + 0x51, 0x75, 0x61, 0x6c, 0x69, 0x74, 0x79, 0x53, 0x70, 0x65, 0x63, 0x12, 0x57, 0x0a, 0x11, 0x64, + 0x61, 0x74, 0x61, 0x5f, 0x70, 0x72, 0x6f, 0x66, 0x69, 0x6c, 0x65, 0x5f, 0x73, 0x70, 0x65, 0x63, + 0x18, 0x65, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x29, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, + 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, + 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x50, 0x72, 0x6f, 0x66, 0x69, 0x6c, 0x65, 0x53, 0x70, 0x65, + 0x63, 0x48, 0x00, 0x52, 0x0f, 0x64, 0x61, 0x74, 0x61, 0x50, 0x72, 0x6f, 0x66, 0x69, 0x6c, 0x65, + 0x53, 0x70, 0x65, 0x63, 0x12, 0x5d, 0x0a, 0x13, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x64, 0x69, 0x73, + 0x63, 0x6f, 0x76, 0x65, 0x72, 0x79, 0x5f, 0x73, 0x70, 0x65, 0x63, 0x18, 0x66, 0x20, 0x01, 0x28, + 0x0b, 0x32, 0x2b, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, + 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, + 0x61, 0x44, 0x69, 0x73, 0x63, 0x6f, 0x76, 0x65, 0x72, 0x79, 0x53, 0x70, 0x65, 0x63, 0x48, 0x00, + 0x52, 0x11, 0x64, 0x61, 0x74, 0x61, 0x44, 0x69, 0x73, 0x63, 0x6f, 0x76, 0x65, 0x72, 0x79, 0x53, + 0x70, 0x65, 0x63, 0x12, 0x63, 0x0a, 0x13, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x71, 0x75, 0x61, 0x6c, + 0x69, 0x74, 0x79, 0x5f, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x18, 0xc8, 0x01, 0x20, 0x01, 0x28, + 0x0b, 0x32, 0x2b, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, + 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, + 0x61, 0x51, 0x75, 0x61, 0x6c, 0x69, 0x74, 0x79, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x42, 0x03, + 0xe0, 0x41, 0x03, 0x48, 0x01, 0x52, 0x11, 0x64, 0x61, 0x74, 0x61, 0x51, 0x75, 0x61, 0x6c, 0x69, + 0x74, 0x79, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x12, 0x63, 0x0a, 0x13, 0x64, 0x61, 0x74, 0x61, + 0x5f, 0x70, 0x72, 0x6f, 0x66, 0x69, 0x6c, 0x65, 0x5f, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x18, + 0xc9, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x2b, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, + 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, + 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x50, 0x72, 0x6f, 0x66, 0x69, 0x6c, 0x65, 0x52, 0x65, 0x73, + 0x75, 0x6c, 0x74, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x48, 0x01, 0x52, 0x11, 0x64, 0x61, 0x74, 0x61, + 0x50, 0x72, 0x6f, 0x66, 0x69, 0x6c, 0x65, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x12, 0x69, 0x0a, + 0x15, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x64, 0x69, 0x73, 0x63, 0x6f, 0x76, 0x65, 0x72, 0x79, 0x5f, + 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x18, 0xca, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x2d, 0x2e, + 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, + 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x44, 0x69, 0x73, + 0x63, 0x6f, 0x76, 0x65, 0x72, 0x79, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x42, 0x03, 0xe0, 0x41, + 0x03, 0x48, 0x01, 0x52, 0x13, 0x64, 0x61, 0x74, 0x61, 0x44, 0x69, 0x73, 0x63, 0x6f, 0x76, 0x65, + 0x72, 0x79, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x1a, 0x7d, 0x0a, 0x0d, 0x45, 0x78, 0x65, 0x63, + 0x75, 0x74, 0x69, 0x6f, 0x6e, 0x53, 0x70, 0x65, 0x63, 0x12, 0x40, 0x0a, 0x07, 0x74, 0x72, 0x69, + 0x67, 0x67, 0x65, 0x72, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x21, 0x2e, 0x67, 0x6f, 0x6f, + 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, + 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x54, 0x72, 0x69, 0x67, 0x67, 0x65, 0x72, 0x42, 0x03, 0xe0, + 0x41, 0x01, 0x52, 0x07, 0x74, 0x72, 0x69, 0x67, 0x67, 0x65, 0x72, 0x12, 0x1b, 0x0a, 0x05, 0x66, + 0x69, 0x65, 0x6c, 0x64, 0x18, 0x64, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x05, 0x48, + 0x00, 0x52, 0x05, 0x66, 0x69, 0x65, 0x6c, 0x64, 0x42, 0x0d, 0x0a, 0x0b, 0x69, 0x6e, 0x63, 0x72, + 0x65, 0x6d, 0x65, 0x6e, 0x74, 0x61, 0x6c, 0x1a, 0x8b, 0x02, 0x0a, 0x0f, 0x45, 0x78, 0x65, 0x63, + 0x75, 0x74, 0x69, 0x6f, 0x6e, 0x53, 0x74, 0x61, 0x74, 0x75, 0x73, 0x12, 0x52, 0x0a, 0x15, 0x6c, + 0x61, 0x74, 0x65, 0x73, 0x74, 0x5f, 0x6a, 0x6f, 0x62, 0x5f, 0x73, 0x74, 0x61, 0x72, 0x74, 0x5f, + 0x74, 0x69, 0x6d, 0x65, 0x18, 0x04, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, + 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x54, 0x69, 0x6d, + 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x12, 0x6c, 0x61, 0x74, + 0x65, 0x73, 0x74, 0x4a, 0x6f, 0x62, 0x53, 0x74, 0x61, 0x72, 0x74, 0x54, 0x69, 0x6d, 0x65, 0x12, + 0x4e, 0x0a, 0x13, 0x6c, 0x61, 0x74, 0x65, 0x73, 0x74, 0x5f, 0x6a, 0x6f, 0x62, 0x5f, 0x65, 0x6e, + 0x64, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x18, 0x05, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, + 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x54, + 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x10, 0x6c, + 0x61, 0x74, 0x65, 0x73, 0x74, 0x4a, 0x6f, 0x62, 0x45, 0x6e, 0x64, 0x54, 0x69, 0x6d, 0x65, 0x12, + 0x54, 0x0a, 0x16, 0x6c, 0x61, 0x74, 0x65, 0x73, 0x74, 0x5f, 0x6a, 0x6f, 0x62, 0x5f, 0x63, 0x72, + 0x65, 0x61, 0x74, 0x65, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x18, 0x06, 0x20, 0x01, 0x28, 0x0b, 0x32, + 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, + 0x66, 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x42, 0x03, 0xe0, 0x41, 0x01, + 0x52, 0x13, 0x6c, 0x61, 0x74, 0x65, 0x73, 0x74, 0x4a, 0x6f, 0x62, 0x43, 0x72, 0x65, 0x61, 0x74, + 0x65, 0x54, 0x69, 0x6d, 0x65, 0x1a, 0x39, 0x0a, 0x0b, 0x4c, 0x61, 0x62, 0x65, 0x6c, 0x73, 0x45, + 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, 0x03, 0x6b, 0x65, 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, + 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x14, 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, + 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x3a, 0x02, 0x38, 0x01, + 0x3a, 0x63, 0xea, 0x41, 0x60, 0x0a, 0x20, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, + 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x44, + 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x12, 0x3c, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, + 0x73, 0x2f, 0x7b, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x7d, 0x2f, 0x6c, 0x6f, 0x63, 0x61, + 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x7b, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x7d, + 0x2f, 0x64, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x73, 0x2f, 0x7b, 0x64, 0x61, 0x74, 0x61, + 0x53, 0x63, 0x61, 0x6e, 0x7d, 0x42, 0x06, 0x0a, 0x04, 0x73, 0x70, 0x65, 0x63, 0x42, 0x08, 0x0a, + 0x06, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x22, 0xfb, 0x09, 0x0a, 0x0b, 0x44, 0x61, 0x74, 0x61, + 0x53, 0x63, 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x12, 0x1a, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, + 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x06, 0xe0, 0x41, 0x03, 0xe0, 0x41, 0x08, 0x52, 0x04, 0x6e, + 0x61, 0x6d, 0x65, 0x12, 0x1d, 0x0a, 0x03, 0x75, 0x69, 0x64, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, + 0x42, 0x0b, 0xe0, 0x41, 0x03, 0xe2, 0x8c, 0xcf, 0xd7, 0x08, 0x02, 0x08, 0x01, 0x52, 0x03, 0x75, + 0x69, 0x64, 0x12, 0x40, 0x0a, 0x0b, 0x63, 0x72, 0x65, 0x61, 0x74, 0x65, 0x5f, 0x74, 0x69, 0x6d, + 0x65, 0x18, 0x08, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x73, 0x74, - 0x61, 0x6d, 0x70, 0x52, 0x12, 0x6c, 0x61, 0x74, 0x65, 0x73, 0x74, 0x4a, 0x6f, 0x62, 0x53, 0x74, - 0x61, 0x72, 0x74, 0x54, 0x69, 0x6d, 0x65, 0x12, 0x49, 0x0a, 0x13, 0x6c, 0x61, 0x74, 0x65, 0x73, - 0x74, 0x5f, 0x6a, 0x6f, 0x62, 0x5f, 0x65, 0x6e, 0x64, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x18, 0x05, - 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, - 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, - 0x52, 0x10, 0x6c, 0x61, 0x74, 0x65, 0x73, 0x74, 0x4a, 0x6f, 0x62, 0x45, 0x6e, 0x64, 0x54, 0x69, - 0x6d, 0x65, 0x12, 0x54, 0x0a, 0x16, 0x6c, 0x61, 0x74, 0x65, 0x73, 0x74, 0x5f, 0x6a, 0x6f, 0x62, - 0x5f, 0x63, 0x72, 0x65, 0x61, 0x74, 0x65, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x18, 0x06, 0x20, 0x01, - 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, - 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x42, 0x03, - 0xe0, 0x41, 0x01, 0x52, 0x13, 0x6c, 0x61, 0x74, 0x65, 0x73, 0x74, 0x4a, 0x6f, 0x62, 0x43, 0x72, - 0x65, 0x61, 0x74, 0x65, 0x54, 0x69, 0x6d, 0x65, 0x1a, 0x39, 0x0a, 0x0b, 0x4c, 0x61, 0x62, 0x65, - 0x6c, 0x73, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, 0x03, 0x6b, 0x65, 0x79, 0x18, 0x01, - 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x14, 0x0a, 0x05, 0x76, 0x61, 0x6c, - 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x3a, - 0x02, 0x38, 0x01, 0x3a, 0x63, 0xea, 0x41, 0x60, 0x0a, 0x20, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, - 0x65, 0x78, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, - 0x6d, 0x2f, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x12, 0x3c, 0x70, 0x72, 0x6f, 0x6a, + 0x61, 0x6d, 0x70, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x0a, 0x63, 0x72, 0x65, 0x61, 0x74, 0x65, + 0x54, 0x69, 0x6d, 0x65, 0x12, 0x3e, 0x0a, 0x0a, 0x73, 0x74, 0x61, 0x72, 0x74, 0x5f, 0x74, 0x69, + 0x6d, 0x65, 0x18, 0x03, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, + 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x73, + 0x74, 0x61, 0x6d, 0x70, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x09, 0x73, 0x74, 0x61, 0x72, 0x74, + 0x54, 0x69, 0x6d, 0x65, 0x12, 0x3a, 0x0a, 0x08, 0x65, 0x6e, 0x64, 0x5f, 0x74, 0x69, 0x6d, 0x65, + 0x18, 0x04, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, + 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, + 0x6d, 0x70, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x07, 0x65, 0x6e, 0x64, 0x54, 0x69, 0x6d, 0x65, + 0x12, 0x46, 0x0a, 0x05, 0x73, 0x74, 0x61, 0x74, 0x65, 0x18, 0x05, 0x20, 0x01, 0x28, 0x0e, 0x32, + 0x2b, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, + 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x53, + 0x63, 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x2e, 0x53, 0x74, 0x61, 0x74, 0x65, 0x42, 0x03, 0xe0, 0x41, + 0x03, 0x52, 0x05, 0x73, 0x74, 0x61, 0x74, 0x65, 0x12, 0x1d, 0x0a, 0x07, 0x6d, 0x65, 0x73, 0x73, + 0x61, 0x67, 0x65, 0x18, 0x06, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x07, + 0x6d, 0x65, 0x73, 0x73, 0x61, 0x67, 0x65, 0x12, 0x3f, 0x0a, 0x04, 0x74, 0x79, 0x70, 0x65, 0x18, + 0x07, 0x20, 0x01, 0x28, 0x0e, 0x32, 0x26, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, + 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, + 0x2e, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x54, 0x79, 0x70, 0x65, 0x42, 0x03, 0xe0, + 0x41, 0x03, 0x52, 0x04, 0x74, 0x79, 0x70, 0x65, 0x12, 0x5c, 0x0a, 0x11, 0x64, 0x61, 0x74, 0x61, + 0x5f, 0x71, 0x75, 0x61, 0x6c, 0x69, 0x74, 0x79, 0x5f, 0x73, 0x70, 0x65, 0x63, 0x18, 0x64, 0x20, + 0x01, 0x28, 0x0b, 0x32, 0x29, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, + 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, + 0x61, 0x74, 0x61, 0x51, 0x75, 0x61, 0x6c, 0x69, 0x74, 0x79, 0x53, 0x70, 0x65, 0x63, 0x42, 0x03, + 0xe0, 0x41, 0x03, 0x48, 0x00, 0x52, 0x0f, 0x64, 0x61, 0x74, 0x61, 0x51, 0x75, 0x61, 0x6c, 0x69, + 0x74, 0x79, 0x53, 0x70, 0x65, 0x63, 0x12, 0x5c, 0x0a, 0x11, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x70, + 0x72, 0x6f, 0x66, 0x69, 0x6c, 0x65, 0x5f, 0x73, 0x70, 0x65, 0x63, 0x18, 0x65, 0x20, 0x01, 0x28, + 0x0b, 0x32, 0x29, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, + 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, + 0x61, 0x50, 0x72, 0x6f, 0x66, 0x69, 0x6c, 0x65, 0x53, 0x70, 0x65, 0x63, 0x42, 0x03, 0xe0, 0x41, + 0x03, 0x48, 0x00, 0x52, 0x0f, 0x64, 0x61, 0x74, 0x61, 0x50, 0x72, 0x6f, 0x66, 0x69, 0x6c, 0x65, + 0x53, 0x70, 0x65, 0x63, 0x12, 0x62, 0x0a, 0x13, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x64, 0x69, 0x73, + 0x63, 0x6f, 0x76, 0x65, 0x72, 0x79, 0x5f, 0x73, 0x70, 0x65, 0x63, 0x18, 0x66, 0x20, 0x01, 0x28, + 0x0b, 0x32, 0x2b, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, + 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, + 0x61, 0x44, 0x69, 0x73, 0x63, 0x6f, 0x76, 0x65, 0x72, 0x79, 0x53, 0x70, 0x65, 0x63, 0x42, 0x03, + 0xe0, 0x41, 0x03, 0x48, 0x00, 0x52, 0x11, 0x64, 0x61, 0x74, 0x61, 0x44, 0x69, 0x73, 0x63, 0x6f, + 0x76, 0x65, 0x72, 0x79, 0x53, 0x70, 0x65, 0x63, 0x12, 0x63, 0x0a, 0x13, 0x64, 0x61, 0x74, 0x61, + 0x5f, 0x71, 0x75, 0x61, 0x6c, 0x69, 0x74, 0x79, 0x5f, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x18, + 0xc8, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x2b, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, + 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, + 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x51, 0x75, 0x61, 0x6c, 0x69, 0x74, 0x79, 0x52, 0x65, 0x73, + 0x75, 0x6c, 0x74, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x48, 0x01, 0x52, 0x11, 0x64, 0x61, 0x74, 0x61, + 0x51, 0x75, 0x61, 0x6c, 0x69, 0x74, 0x79, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x12, 0x63, 0x0a, + 0x13, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x70, 0x72, 0x6f, 0x66, 0x69, 0x6c, 0x65, 0x5f, 0x72, 0x65, + 0x73, 0x75, 0x6c, 0x74, 0x18, 0xc9, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x2b, 0x2e, 0x67, 0x6f, + 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, + 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x50, 0x72, 0x6f, 0x66, 0x69, + 0x6c, 0x65, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x48, 0x01, 0x52, + 0x11, 0x64, 0x61, 0x74, 0x61, 0x50, 0x72, 0x6f, 0x66, 0x69, 0x6c, 0x65, 0x52, 0x65, 0x73, 0x75, + 0x6c, 0x74, 0x12, 0x69, 0x0a, 0x15, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x64, 0x69, 0x73, 0x63, 0x6f, + 0x76, 0x65, 0x72, 0x79, 0x5f, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x18, 0xca, 0x01, 0x20, 0x01, + 0x28, 0x0b, 0x32, 0x2d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, + 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, + 0x74, 0x61, 0x44, 0x69, 0x73, 0x63, 0x6f, 0x76, 0x65, 0x72, 0x79, 0x52, 0x65, 0x73, 0x75, 0x6c, + 0x74, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x48, 0x01, 0x52, 0x13, 0x64, 0x61, 0x74, 0x61, 0x44, 0x69, + 0x73, 0x63, 0x6f, 0x76, 0x65, 0x72, 0x79, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x22, 0x71, 0x0a, + 0x05, 0x53, 0x74, 0x61, 0x74, 0x65, 0x12, 0x15, 0x0a, 0x11, 0x53, 0x54, 0x41, 0x54, 0x45, 0x5f, + 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x0b, 0x0a, + 0x07, 0x52, 0x55, 0x4e, 0x4e, 0x49, 0x4e, 0x47, 0x10, 0x01, 0x12, 0x0d, 0x0a, 0x09, 0x43, 0x41, + 0x4e, 0x43, 0x45, 0x4c, 0x49, 0x4e, 0x47, 0x10, 0x02, 0x12, 0x0d, 0x0a, 0x09, 0x43, 0x41, 0x4e, + 0x43, 0x45, 0x4c, 0x4c, 0x45, 0x44, 0x10, 0x03, 0x12, 0x0d, 0x0a, 0x09, 0x53, 0x55, 0x43, 0x43, + 0x45, 0x45, 0x44, 0x45, 0x44, 0x10, 0x04, 0x12, 0x0a, 0x0a, 0x06, 0x46, 0x41, 0x49, 0x4c, 0x45, + 0x44, 0x10, 0x05, 0x12, 0x0b, 0x0a, 0x07, 0x50, 0x45, 0x4e, 0x44, 0x49, 0x4e, 0x47, 0x10, 0x07, + 0x3a, 0x71, 0xea, 0x41, 0x6e, 0x0a, 0x23, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, + 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x44, + 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x12, 0x47, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x7b, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x7d, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x7b, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x7d, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x73, 0x2f, 0x7b, 0x64, - 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x7d, 0x42, 0x06, 0x0a, 0x04, 0x73, 0x70, 0x65, 0x63, - 0x42, 0x08, 0x0a, 0x06, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x22, 0xf0, 0x09, 0x0a, 0x0b, 0x44, - 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x12, 0x17, 0x0a, 0x04, 0x6e, 0x61, - 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x04, 0x6e, - 0x61, 0x6d, 0x65, 0x12, 0x15, 0x0a, 0x03, 0x75, 0x69, 0x64, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, - 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x03, 0x75, 0x69, 0x64, 0x12, 0x40, 0x0a, 0x0b, 0x63, 0x72, - 0x65, 0x61, 0x74, 0x65, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x18, 0x08, 0x20, 0x01, 0x28, 0x0b, 0x32, - 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, - 0x66, 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x42, 0x03, 0xe0, 0x41, 0x03, - 0x52, 0x0a, 0x63, 0x72, 0x65, 0x61, 0x74, 0x65, 0x54, 0x69, 0x6d, 0x65, 0x12, 0x3e, 0x0a, 0x0a, - 0x73, 0x74, 0x61, 0x72, 0x74, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x18, 0x03, 0x20, 0x01, 0x28, 0x0b, - 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, - 0x75, 0x66, 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x42, 0x03, 0xe0, 0x41, - 0x03, 0x52, 0x09, 0x73, 0x74, 0x61, 0x72, 0x74, 0x54, 0x69, 0x6d, 0x65, 0x12, 0x3a, 0x0a, 0x08, - 0x65, 0x6e, 0x64, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x18, 0x04, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, - 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, - 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, - 0x07, 0x65, 0x6e, 0x64, 0x54, 0x69, 0x6d, 0x65, 0x12, 0x46, 0x0a, 0x05, 0x73, 0x74, 0x61, 0x74, - 0x65, 0x18, 0x05, 0x20, 0x01, 0x28, 0x0e, 0x32, 0x2b, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, - 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, - 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x2e, 0x53, - 0x74, 0x61, 0x74, 0x65, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x05, 0x73, 0x74, 0x61, 0x74, 0x65, - 0x12, 0x1d, 0x0a, 0x07, 0x6d, 0x65, 0x73, 0x73, 0x61, 0x67, 0x65, 0x18, 0x06, 0x20, 0x01, 0x28, - 0x09, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x07, 0x6d, 0x65, 0x73, 0x73, 0x61, 0x67, 0x65, 0x12, - 0x3f, 0x0a, 0x04, 0x74, 0x79, 0x70, 0x65, 0x18, 0x07, 0x20, 0x01, 0x28, 0x0e, 0x32, 0x26, 0x2e, - 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, - 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, - 0x6e, 0x54, 0x79, 0x70, 0x65, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x04, 0x74, 0x79, 0x70, 0x65, - 0x12, 0x5c, 0x0a, 0x11, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x71, 0x75, 0x61, 0x6c, 0x69, 0x74, 0x79, - 0x5f, 0x73, 0x70, 0x65, 0x63, 0x18, 0x64, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x29, 0x2e, 0x67, 0x6f, - 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, - 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x51, 0x75, 0x61, 0x6c, 0x69, - 0x74, 0x79, 0x53, 0x70, 0x65, 0x63, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x48, 0x00, 0x52, 0x0f, 0x64, - 0x61, 0x74, 0x61, 0x51, 0x75, 0x61, 0x6c, 0x69, 0x74, 0x79, 0x53, 0x70, 0x65, 0x63, 0x12, 0x5c, - 0x0a, 0x11, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x70, 0x72, 0x6f, 0x66, 0x69, 0x6c, 0x65, 0x5f, 0x73, - 0x70, 0x65, 0x63, 0x18, 0x65, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x29, 0x2e, 0x67, 0x6f, 0x6f, 0x67, - 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, - 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x50, 0x72, 0x6f, 0x66, 0x69, 0x6c, 0x65, - 0x53, 0x70, 0x65, 0x63, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x48, 0x00, 0x52, 0x0f, 0x64, 0x61, 0x74, - 0x61, 0x50, 0x72, 0x6f, 0x66, 0x69, 0x6c, 0x65, 0x53, 0x70, 0x65, 0x63, 0x12, 0x62, 0x0a, 0x13, - 0x64, 0x61, 0x74, 0x61, 0x5f, 0x64, 0x69, 0x73, 0x63, 0x6f, 0x76, 0x65, 0x72, 0x79, 0x5f, 0x73, - 0x70, 0x65, 0x63, 0x18, 0x66, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x2b, 0x2e, 0x67, 0x6f, 0x6f, 0x67, - 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, - 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x44, 0x69, 0x73, 0x63, 0x6f, 0x76, 0x65, - 0x72, 0x79, 0x53, 0x70, 0x65, 0x63, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x48, 0x00, 0x52, 0x11, 0x64, - 0x61, 0x74, 0x61, 0x44, 0x69, 0x73, 0x63, 0x6f, 0x76, 0x65, 0x72, 0x79, 0x53, 0x70, 0x65, 0x63, - 0x12, 0x63, 0x0a, 0x13, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x71, 0x75, 0x61, 0x6c, 0x69, 0x74, 0x79, - 0x5f, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x18, 0xc8, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x2b, - 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, - 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x51, 0x75, - 0x61, 0x6c, 0x69, 0x74, 0x79, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x42, 0x03, 0xe0, 0x41, 0x03, - 0x48, 0x01, 0x52, 0x11, 0x64, 0x61, 0x74, 0x61, 0x51, 0x75, 0x61, 0x6c, 0x69, 0x74, 0x79, 0x52, - 0x65, 0x73, 0x75, 0x6c, 0x74, 0x12, 0x63, 0x0a, 0x13, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x70, 0x72, - 0x6f, 0x66, 0x69, 0x6c, 0x65, 0x5f, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x18, 0xc9, 0x01, 0x20, - 0x01, 0x28, 0x0b, 0x32, 0x2b, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, - 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, - 0x61, 0x74, 0x61, 0x50, 0x72, 0x6f, 0x66, 0x69, 0x6c, 0x65, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, - 0x42, 0x03, 0xe0, 0x41, 0x03, 0x48, 0x01, 0x52, 0x11, 0x64, 0x61, 0x74, 0x61, 0x50, 0x72, 0x6f, - 0x66, 0x69, 0x6c, 0x65, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x12, 0x69, 0x0a, 0x15, 0x64, 0x61, - 0x74, 0x61, 0x5f, 0x64, 0x69, 0x73, 0x63, 0x6f, 0x76, 0x65, 0x72, 0x79, 0x5f, 0x72, 0x65, 0x73, - 0x75, 0x6c, 0x74, 0x18, 0xca, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x2d, 0x2e, 0x67, 0x6f, 0x6f, - 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, - 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x44, 0x69, 0x73, 0x63, 0x6f, 0x76, - 0x65, 0x72, 0x79, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x48, 0x01, - 0x52, 0x13, 0x64, 0x61, 0x74, 0x61, 0x44, 0x69, 0x73, 0x63, 0x6f, 0x76, 0x65, 0x72, 0x79, 0x52, - 0x65, 0x73, 0x75, 0x6c, 0x74, 0x22, 0x71, 0x0a, 0x05, 0x53, 0x74, 0x61, 0x74, 0x65, 0x12, 0x15, - 0x0a, 0x11, 0x53, 0x54, 0x41, 0x54, 0x45, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, - 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x0b, 0x0a, 0x07, 0x52, 0x55, 0x4e, 0x4e, 0x49, 0x4e, 0x47, - 0x10, 0x01, 0x12, 0x0d, 0x0a, 0x09, 0x43, 0x41, 0x4e, 0x43, 0x45, 0x4c, 0x49, 0x4e, 0x47, 0x10, - 0x02, 0x12, 0x0d, 0x0a, 0x09, 0x43, 0x41, 0x4e, 0x43, 0x45, 0x4c, 0x4c, 0x45, 0x44, 0x10, 0x03, - 0x12, 0x0d, 0x0a, 0x09, 0x53, 0x55, 0x43, 0x43, 0x45, 0x45, 0x44, 0x45, 0x44, 0x10, 0x04, 0x12, - 0x0a, 0x0a, 0x06, 0x46, 0x41, 0x49, 0x4c, 0x45, 0x44, 0x10, 0x05, 0x12, 0x0b, 0x0a, 0x07, 0x50, - 0x45, 0x4e, 0x44, 0x49, 0x4e, 0x47, 0x10, 0x07, 0x3a, 0x71, 0xea, 0x41, 0x6e, 0x0a, 0x23, 0x64, - 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, - 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x4a, - 0x6f, 0x62, 0x12, 0x47, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x7b, 0x70, 0x72, - 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x7d, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, - 0x2f, 0x7b, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x7d, 0x2f, 0x64, 0x61, 0x74, 0x61, - 0x53, 0x63, 0x61, 0x6e, 0x73, 0x2f, 0x7b, 0x64, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x7d, - 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x2f, 0x7b, 0x6a, 0x6f, 0x62, 0x7d, 0x42, 0x06, 0x0a, 0x04, 0x73, - 0x70, 0x65, 0x63, 0x42, 0x08, 0x0a, 0x06, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x2a, 0x66, 0x0a, - 0x0c, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x54, 0x79, 0x70, 0x65, 0x12, 0x1e, 0x0a, - 0x1a, 0x44, 0x41, 0x54, 0x41, 0x5f, 0x53, 0x43, 0x41, 0x4e, 0x5f, 0x54, 0x59, 0x50, 0x45, 0x5f, - 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x10, 0x0a, - 0x0c, 0x44, 0x41, 0x54, 0x41, 0x5f, 0x51, 0x55, 0x41, 0x4c, 0x49, 0x54, 0x59, 0x10, 0x01, 0x12, - 0x10, 0x0a, 0x0c, 0x44, 0x41, 0x54, 0x41, 0x5f, 0x50, 0x52, 0x4f, 0x46, 0x49, 0x4c, 0x45, 0x10, - 0x02, 0x12, 0x12, 0x0a, 0x0e, 0x44, 0x41, 0x54, 0x41, 0x5f, 0x44, 0x49, 0x53, 0x43, 0x4f, 0x56, - 0x45, 0x52, 0x59, 0x10, 0x03, 0x32, 0xb6, 0x0f, 0x0a, 0x0f, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, - 0x61, 0x6e, 0x53, 0x65, 0x72, 0x76, 0x69, 0x63, 0x65, 0x12, 0xe3, 0x01, 0x0a, 0x0e, 0x43, 0x72, - 0x65, 0x61, 0x74, 0x65, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x12, 0x2f, 0x2e, 0x67, - 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, - 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x44, 0x61, - 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, - 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x6c, 0x6f, 0x6e, 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, - 0x6e, 0x67, 0x2e, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x22, 0x80, 0x01, 0xca, - 0x41, 0x1d, 0x0a, 0x08, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x12, 0x11, 0x4f, 0x70, - 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0xda, - 0x41, 0x1d, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x2c, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x73, 0x63, - 0x61, 0x6e, 0x2c, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x73, 0x63, 0x61, 0x6e, 0x5f, 0x69, 0x64, 0x82, - 0xd3, 0xe4, 0x93, 0x02, 0x3a, 0x3a, 0x09, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x73, 0x63, 0x61, 0x6e, - 0x22, 0x2d, 0x2f, 0x76, 0x31, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, - 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, - 0x6e, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x73, 0x12, - 0xe5, 0x01, 0x0a, 0x0e, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, - 0x61, 0x6e, 0x12, 0x2f, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, - 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x55, 0x70, - 0x64, 0x61, 0x74, 0x65, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x52, 0x65, 0x71, 0x75, - 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x6c, 0x6f, 0x6e, - 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, 0x67, 0x2e, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, - 0x6f, 0x6e, 0x22, 0x82, 0x01, 0xca, 0x41, 0x1d, 0x0a, 0x08, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, - 0x61, 0x6e, 0x12, 0x11, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, - 0x61, 0x64, 0x61, 0x74, 0x61, 0xda, 0x41, 0x15, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x73, 0x63, 0x61, - 0x6e, 0x2c, 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x82, 0xd3, 0xe4, - 0x93, 0x02, 0x44, 0x3a, 0x09, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x73, 0x63, 0x61, 0x6e, 0x32, 0x37, - 0x2f, 0x76, 0x31, 0x2f, 0x7b, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x73, 0x63, 0x61, 0x6e, 0x2e, 0x6e, - 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, - 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x53, - 0x63, 0x61, 0x6e, 0x73, 0x2f, 0x2a, 0x7d, 0x12, 0xcb, 0x01, 0x0a, 0x0e, 0x44, 0x65, 0x6c, 0x65, + 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x7d, 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x2f, 0x7b, 0x6a, + 0x6f, 0x62, 0x7d, 0x42, 0x06, 0x0a, 0x04, 0x73, 0x70, 0x65, 0x63, 0x42, 0x08, 0x0a, 0x06, 0x72, + 0x65, 0x73, 0x75, 0x6c, 0x74, 0x2a, 0x66, 0x0a, 0x0c, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, + 0x6e, 0x54, 0x79, 0x70, 0x65, 0x12, 0x1e, 0x0a, 0x1a, 0x44, 0x41, 0x54, 0x41, 0x5f, 0x53, 0x43, + 0x41, 0x4e, 0x5f, 0x54, 0x59, 0x50, 0x45, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, + 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x10, 0x0a, 0x0c, 0x44, 0x41, 0x54, 0x41, 0x5f, 0x51, 0x55, + 0x41, 0x4c, 0x49, 0x54, 0x59, 0x10, 0x01, 0x12, 0x10, 0x0a, 0x0c, 0x44, 0x41, 0x54, 0x41, 0x5f, + 0x50, 0x52, 0x4f, 0x46, 0x49, 0x4c, 0x45, 0x10, 0x02, 0x12, 0x12, 0x0a, 0x0e, 0x44, 0x41, 0x54, + 0x41, 0x5f, 0x44, 0x49, 0x53, 0x43, 0x4f, 0x56, 0x45, 0x52, 0x59, 0x10, 0x03, 0x32, 0xb6, 0x0f, + 0x0a, 0x0f, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x53, 0x65, 0x72, 0x76, 0x69, 0x63, + 0x65, 0x12, 0xe3, 0x01, 0x0a, 0x0e, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x44, 0x61, 0x74, 0x61, + 0x53, 0x63, 0x61, 0x6e, 0x12, 0x2f, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, + 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, + 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x52, 0x65, + 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x6c, + 0x6f, 0x6e, 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, 0x67, 0x2e, 0x4f, 0x70, 0x65, 0x72, 0x61, + 0x74, 0x69, 0x6f, 0x6e, 0x22, 0x80, 0x01, 0xca, 0x41, 0x1d, 0x0a, 0x08, 0x44, 0x61, 0x74, 0x61, + 0x53, 0x63, 0x61, 0x6e, 0x12, 0x11, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, + 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0xda, 0x41, 0x1d, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, + 0x2c, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x73, 0x63, 0x61, 0x6e, 0x2c, 0x64, 0x61, 0x74, 0x61, 0x5f, + 0x73, 0x63, 0x61, 0x6e, 0x5f, 0x69, 0x64, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x3a, 0x3a, 0x09, 0x64, + 0x61, 0x74, 0x61, 0x5f, 0x73, 0x63, 0x61, 0x6e, 0x22, 0x2d, 0x2f, 0x76, 0x31, 0x2f, 0x7b, 0x70, + 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, + 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x64, 0x61, + 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x73, 0x12, 0xe5, 0x01, 0x0a, 0x0e, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x12, 0x2f, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, - 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x44, 0x61, 0x74, 0x61, + 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x6c, 0x6f, 0x6e, 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, 0x67, - 0x2e, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x22, 0x69, 0xca, 0x41, 0x2a, 0x0a, - 0x15, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, - 0x2e, 0x45, 0x6d, 0x70, 0x74, 0x79, 0x12, 0x11, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, - 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0xda, 0x41, 0x04, 0x6e, 0x61, 0x6d, 0x65, - 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x2f, 0x2a, 0x2d, 0x2f, 0x76, 0x31, 0x2f, 0x7b, 0x6e, 0x61, 0x6d, - 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, - 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, - 0x6e, 0x73, 0x2f, 0x2a, 0x7d, 0x12, 0x9d, 0x01, 0x0a, 0x0b, 0x47, 0x65, 0x74, 0x44, 0x61, 0x74, - 0x61, 0x53, 0x63, 0x61, 0x6e, 0x12, 0x2c, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, - 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, - 0x2e, 0x47, 0x65, 0x74, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x52, 0x65, 0x71, 0x75, - 0x65, 0x73, 0x74, 0x1a, 0x22, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, - 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, - 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x22, 0x3c, 0xda, 0x41, 0x04, 0x6e, 0x61, 0x6d, 0x65, - 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x2f, 0x12, 0x2d, 0x2f, 0x76, 0x31, 0x2f, 0x7b, 0x6e, 0x61, 0x6d, - 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, - 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, - 0x6e, 0x73, 0x2f, 0x2a, 0x7d, 0x12, 0xb0, 0x01, 0x0a, 0x0d, 0x4c, 0x69, 0x73, 0x74, 0x44, 0x61, - 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x73, 0x12, 0x2e, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, - 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, - 0x76, 0x31, 0x2e, 0x4c, 0x69, 0x73, 0x74, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x73, - 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x2f, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, - 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, - 0x76, 0x31, 0x2e, 0x4c, 0x69, 0x73, 0x74, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x73, - 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x3e, 0xda, 0x41, 0x06, 0x70, 0x61, 0x72, - 0x65, 0x6e, 0x74, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x2f, 0x12, 0x2d, 0x2f, 0x76, 0x31, 0x2f, 0x7b, - 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, - 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x64, - 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x73, 0x12, 0xaf, 0x01, 0x0a, 0x0b, 0x52, 0x75, 0x6e, - 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x12, 0x2c, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, - 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, - 0x2e, 0x76, 0x31, 0x2e, 0x52, 0x75, 0x6e, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x52, - 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x2d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, - 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, - 0x31, 0x2e, 0x52, 0x75, 0x6e, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x52, 0x65, 0x73, - 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x43, 0xda, 0x41, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x82, 0xd3, - 0xe4, 0x93, 0x02, 0x36, 0x3a, 0x01, 0x2a, 0x22, 0x31, 0x2f, 0x76, 0x31, 0x2f, 0x7b, 0x6e, 0x61, - 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, - 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x53, 0x63, - 0x61, 0x6e, 0x73, 0x2f, 0x2a, 0x7d, 0x3a, 0x72, 0x75, 0x6e, 0x12, 0xad, 0x01, 0x0a, 0x0e, 0x47, - 0x65, 0x74, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x12, 0x2f, 0x2e, + 0x2e, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x22, 0x82, 0x01, 0xca, 0x41, 0x1d, + 0x0a, 0x08, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x12, 0x11, 0x4f, 0x70, 0x65, 0x72, + 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0xda, 0x41, 0x15, + 0x64, 0x61, 0x74, 0x61, 0x5f, 0x73, 0x63, 0x61, 0x6e, 0x2c, 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, + 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x44, 0x3a, 0x09, 0x64, 0x61, 0x74, + 0x61, 0x5f, 0x73, 0x63, 0x61, 0x6e, 0x32, 0x37, 0x2f, 0x76, 0x31, 0x2f, 0x7b, 0x64, 0x61, 0x74, + 0x61, 0x5f, 0x73, 0x63, 0x61, 0x6e, 0x2e, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, + 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, + 0x2f, 0x2a, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x73, 0x2f, 0x2a, 0x7d, 0x12, + 0xcb, 0x01, 0x0a, 0x0e, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, + 0x61, 0x6e, 0x12, 0x2f, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, + 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x65, + 0x6c, 0x65, 0x74, 0x65, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x52, 0x65, 0x71, 0x75, + 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x6c, 0x6f, 0x6e, + 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, 0x67, 0x2e, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, + 0x6f, 0x6e, 0x22, 0x69, 0xca, 0x41, 0x2a, 0x0a, 0x15, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, + 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x45, 0x6d, 0x70, 0x74, 0x79, 0x12, 0x11, + 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, + 0x61, 0xda, 0x41, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x2f, 0x2a, 0x2d, + 0x2f, 0x76, 0x31, 0x2f, 0x7b, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, + 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, + 0x2f, 0x64, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x73, 0x2f, 0x2a, 0x7d, 0x12, 0x9d, 0x01, + 0x0a, 0x0b, 0x47, 0x65, 0x74, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x12, 0x2c, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x47, 0x65, 0x74, 0x44, 0x61, 0x74, 0x61, - 0x53, 0x63, 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x25, - 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, - 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, - 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x22, 0x43, 0xda, 0x41, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x82, 0xd3, - 0xe4, 0x93, 0x02, 0x36, 0x12, 0x34, 0x2f, 0x76, 0x31, 0x2f, 0x7b, 0x6e, 0x61, 0x6d, 0x65, 0x3d, - 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, - 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x73, - 0x2f, 0x2a, 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x2f, 0x2a, 0x7d, 0x12, 0xc0, 0x01, 0x0a, 0x10, 0x4c, - 0x69, 0x73, 0x74, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x73, 0x12, - 0x31, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, + 0x53, 0x63, 0x61, 0x6e, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x22, 0x2e, 0x67, 0x6f, + 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, + 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x22, + 0x3c, 0xda, 0x41, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x2f, 0x12, 0x2d, + 0x2f, 0x76, 0x31, 0x2f, 0x7b, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, + 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, + 0x2f, 0x64, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x73, 0x2f, 0x2a, 0x7d, 0x12, 0xb0, 0x01, + 0x0a, 0x0d, 0x4c, 0x69, 0x73, 0x74, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x73, 0x12, + 0x2e, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x4c, 0x69, 0x73, 0x74, 0x44, - 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, - 0x73, 0x74, 0x1a, 0x32, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, - 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x4c, 0x69, - 0x73, 0x74, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, - 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x45, 0xda, 0x41, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, - 0x74, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x36, 0x12, 0x34, 0x2f, 0x76, 0x31, 0x2f, 0x7b, 0x70, 0x61, - 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, - 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x64, 0x61, 0x74, 0x61, - 0x53, 0x63, 0x61, 0x6e, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x12, 0xc1, 0x02, - 0x0a, 0x18, 0x47, 0x65, 0x6e, 0x65, 0x72, 0x61, 0x74, 0x65, 0x44, 0x61, 0x74, 0x61, 0x51, 0x75, - 0x61, 0x6c, 0x69, 0x74, 0x79, 0x52, 0x75, 0x6c, 0x65, 0x73, 0x12, 0x39, 0x2e, 0x67, 0x6f, 0x6f, - 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, - 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x47, 0x65, 0x6e, 0x65, 0x72, 0x61, 0x74, 0x65, 0x44, 0x61, - 0x74, 0x61, 0x51, 0x75, 0x61, 0x6c, 0x69, 0x74, 0x79, 0x52, 0x75, 0x6c, 0x65, 0x73, 0x52, 0x65, - 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x3a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, + 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, + 0x2f, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, + 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x4c, 0x69, 0x73, 0x74, 0x44, + 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x73, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, + 0x22, 0x3e, 0xda, 0x41, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x82, 0xd3, 0xe4, 0x93, 0x02, + 0x2f, 0x12, 0x2d, 0x2f, 0x76, 0x31, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x70, + 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, + 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x73, + 0x12, 0xaf, 0x01, 0x0a, 0x0b, 0x52, 0x75, 0x6e, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, + 0x12, 0x2c, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, + 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x52, 0x75, 0x6e, 0x44, + 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x2d, + 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, + 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x52, 0x75, 0x6e, 0x44, 0x61, 0x74, + 0x61, 0x53, 0x63, 0x61, 0x6e, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x43, 0xda, + 0x41, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x36, 0x3a, 0x01, 0x2a, 0x22, + 0x31, 0x2f, 0x76, 0x31, 0x2f, 0x7b, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, + 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, + 0x2a, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x73, 0x2f, 0x2a, 0x7d, 0x3a, 0x72, + 0x75, 0x6e, 0x12, 0xad, 0x01, 0x0a, 0x0e, 0x47, 0x65, 0x74, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, + 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x12, 0x2f, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, - 0x2e, 0x47, 0x65, 0x6e, 0x65, 0x72, 0x61, 0x74, 0x65, 0x44, 0x61, 0x74, 0x61, 0x51, 0x75, 0x61, - 0x6c, 0x69, 0x74, 0x79, 0x52, 0x75, 0x6c, 0x65, 0x73, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, - 0x65, 0x22, 0xad, 0x01, 0xda, 0x41, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x82, 0xd3, 0xe4, 0x93, 0x02, - 0x9f, 0x01, 0x3a, 0x01, 0x2a, 0x5a, 0x52, 0x3a, 0x01, 0x2a, 0x22, 0x4d, 0x2f, 0x76, 0x31, 0x2f, - 0x7b, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, - 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x64, 0x61, 0x74, - 0x61, 0x53, 0x63, 0x61, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x2f, 0x2a, 0x7d, - 0x3a, 0x67, 0x65, 0x6e, 0x65, 0x72, 0x61, 0x74, 0x65, 0x44, 0x61, 0x74, 0x61, 0x51, 0x75, 0x61, - 0x6c, 0x69, 0x74, 0x79, 0x52, 0x75, 0x6c, 0x65, 0x73, 0x22, 0x46, 0x2f, 0x76, 0x31, 0x2f, 0x7b, - 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, - 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x64, 0x61, 0x74, 0x61, - 0x53, 0x63, 0x61, 0x6e, 0x73, 0x2f, 0x2a, 0x7d, 0x3a, 0x67, 0x65, 0x6e, 0x65, 0x72, 0x61, 0x74, + 0x2e, 0x47, 0x65, 0x74, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x52, + 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x25, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, + 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, + 0x31, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x22, 0x43, 0xda, + 0x41, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x36, 0x12, 0x34, 0x2f, 0x76, + 0x31, 0x2f, 0x7b, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, + 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x64, + 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x2f, + 0x2a, 0x7d, 0x12, 0xc0, 0x01, 0x0a, 0x10, 0x4c, 0x69, 0x73, 0x74, 0x44, 0x61, 0x74, 0x61, 0x53, + 0x63, 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x73, 0x12, 0x31, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, + 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, + 0x76, 0x31, 0x2e, 0x4c, 0x69, 0x73, 0x74, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x4a, + 0x6f, 0x62, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x32, 0x2e, 0x67, 0x6f, 0x6f, + 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, + 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x4c, 0x69, 0x73, 0x74, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, + 0x61, 0x6e, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x45, + 0xda, 0x41, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x36, 0x12, + 0x34, 0x2f, 0x76, 0x31, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, + 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, + 0x73, 0x2f, 0x2a, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x73, 0x2f, 0x2a, 0x7d, + 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x12, 0xc1, 0x02, 0x0a, 0x18, 0x47, 0x65, 0x6e, 0x65, 0x72, 0x61, + 0x74, 0x65, 0x44, 0x61, 0x74, 0x61, 0x51, 0x75, 0x61, 0x6c, 0x69, 0x74, 0x79, 0x52, 0x75, 0x6c, + 0x65, 0x73, 0x12, 0x39, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, + 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x47, 0x65, + 0x6e, 0x65, 0x72, 0x61, 0x74, 0x65, 0x44, 0x61, 0x74, 0x61, 0x51, 0x75, 0x61, 0x6c, 0x69, 0x74, + 0x79, 0x52, 0x75, 0x6c, 0x65, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x3a, 0x2e, + 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, + 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x2e, 0x47, 0x65, 0x6e, 0x65, 0x72, 0x61, 0x74, + 0x65, 0x44, 0x61, 0x74, 0x61, 0x51, 0x75, 0x61, 0x6c, 0x69, 0x74, 0x79, 0x52, 0x75, 0x6c, 0x65, + 0x73, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0xad, 0x01, 0xda, 0x41, 0x04, 0x6e, + 0x61, 0x6d, 0x65, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x9f, 0x01, 0x3a, 0x01, 0x2a, 0x5a, 0x52, 0x3a, + 0x01, 0x2a, 0x22, 0x4d, 0x2f, 0x76, 0x31, 0x2f, 0x7b, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, + 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, + 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x73, 0x2f, 0x2a, + 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x2f, 0x2a, 0x7d, 0x3a, 0x67, 0x65, 0x6e, 0x65, 0x72, 0x61, 0x74, 0x65, 0x44, 0x61, 0x74, 0x61, 0x51, 0x75, 0x61, 0x6c, 0x69, 0x74, 0x79, 0x52, 0x75, 0x6c, 0x65, - 0x73, 0x1a, 0x4b, 0xca, 0x41, 0x17, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x67, - 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0xd2, 0x41, 0x2e, - 0x68, 0x74, 0x74, 0x70, 0x73, 0x3a, 0x2f, 0x2f, 0x77, 0x77, 0x77, 0x2e, 0x67, 0x6f, 0x6f, 0x67, - 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x61, 0x75, 0x74, 0x68, 0x2f, - 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2d, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x42, 0x6a, - 0x0a, 0x1c, 0x63, 0x6f, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, - 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x42, 0x0e, - 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x73, 0x50, 0x72, 0x6f, 0x74, 0x6f, 0x50, 0x01, - 0x5a, 0x38, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, - 0x6f, 0x6d, 0x2f, 0x67, 0x6f, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2f, 0x61, - 0x70, 0x69, 0x76, 0x31, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x70, 0x62, 0x3b, - 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x70, 0x62, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, - 0x6f, 0x33, + 0x73, 0x22, 0x46, 0x2f, 0x76, 0x31, 0x2f, 0x7b, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, + 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, + 0x73, 0x2f, 0x2a, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, 0x73, 0x2f, 0x2a, 0x7d, + 0x3a, 0x67, 0x65, 0x6e, 0x65, 0x72, 0x61, 0x74, 0x65, 0x44, 0x61, 0x74, 0x61, 0x51, 0x75, 0x61, + 0x6c, 0x69, 0x74, 0x79, 0x52, 0x75, 0x6c, 0x65, 0x73, 0x1a, 0x4b, 0xca, 0x41, 0x17, 0x64, 0x61, + 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, + 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0xd2, 0x41, 0x2e, 0x68, 0x74, 0x74, 0x70, 0x73, 0x3a, 0x2f, 0x2f, + 0x77, 0x77, 0x77, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, + 0x6f, 0x6d, 0x2f, 0x61, 0x75, 0x74, 0x68, 0x2f, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2d, 0x70, 0x6c, + 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x42, 0x6a, 0x0a, 0x1c, 0x63, 0x6f, 0x6d, 0x2e, 0x67, 0x6f, + 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x70, + 0x6c, 0x65, 0x78, 0x2e, 0x76, 0x31, 0x42, 0x0e, 0x44, 0x61, 0x74, 0x61, 0x53, 0x63, 0x61, 0x6e, + 0x73, 0x50, 0x72, 0x6f, 0x74, 0x6f, 0x50, 0x01, 0x5a, 0x38, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, + 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x67, 0x6f, 0x2f, 0x64, 0x61, + 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, 0x2f, 0x61, 0x70, 0x69, 0x76, 0x31, 0x2f, 0x64, 0x61, 0x74, + 0x61, 0x70, 0x6c, 0x65, 0x78, 0x70, 0x62, 0x3b, 0x64, 0x61, 0x74, 0x61, 0x70, 0x6c, 0x65, 0x78, + 0x70, 0x62, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, } var ( diff --git a/gkemulticloud/apiv1/gkemulticloudpb/attached_resources.pb.go b/gkemulticloud/apiv1/gkemulticloudpb/attached_resources.pb.go index 579cf21b405f..488da2b57c8e 100755 --- a/gkemulticloud/apiv1/gkemulticloudpb/attached_resources.pb.go +++ b/gkemulticloud/apiv1/gkemulticloudpb/attached_resources.pb.go @@ -190,6 +190,19 @@ type AttachedCluster struct { BinaryAuthorization *BinaryAuthorization `protobuf:"bytes,25,opt,name=binary_authorization,json=binaryAuthorization,proto3" json:"binary_authorization,omitempty"` // Optional. Security Posture configuration for this cluster. SecurityPostureConfig *SecurityPostureConfig `protobuf:"bytes,26,opt,name=security_posture_config,json=securityPostureConfig,proto3" json:"security_posture_config,omitempty"` + // Optional. Input only. Tag keys/values directly bound to this resource. + // + // Tag key must be specified in the format / + // where the tag namespace is the ID of the organization or name of the + // project that the tag key is defined in. + // The short name of a tag key or value can have a maximum length of 256 + // characters. The permitted character set for the short name includes UTF-8 + // encoded Unicode characters except single quotes ('), double quotes ("), + // backslashes (\), and forward slashes (/). + // + // See [Tags](http://cloud/resource-manager/docs/tags/tags-overview) + // for more details on Google Cloud Platform tags. + Tags map[string]string `protobuf:"bytes,27,rep,name=tags,proto3" json:"tags,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` } func (x *AttachedCluster) Reset() { @@ -383,6 +396,13 @@ func (x *AttachedCluster) GetSecurityPostureConfig() *SecurityPostureConfig { return nil } +func (x *AttachedCluster) GetTags() map[string]string { + if x != nil { + return x.Tags + } + return nil +} + // Configuration related to the cluster RBAC settings. type AttachedClustersAuthorization struct { state protoimpl.MessageState @@ -775,6 +795,10 @@ type AttachedProxyConfig struct { // The Kubernetes Secret resource that contains the HTTP(S) proxy // configuration. The secret must be a JSON encoded proxy configuration // as described in + // https://cloud.google.com/kubernetes-engine/multi-cloud/docs/attached/eks/how-to/use-a-proxy#configure-proxy-support + // for EKS clusters and + // https://cloud.google.com/kubernetes-engine/multi-cloud/docs/attached/aks/how-to/use-a-proxy#configure-proxy-support + // for AKS clusters. KubernetesSecret *KubernetesSecret `protobuf:"bytes,1,opt,name=kubernetes_secret,json=kubernetesSecret,proto3" json:"kubernetes_secret,omitempty"` } @@ -888,7 +912,7 @@ var file_google_cloud_gkemulticloud_v1_attached_resources_proto_rawDesc = []byte 0x76, 0x31, 0x2f, 0x63, 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, 0x5f, 0x72, 0x65, 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, 0x73, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x1f, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2f, 0x74, 0x69, 0x6d, 0x65, 0x73, - 0x74, 0x61, 0x6d, 0x70, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x22, 0x8e, 0x0f, 0x0a, 0x0f, 0x41, + 0x74, 0x61, 0x6d, 0x70, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x22, 0x9d, 0x10, 0x0a, 0x0f, 0x41, 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x43, 0x6c, 0x75, 0x73, 0x74, 0x65, 0x72, 0x12, 0x12, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x25, 0x0a, 0x0b, 0x64, 0x65, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x69, 0x6f, @@ -990,101 +1014,110 @@ var file_google_cloud_gkemulticloud_v1_attached_resources_proto_rawDesc = []byte 0x76, 0x31, 0x2e, 0x53, 0x65, 0x63, 0x75, 0x72, 0x69, 0x74, 0x79, 0x50, 0x6f, 0x73, 0x74, 0x75, 0x72, 0x65, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x15, 0x73, 0x65, 0x63, 0x75, 0x72, 0x69, 0x74, 0x79, 0x50, 0x6f, 0x73, 0x74, 0x75, 0x72, 0x65, 0x43, 0x6f, - 0x6e, 0x66, 0x69, 0x67, 0x1a, 0x3e, 0x0a, 0x10, 0x41, 0x6e, 0x6e, 0x6f, 0x74, 0x61, 0x74, 0x69, - 0x6f, 0x6e, 0x73, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, 0x03, 0x6b, 0x65, 0x79, 0x18, - 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x14, 0x0a, 0x05, 0x76, 0x61, - 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, - 0x3a, 0x02, 0x38, 0x01, 0x22, 0x75, 0x0a, 0x05, 0x53, 0x74, 0x61, 0x74, 0x65, 0x12, 0x15, 0x0a, - 0x11, 0x53, 0x54, 0x41, 0x54, 0x45, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, - 0x45, 0x44, 0x10, 0x00, 0x12, 0x10, 0x0a, 0x0c, 0x50, 0x52, 0x4f, 0x56, 0x49, 0x53, 0x49, 0x4f, - 0x4e, 0x49, 0x4e, 0x47, 0x10, 0x01, 0x12, 0x0b, 0x0a, 0x07, 0x52, 0x55, 0x4e, 0x4e, 0x49, 0x4e, - 0x47, 0x10, 0x02, 0x12, 0x0f, 0x0a, 0x0b, 0x52, 0x45, 0x43, 0x4f, 0x4e, 0x43, 0x49, 0x4c, 0x49, - 0x4e, 0x47, 0x10, 0x03, 0x12, 0x0c, 0x0a, 0x08, 0x53, 0x54, 0x4f, 0x50, 0x50, 0x49, 0x4e, 0x47, - 0x10, 0x04, 0x12, 0x09, 0x0a, 0x05, 0x45, 0x52, 0x52, 0x4f, 0x52, 0x10, 0x05, 0x12, 0x0c, 0x0a, - 0x08, 0x44, 0x45, 0x47, 0x52, 0x41, 0x44, 0x45, 0x44, 0x10, 0x06, 0x3a, 0x7e, 0xea, 0x41, 0x7b, - 0x0a, 0x2c, 0x67, 0x6b, 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, - 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x41, - 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x43, 0x6c, 0x75, 0x73, 0x74, 0x65, 0x72, 0x12, 0x4b, - 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x7b, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, - 0x74, 0x7d, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x7b, 0x6c, 0x6f, - 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x7d, 0x2f, 0x61, 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, - 0x43, 0x6c, 0x75, 0x73, 0x74, 0x65, 0x72, 0x73, 0x2f, 0x7b, 0x61, 0x74, 0x74, 0x61, 0x63, 0x68, - 0x65, 0x64, 0x5f, 0x63, 0x6c, 0x75, 0x73, 0x74, 0x65, 0x72, 0x7d, 0x22, 0xd6, 0x01, 0x0a, 0x1d, - 0x41, 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x43, 0x6c, 0x75, 0x73, 0x74, 0x65, 0x72, 0x73, - 0x41, 0x75, 0x74, 0x68, 0x6f, 0x72, 0x69, 0x7a, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x12, 0x58, 0x0a, - 0x0b, 0x61, 0x64, 0x6d, 0x69, 0x6e, 0x5f, 0x75, 0x73, 0x65, 0x72, 0x73, 0x18, 0x01, 0x20, 0x03, - 0x28, 0x0b, 0x32, 0x32, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, + 0x6e, 0x66, 0x69, 0x67, 0x12, 0x54, 0x0a, 0x04, 0x74, 0x61, 0x67, 0x73, 0x18, 0x1b, 0x20, 0x03, + 0x28, 0x0b, 0x32, 0x38, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x67, 0x6b, 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x76, 0x31, 0x2e, 0x41, 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x43, 0x6c, 0x75, 0x73, 0x74, - 0x65, 0x72, 0x55, 0x73, 0x65, 0x72, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0a, 0x61, 0x64, 0x6d, - 0x69, 0x6e, 0x55, 0x73, 0x65, 0x72, 0x73, 0x12, 0x5b, 0x0a, 0x0c, 0x61, 0x64, 0x6d, 0x69, 0x6e, - 0x5f, 0x67, 0x72, 0x6f, 0x75, 0x70, 0x73, 0x18, 0x02, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x33, 0x2e, - 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x67, 0x6b, 0x65, - 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x76, 0x31, 0x2e, 0x41, 0x74, - 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x43, 0x6c, 0x75, 0x73, 0x74, 0x65, 0x72, 0x47, 0x72, 0x6f, - 0x75, 0x70, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0b, 0x61, 0x64, 0x6d, 0x69, 0x6e, 0x47, 0x72, - 0x6f, 0x75, 0x70, 0x73, 0x22, 0x36, 0x0a, 0x13, 0x41, 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, - 0x43, 0x6c, 0x75, 0x73, 0x74, 0x65, 0x72, 0x55, 0x73, 0x65, 0x72, 0x12, 0x1f, 0x0a, 0x08, 0x75, - 0x73, 0x65, 0x72, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, - 0x41, 0x02, 0x52, 0x08, 0x75, 0x73, 0x65, 0x72, 0x6e, 0x61, 0x6d, 0x65, 0x22, 0x31, 0x0a, 0x14, - 0x41, 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x43, 0x6c, 0x75, 0x73, 0x74, 0x65, 0x72, 0x47, - 0x72, 0x6f, 0x75, 0x70, 0x12, 0x19, 0x0a, 0x05, 0x67, 0x72, 0x6f, 0x75, 0x70, 0x18, 0x01, 0x20, - 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x05, 0x67, 0x72, 0x6f, 0x75, 0x70, 0x22, - 0x4c, 0x0a, 0x12, 0x41, 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x4f, 0x69, 0x64, 0x63, 0x43, - 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x1d, 0x0a, 0x0a, 0x69, 0x73, 0x73, 0x75, 0x65, 0x72, 0x5f, - 0x75, 0x72, 0x6c, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x09, 0x69, 0x73, 0x73, 0x75, 0x65, - 0x72, 0x55, 0x72, 0x6c, 0x12, 0x17, 0x0a, 0x04, 0x6a, 0x77, 0x6b, 0x73, 0x18, 0x02, 0x20, 0x01, - 0x28, 0x0c, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x04, 0x6a, 0x77, 0x6b, 0x73, 0x22, 0x83, 0x02, - 0x0a, 0x14, 0x41, 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x53, 0x65, 0x72, 0x76, 0x65, 0x72, - 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x12, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, - 0x20, 0x01, 0x28, 0x09, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x61, 0x0a, 0x0e, 0x76, 0x61, - 0x6c, 0x69, 0x64, 0x5f, 0x76, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x73, 0x18, 0x02, 0x20, 0x03, - 0x28, 0x0b, 0x32, 0x3a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, - 0x64, 0x2e, 0x67, 0x6b, 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, - 0x76, 0x31, 0x2e, 0x41, 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x50, 0x6c, 0x61, 0x74, 0x66, - 0x6f, 0x72, 0x6d, 0x56, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x49, 0x6e, 0x66, 0x6f, 0x52, 0x0d, - 0x76, 0x61, 0x6c, 0x69, 0x64, 0x56, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x73, 0x3a, 0x74, 0xea, - 0x41, 0x71, 0x0a, 0x31, 0x67, 0x6b, 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, - 0x64, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, - 0x2f, 0x41, 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x53, 0x65, 0x72, 0x76, 0x65, 0x72, 0x43, - 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x3c, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, - 0x7b, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x7d, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, - 0x6f, 0x6e, 0x73, 0x2f, 0x7b, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x7d, 0x2f, 0x61, - 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x53, 0x65, 0x72, 0x76, 0x65, 0x72, 0x43, 0x6f, 0x6e, - 0x66, 0x69, 0x67, 0x22, 0x37, 0x0a, 0x1b, 0x41, 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x50, - 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x56, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x49, 0x6e, - 0x66, 0x6f, 0x12, 0x18, 0x0a, 0x07, 0x76, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x18, 0x01, 0x20, - 0x01, 0x28, 0x09, 0x52, 0x07, 0x76, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x22, 0x30, 0x0a, 0x14, - 0x41, 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x43, 0x6c, 0x75, 0x73, 0x74, 0x65, 0x72, 0x45, - 0x72, 0x72, 0x6f, 0x72, 0x12, 0x18, 0x0a, 0x07, 0x6d, 0x65, 0x73, 0x73, 0x61, 0x67, 0x65, 0x18, - 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x07, 0x6d, 0x65, 0x73, 0x73, 0x61, 0x67, 0x65, 0x22, 0x73, - 0x0a, 0x13, 0x41, 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x50, 0x72, 0x6f, 0x78, 0x79, 0x43, - 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x5c, 0x0a, 0x11, 0x6b, 0x75, 0x62, 0x65, 0x72, 0x6e, 0x65, - 0x74, 0x65, 0x73, 0x5f, 0x73, 0x65, 0x63, 0x72, 0x65, 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, - 0x32, 0x2f, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, - 0x67, 0x6b, 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x76, 0x31, - 0x2e, 0x4b, 0x75, 0x62, 0x65, 0x72, 0x6e, 0x65, 0x74, 0x65, 0x73, 0x53, 0x65, 0x63, 0x72, 0x65, - 0x74, 0x52, 0x10, 0x6b, 0x75, 0x62, 0x65, 0x72, 0x6e, 0x65, 0x74, 0x65, 0x73, 0x53, 0x65, 0x63, - 0x72, 0x65, 0x74, 0x22, 0x44, 0x0a, 0x10, 0x4b, 0x75, 0x62, 0x65, 0x72, 0x6e, 0x65, 0x74, 0x65, - 0x73, 0x53, 0x65, 0x63, 0x72, 0x65, 0x74, 0x12, 0x12, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, - 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x1c, 0x0a, 0x09, 0x6e, - 0x61, 0x6d, 0x65, 0x73, 0x70, 0x61, 0x63, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x09, - 0x6e, 0x61, 0x6d, 0x65, 0x73, 0x70, 0x61, 0x63, 0x65, 0x42, 0xe9, 0x01, 0x0a, 0x21, 0x63, 0x6f, - 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x67, - 0x6b, 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x76, 0x31, 0x42, - 0x16, 0x41, 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x52, 0x65, 0x73, 0x6f, 0x75, 0x72, 0x63, - 0x65, 0x73, 0x50, 0x72, 0x6f, 0x74, 0x6f, 0x50, 0x01, 0x5a, 0x47, 0x63, 0x6c, 0x6f, 0x75, 0x64, - 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x67, 0x6f, 0x2f, 0x67, - 0x6b, 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2f, 0x61, 0x70, 0x69, - 0x76, 0x31, 0x2f, 0x67, 0x6b, 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, 0x64, - 0x70, 0x62, 0x3b, 0x67, 0x6b, 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, 0x64, - 0x70, 0x62, 0xaa, 0x02, 0x1d, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x43, 0x6c, 0x6f, 0x75, - 0x64, 0x2e, 0x47, 0x6b, 0x65, 0x4d, 0x75, 0x6c, 0x74, 0x69, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x2e, - 0x56, 0x31, 0xca, 0x02, 0x1d, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x5c, 0x43, 0x6c, 0x6f, 0x75, - 0x64, 0x5c, 0x47, 0x6b, 0x65, 0x4d, 0x75, 0x6c, 0x74, 0x69, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x5c, - 0x56, 0x31, 0xea, 0x02, 0x20, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x3a, 0x3a, 0x43, 0x6c, 0x6f, - 0x75, 0x64, 0x3a, 0x3a, 0x47, 0x6b, 0x65, 0x4d, 0x75, 0x6c, 0x74, 0x69, 0x43, 0x6c, 0x6f, 0x75, - 0x64, 0x3a, 0x3a, 0x56, 0x31, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, + 0x65, 0x72, 0x2e, 0x54, 0x61, 0x67, 0x73, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x42, 0x06, 0xe0, 0x41, + 0x01, 0xe0, 0x41, 0x04, 0x52, 0x04, 0x74, 0x61, 0x67, 0x73, 0x1a, 0x3e, 0x0a, 0x10, 0x41, 0x6e, + 0x6e, 0x6f, 0x74, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, + 0x0a, 0x03, 0x6b, 0x65, 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, + 0x12, 0x14, 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, + 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x3a, 0x02, 0x38, 0x01, 0x1a, 0x37, 0x0a, 0x09, 0x54, 0x61, + 0x67, 0x73, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, 0x03, 0x6b, 0x65, 0x79, 0x18, 0x01, + 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x14, 0x0a, 0x05, 0x76, 0x61, 0x6c, + 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x3a, + 0x02, 0x38, 0x01, 0x22, 0x75, 0x0a, 0x05, 0x53, 0x74, 0x61, 0x74, 0x65, 0x12, 0x15, 0x0a, 0x11, + 0x53, 0x54, 0x41, 0x54, 0x45, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, + 0x44, 0x10, 0x00, 0x12, 0x10, 0x0a, 0x0c, 0x50, 0x52, 0x4f, 0x56, 0x49, 0x53, 0x49, 0x4f, 0x4e, + 0x49, 0x4e, 0x47, 0x10, 0x01, 0x12, 0x0b, 0x0a, 0x07, 0x52, 0x55, 0x4e, 0x4e, 0x49, 0x4e, 0x47, + 0x10, 0x02, 0x12, 0x0f, 0x0a, 0x0b, 0x52, 0x45, 0x43, 0x4f, 0x4e, 0x43, 0x49, 0x4c, 0x49, 0x4e, + 0x47, 0x10, 0x03, 0x12, 0x0c, 0x0a, 0x08, 0x53, 0x54, 0x4f, 0x50, 0x50, 0x49, 0x4e, 0x47, 0x10, + 0x04, 0x12, 0x09, 0x0a, 0x05, 0x45, 0x52, 0x52, 0x4f, 0x52, 0x10, 0x05, 0x12, 0x0c, 0x0a, 0x08, + 0x44, 0x45, 0x47, 0x52, 0x41, 0x44, 0x45, 0x44, 0x10, 0x06, 0x3a, 0x7e, 0xea, 0x41, 0x7b, 0x0a, + 0x2c, 0x67, 0x6b, 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x67, + 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x41, 0x74, + 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x43, 0x6c, 0x75, 0x73, 0x74, 0x65, 0x72, 0x12, 0x4b, 0x70, + 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x7b, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, + 0x7d, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x7b, 0x6c, 0x6f, 0x63, + 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x7d, 0x2f, 0x61, 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x43, + 0x6c, 0x75, 0x73, 0x74, 0x65, 0x72, 0x73, 0x2f, 0x7b, 0x61, 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, + 0x64, 0x5f, 0x63, 0x6c, 0x75, 0x73, 0x74, 0x65, 0x72, 0x7d, 0x22, 0xd6, 0x01, 0x0a, 0x1d, 0x41, + 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x43, 0x6c, 0x75, 0x73, 0x74, 0x65, 0x72, 0x73, 0x41, + 0x75, 0x74, 0x68, 0x6f, 0x72, 0x69, 0x7a, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x12, 0x58, 0x0a, 0x0b, + 0x61, 0x64, 0x6d, 0x69, 0x6e, 0x5f, 0x75, 0x73, 0x65, 0x72, 0x73, 0x18, 0x01, 0x20, 0x03, 0x28, + 0x0b, 0x32, 0x32, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, + 0x2e, 0x67, 0x6b, 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x76, + 0x31, 0x2e, 0x41, 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x43, 0x6c, 0x75, 0x73, 0x74, 0x65, + 0x72, 0x55, 0x73, 0x65, 0x72, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0a, 0x61, 0x64, 0x6d, 0x69, + 0x6e, 0x55, 0x73, 0x65, 0x72, 0x73, 0x12, 0x5b, 0x0a, 0x0c, 0x61, 0x64, 0x6d, 0x69, 0x6e, 0x5f, + 0x67, 0x72, 0x6f, 0x75, 0x70, 0x73, 0x18, 0x02, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x33, 0x2e, 0x67, + 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x67, 0x6b, 0x65, 0x6d, + 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x76, 0x31, 0x2e, 0x41, 0x74, 0x74, + 0x61, 0x63, 0x68, 0x65, 0x64, 0x43, 0x6c, 0x75, 0x73, 0x74, 0x65, 0x72, 0x47, 0x72, 0x6f, 0x75, + 0x70, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0b, 0x61, 0x64, 0x6d, 0x69, 0x6e, 0x47, 0x72, 0x6f, + 0x75, 0x70, 0x73, 0x22, 0x36, 0x0a, 0x13, 0x41, 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x43, + 0x6c, 0x75, 0x73, 0x74, 0x65, 0x72, 0x55, 0x73, 0x65, 0x72, 0x12, 0x1f, 0x0a, 0x08, 0x75, 0x73, + 0x65, 0x72, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, + 0x02, 0x52, 0x08, 0x75, 0x73, 0x65, 0x72, 0x6e, 0x61, 0x6d, 0x65, 0x22, 0x31, 0x0a, 0x14, 0x41, + 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x43, 0x6c, 0x75, 0x73, 0x74, 0x65, 0x72, 0x47, 0x72, + 0x6f, 0x75, 0x70, 0x12, 0x19, 0x0a, 0x05, 0x67, 0x72, 0x6f, 0x75, 0x70, 0x18, 0x01, 0x20, 0x01, + 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x05, 0x67, 0x72, 0x6f, 0x75, 0x70, 0x22, 0x4c, + 0x0a, 0x12, 0x41, 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x4f, 0x69, 0x64, 0x63, 0x43, 0x6f, + 0x6e, 0x66, 0x69, 0x67, 0x12, 0x1d, 0x0a, 0x0a, 0x69, 0x73, 0x73, 0x75, 0x65, 0x72, 0x5f, 0x75, + 0x72, 0x6c, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x09, 0x69, 0x73, 0x73, 0x75, 0x65, 0x72, + 0x55, 0x72, 0x6c, 0x12, 0x17, 0x0a, 0x04, 0x6a, 0x77, 0x6b, 0x73, 0x18, 0x02, 0x20, 0x01, 0x28, + 0x0c, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x04, 0x6a, 0x77, 0x6b, 0x73, 0x22, 0x83, 0x02, 0x0a, + 0x14, 0x41, 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x53, 0x65, 0x72, 0x76, 0x65, 0x72, 0x43, + 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x12, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, + 0x01, 0x28, 0x09, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x61, 0x0a, 0x0e, 0x76, 0x61, 0x6c, + 0x69, 0x64, 0x5f, 0x76, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x73, 0x18, 0x02, 0x20, 0x03, 0x28, + 0x0b, 0x32, 0x3a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, + 0x2e, 0x67, 0x6b, 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x76, + 0x31, 0x2e, 0x41, 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x50, 0x6c, 0x61, 0x74, 0x66, 0x6f, + 0x72, 0x6d, 0x56, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x49, 0x6e, 0x66, 0x6f, 0x52, 0x0d, 0x76, + 0x61, 0x6c, 0x69, 0x64, 0x56, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x73, 0x3a, 0x74, 0xea, 0x41, + 0x71, 0x0a, 0x31, 0x67, 0x6b, 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, 0x64, + 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, + 0x41, 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x53, 0x65, 0x72, 0x76, 0x65, 0x72, 0x43, 0x6f, + 0x6e, 0x66, 0x69, 0x67, 0x12, 0x3c, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x7b, + 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x7d, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, + 0x6e, 0x73, 0x2f, 0x7b, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x7d, 0x2f, 0x61, 0x74, + 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x53, 0x65, 0x72, 0x76, 0x65, 0x72, 0x43, 0x6f, 0x6e, 0x66, + 0x69, 0x67, 0x22, 0x37, 0x0a, 0x1b, 0x41, 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x50, 0x6c, + 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x56, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x49, 0x6e, 0x66, + 0x6f, 0x12, 0x18, 0x0a, 0x07, 0x76, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x18, 0x01, 0x20, 0x01, + 0x28, 0x09, 0x52, 0x07, 0x76, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x22, 0x30, 0x0a, 0x14, 0x41, + 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x43, 0x6c, 0x75, 0x73, 0x74, 0x65, 0x72, 0x45, 0x72, + 0x72, 0x6f, 0x72, 0x12, 0x18, 0x0a, 0x07, 0x6d, 0x65, 0x73, 0x73, 0x61, 0x67, 0x65, 0x18, 0x01, + 0x20, 0x01, 0x28, 0x09, 0x52, 0x07, 0x6d, 0x65, 0x73, 0x73, 0x61, 0x67, 0x65, 0x22, 0x73, 0x0a, + 0x13, 0x41, 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x50, 0x72, 0x6f, 0x78, 0x79, 0x43, 0x6f, + 0x6e, 0x66, 0x69, 0x67, 0x12, 0x5c, 0x0a, 0x11, 0x6b, 0x75, 0x62, 0x65, 0x72, 0x6e, 0x65, 0x74, + 0x65, 0x73, 0x5f, 0x73, 0x65, 0x63, 0x72, 0x65, 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, + 0x2f, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x67, + 0x6b, 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x76, 0x31, 0x2e, + 0x4b, 0x75, 0x62, 0x65, 0x72, 0x6e, 0x65, 0x74, 0x65, 0x73, 0x53, 0x65, 0x63, 0x72, 0x65, 0x74, + 0x52, 0x10, 0x6b, 0x75, 0x62, 0x65, 0x72, 0x6e, 0x65, 0x74, 0x65, 0x73, 0x53, 0x65, 0x63, 0x72, + 0x65, 0x74, 0x22, 0x44, 0x0a, 0x10, 0x4b, 0x75, 0x62, 0x65, 0x72, 0x6e, 0x65, 0x74, 0x65, 0x73, + 0x53, 0x65, 0x63, 0x72, 0x65, 0x74, 0x12, 0x12, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, + 0x20, 0x01, 0x28, 0x09, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x1c, 0x0a, 0x09, 0x6e, 0x61, + 0x6d, 0x65, 0x73, 0x70, 0x61, 0x63, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x09, 0x6e, + 0x61, 0x6d, 0x65, 0x73, 0x70, 0x61, 0x63, 0x65, 0x42, 0xe9, 0x01, 0x0a, 0x21, 0x63, 0x6f, 0x6d, + 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x67, 0x6b, + 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x76, 0x31, 0x42, 0x16, + 0x41, 0x74, 0x74, 0x61, 0x63, 0x68, 0x65, 0x64, 0x52, 0x65, 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, + 0x73, 0x50, 0x72, 0x6f, 0x74, 0x6f, 0x50, 0x01, 0x5a, 0x47, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, + 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x67, 0x6f, 0x2f, 0x67, 0x6b, + 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2f, 0x61, 0x70, 0x69, 0x76, + 0x31, 0x2f, 0x67, 0x6b, 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x70, + 0x62, 0x3b, 0x67, 0x6b, 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x70, + 0x62, 0xaa, 0x02, 0x1d, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x43, 0x6c, 0x6f, 0x75, 0x64, + 0x2e, 0x47, 0x6b, 0x65, 0x4d, 0x75, 0x6c, 0x74, 0x69, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x56, + 0x31, 0xca, 0x02, 0x1d, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x5c, 0x43, 0x6c, 0x6f, 0x75, 0x64, + 0x5c, 0x47, 0x6b, 0x65, 0x4d, 0x75, 0x6c, 0x74, 0x69, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x5c, 0x56, + 0x31, 0xea, 0x02, 0x20, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x3a, 0x3a, 0x43, 0x6c, 0x6f, 0x75, + 0x64, 0x3a, 0x3a, 0x47, 0x6b, 0x65, 0x4d, 0x75, 0x6c, 0x74, 0x69, 0x43, 0x6c, 0x6f, 0x75, 0x64, + 0x3a, 0x3a, 0x56, 0x31, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, } var ( @@ -1100,7 +1133,7 @@ func file_google_cloud_gkemulticloud_v1_attached_resources_proto_rawDescGZIP() [ } var file_google_cloud_gkemulticloud_v1_attached_resources_proto_enumTypes = make([]protoimpl.EnumInfo, 1) -var file_google_cloud_gkemulticloud_v1_attached_resources_proto_msgTypes = make([]protoimpl.MessageInfo, 11) +var file_google_cloud_gkemulticloud_v1_attached_resources_proto_msgTypes = make([]protoimpl.MessageInfo, 12) var file_google_cloud_gkemulticloud_v1_attached_resources_proto_goTypes = []any{ (AttachedCluster_State)(0), // 0: google.cloud.gkemulticloud.v1.AttachedCluster.State (*AttachedCluster)(nil), // 1: google.cloud.gkemulticloud.v1.AttachedCluster @@ -1114,38 +1147,40 @@ var file_google_cloud_gkemulticloud_v1_attached_resources_proto_goTypes = []any{ (*AttachedProxyConfig)(nil), // 9: google.cloud.gkemulticloud.v1.AttachedProxyConfig (*KubernetesSecret)(nil), // 10: google.cloud.gkemulticloud.v1.KubernetesSecret nil, // 11: google.cloud.gkemulticloud.v1.AttachedCluster.AnnotationsEntry - (*Fleet)(nil), // 12: google.cloud.gkemulticloud.v1.Fleet - (*timestamppb.Timestamp)(nil), // 13: google.protobuf.Timestamp - (*WorkloadIdentityConfig)(nil), // 14: google.cloud.gkemulticloud.v1.WorkloadIdentityConfig - (*LoggingConfig)(nil), // 15: google.cloud.gkemulticloud.v1.LoggingConfig - (*MonitoringConfig)(nil), // 16: google.cloud.gkemulticloud.v1.MonitoringConfig - (*BinaryAuthorization)(nil), // 17: google.cloud.gkemulticloud.v1.BinaryAuthorization - (*SecurityPostureConfig)(nil), // 18: google.cloud.gkemulticloud.v1.SecurityPostureConfig + nil, // 12: google.cloud.gkemulticloud.v1.AttachedCluster.TagsEntry + (*Fleet)(nil), // 13: google.cloud.gkemulticloud.v1.Fleet + (*timestamppb.Timestamp)(nil), // 14: google.protobuf.Timestamp + (*WorkloadIdentityConfig)(nil), // 15: google.cloud.gkemulticloud.v1.WorkloadIdentityConfig + (*LoggingConfig)(nil), // 16: google.cloud.gkemulticloud.v1.LoggingConfig + (*MonitoringConfig)(nil), // 17: google.cloud.gkemulticloud.v1.MonitoringConfig + (*BinaryAuthorization)(nil), // 18: google.cloud.gkemulticloud.v1.BinaryAuthorization + (*SecurityPostureConfig)(nil), // 19: google.cloud.gkemulticloud.v1.SecurityPostureConfig } var file_google_cloud_gkemulticloud_v1_attached_resources_proto_depIdxs = []int32{ 5, // 0: google.cloud.gkemulticloud.v1.AttachedCluster.oidc_config:type_name -> google.cloud.gkemulticloud.v1.AttachedOidcConfig - 12, // 1: google.cloud.gkemulticloud.v1.AttachedCluster.fleet:type_name -> google.cloud.gkemulticloud.v1.Fleet + 13, // 1: google.cloud.gkemulticloud.v1.AttachedCluster.fleet:type_name -> google.cloud.gkemulticloud.v1.Fleet 0, // 2: google.cloud.gkemulticloud.v1.AttachedCluster.state:type_name -> google.cloud.gkemulticloud.v1.AttachedCluster.State - 13, // 3: google.cloud.gkemulticloud.v1.AttachedCluster.create_time:type_name -> google.protobuf.Timestamp - 13, // 4: google.cloud.gkemulticloud.v1.AttachedCluster.update_time:type_name -> google.protobuf.Timestamp + 14, // 3: google.cloud.gkemulticloud.v1.AttachedCluster.create_time:type_name -> google.protobuf.Timestamp + 14, // 4: google.cloud.gkemulticloud.v1.AttachedCluster.update_time:type_name -> google.protobuf.Timestamp 11, // 5: google.cloud.gkemulticloud.v1.AttachedCluster.annotations:type_name -> google.cloud.gkemulticloud.v1.AttachedCluster.AnnotationsEntry - 14, // 6: google.cloud.gkemulticloud.v1.AttachedCluster.workload_identity_config:type_name -> google.cloud.gkemulticloud.v1.WorkloadIdentityConfig - 15, // 7: google.cloud.gkemulticloud.v1.AttachedCluster.logging_config:type_name -> google.cloud.gkemulticloud.v1.LoggingConfig + 15, // 6: google.cloud.gkemulticloud.v1.AttachedCluster.workload_identity_config:type_name -> google.cloud.gkemulticloud.v1.WorkloadIdentityConfig + 16, // 7: google.cloud.gkemulticloud.v1.AttachedCluster.logging_config:type_name -> google.cloud.gkemulticloud.v1.LoggingConfig 8, // 8: google.cloud.gkemulticloud.v1.AttachedCluster.errors:type_name -> google.cloud.gkemulticloud.v1.AttachedClusterError 2, // 9: google.cloud.gkemulticloud.v1.AttachedCluster.authorization:type_name -> google.cloud.gkemulticloud.v1.AttachedClustersAuthorization - 16, // 10: google.cloud.gkemulticloud.v1.AttachedCluster.monitoring_config:type_name -> google.cloud.gkemulticloud.v1.MonitoringConfig + 17, // 10: google.cloud.gkemulticloud.v1.AttachedCluster.monitoring_config:type_name -> google.cloud.gkemulticloud.v1.MonitoringConfig 9, // 11: google.cloud.gkemulticloud.v1.AttachedCluster.proxy_config:type_name -> google.cloud.gkemulticloud.v1.AttachedProxyConfig - 17, // 12: google.cloud.gkemulticloud.v1.AttachedCluster.binary_authorization:type_name -> google.cloud.gkemulticloud.v1.BinaryAuthorization - 18, // 13: google.cloud.gkemulticloud.v1.AttachedCluster.security_posture_config:type_name -> google.cloud.gkemulticloud.v1.SecurityPostureConfig - 3, // 14: google.cloud.gkemulticloud.v1.AttachedClustersAuthorization.admin_users:type_name -> google.cloud.gkemulticloud.v1.AttachedClusterUser - 4, // 15: google.cloud.gkemulticloud.v1.AttachedClustersAuthorization.admin_groups:type_name -> google.cloud.gkemulticloud.v1.AttachedClusterGroup - 7, // 16: google.cloud.gkemulticloud.v1.AttachedServerConfig.valid_versions:type_name -> google.cloud.gkemulticloud.v1.AttachedPlatformVersionInfo - 10, // 17: google.cloud.gkemulticloud.v1.AttachedProxyConfig.kubernetes_secret:type_name -> google.cloud.gkemulticloud.v1.KubernetesSecret - 18, // [18:18] is the sub-list for method output_type - 18, // [18:18] is the sub-list for method input_type - 18, // [18:18] is the sub-list for extension type_name - 18, // [18:18] is the sub-list for extension extendee - 0, // [0:18] is the sub-list for field type_name + 18, // 12: google.cloud.gkemulticloud.v1.AttachedCluster.binary_authorization:type_name -> google.cloud.gkemulticloud.v1.BinaryAuthorization + 19, // 13: google.cloud.gkemulticloud.v1.AttachedCluster.security_posture_config:type_name -> google.cloud.gkemulticloud.v1.SecurityPostureConfig + 12, // 14: google.cloud.gkemulticloud.v1.AttachedCluster.tags:type_name -> google.cloud.gkemulticloud.v1.AttachedCluster.TagsEntry + 3, // 15: google.cloud.gkemulticloud.v1.AttachedClustersAuthorization.admin_users:type_name -> google.cloud.gkemulticloud.v1.AttachedClusterUser + 4, // 16: google.cloud.gkemulticloud.v1.AttachedClustersAuthorization.admin_groups:type_name -> google.cloud.gkemulticloud.v1.AttachedClusterGroup + 7, // 17: google.cloud.gkemulticloud.v1.AttachedServerConfig.valid_versions:type_name -> google.cloud.gkemulticloud.v1.AttachedPlatformVersionInfo + 10, // 18: google.cloud.gkemulticloud.v1.AttachedProxyConfig.kubernetes_secret:type_name -> google.cloud.gkemulticloud.v1.KubernetesSecret + 19, // [19:19] is the sub-list for method output_type + 19, // [19:19] is the sub-list for method input_type + 19, // [19:19] is the sub-list for extension type_name + 19, // [19:19] is the sub-list for extension extendee + 0, // [0:19] is the sub-list for field type_name } func init() { file_google_cloud_gkemulticloud_v1_attached_resources_proto_init() } @@ -1160,7 +1195,7 @@ func file_google_cloud_gkemulticloud_v1_attached_resources_proto_init() { GoPackagePath: reflect.TypeOf(x{}).PkgPath(), RawDescriptor: file_google_cloud_gkemulticloud_v1_attached_resources_proto_rawDesc, NumEnums: 1, - NumMessages: 11, + NumMessages: 12, NumExtensions: 0, NumServices: 0, }, diff --git a/gkemulticloud/apiv1/gkemulticloudpb/attached_service.pb.go b/gkemulticloud/apiv1/gkemulticloudpb/attached_service.pb.go index 83ba920c8408..326c543b249c 100755 --- a/gkemulticloud/apiv1/gkemulticloudpb/attached_service.pb.go +++ b/gkemulticloud/apiv1/gkemulticloudpb/attached_service.pb.go @@ -415,6 +415,7 @@ type UpdateAttachedClusterRequest struct { // - `proxy_config.kubernetes_secret.name`. // - `proxy_config.kubernetes_secret.namespace`. // - `security_posture_config.vulnerability_mode` + // - `monitoring_config.cloud_monitoring_config.enabled` UpdateMask *fieldmaskpb.FieldMask `protobuf:"bytes,3,opt,name=update_mask,json=updateMask,proto3" json:"update_mask,omitempty"` } diff --git a/gkemulticloud/apiv1/gkemulticloudpb/common_resources.pb.go b/gkemulticloud/apiv1/gkemulticloudpb/common_resources.pb.go index abff62c5cadd..391d04246565 100755 --- a/gkemulticloud/apiv1/gkemulticloudpb/common_resources.pb.go +++ b/gkemulticloud/apiv1/gkemulticloudpb/common_resources.pb.go @@ -204,7 +204,7 @@ func (x BinaryAuthorization_EvaluationMode) Number() protoreflect.EnumNumber { // Deprecated: Use BinaryAuthorization_EvaluationMode.Descriptor instead. func (BinaryAuthorization_EvaluationMode) EnumDescriptor() ([]byte, []int) { - return file_google_cloud_gkemulticloud_v1_common_resources_proto_rawDescGZIP(), []int{11, 0} + return file_google_cloud_gkemulticloud_v1_common_resources_proto_rawDescGZIP(), []int{12, 0} } // VulnerabilityMode defines enablement mode for vulnerability scanning. @@ -258,7 +258,7 @@ func (x SecurityPostureConfig_VulnerabilityMode) Number() protoreflect.EnumNumbe // Deprecated: Use SecurityPostureConfig_VulnerabilityMode.Descriptor instead. func (SecurityPostureConfig_VulnerabilityMode) EnumDescriptor() ([]byte, []int) { - return file_google_cloud_gkemulticloud_v1_common_resources_proto_rawDescGZIP(), []int{12, 0} + return file_google_cloud_gkemulticloud_v1_common_resources_proto_rawDescGZIP(), []int{13, 0} } // Jwk is a JSON Web Key as specified in RFC 7517. @@ -515,9 +515,10 @@ type OperationMetadata struct { Verb string `protobuf:"bytes,7,opt,name=verb,proto3" json:"verb,omitempty"` // Output only. Identifies whether it has been requested cancellation // for the operation. Operations that have successfully been cancelled - // have [Operation.error][] value with a - // [google.rpc.Status.code][google.rpc.Status.code] of 1, corresponding to - // `Code.CANCELLED`. + // have + // [google.longrunning.Operation.error][google.longrunning.Operation.error] + // value with a [google.rpc.Status.code][google.rpc.Status.code] of 1, + // corresponding to `Code.CANCELLED`. RequestedCancellation bool `protobuf:"varint,6,opt,name=requested_cancellation,json=requestedCancellation,proto3" json:"requested_cancellation,omitempty"` } @@ -952,6 +953,9 @@ type MonitoringConfig struct { // Enable Google Cloud Managed Service for Prometheus in the cluster. ManagedPrometheusConfig *ManagedPrometheusConfig `protobuf:"bytes,2,opt,name=managed_prometheus_config,json=managedPrometheusConfig,proto3" json:"managed_prometheus_config,omitempty"` + // Optionally enable GKE metrics. + // Only for Attached Clusters. + CloudMonitoringConfig *CloudMonitoringConfig `protobuf:"bytes,4,opt,name=cloud_monitoring_config,json=cloudMonitoringConfig,proto3" json:"cloud_monitoring_config,omitempty"` } func (x *MonitoringConfig) Reset() { @@ -991,6 +995,13 @@ func (x *MonitoringConfig) GetManagedPrometheusConfig() *ManagedPrometheusConfig return nil } +func (x *MonitoringConfig) GetCloudMonitoringConfig() *CloudMonitoringConfig { + if x != nil { + return x.CloudMonitoringConfig + } + return nil +} + // ManagedPrometheusConfig defines the configuration for // Google Cloud Managed Service for Prometheus. type ManagedPrometheusConfig struct { @@ -1039,6 +1050,56 @@ func (x *ManagedPrometheusConfig) GetEnabled() bool { return false } +// CloudMonitoringConfig defines the configuration for +// built-in Cloud Logging and Monitoring. +// Only for Attached Clusters. +type CloudMonitoringConfig struct { + state protoimpl.MessageState + sizeCache protoimpl.SizeCache + unknownFields protoimpl.UnknownFields + + // Enable GKE-native logging and metrics. + // Only for Attached Clusters. + Enabled *bool `protobuf:"varint,1,opt,name=enabled,proto3,oneof" json:"enabled,omitempty"` +} + +func (x *CloudMonitoringConfig) Reset() { + *x = CloudMonitoringConfig{} + mi := &file_google_cloud_gkemulticloud_v1_common_resources_proto_msgTypes[11] + ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) + ms.StoreMessageInfo(mi) +} + +func (x *CloudMonitoringConfig) String() string { + return protoimpl.X.MessageStringOf(x) +} + +func (*CloudMonitoringConfig) ProtoMessage() {} + +func (x *CloudMonitoringConfig) ProtoReflect() protoreflect.Message { + mi := &file_google_cloud_gkemulticloud_v1_common_resources_proto_msgTypes[11] + if x != nil { + ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) + if ms.LoadMessageInfo() == nil { + ms.StoreMessageInfo(mi) + } + return ms + } + return mi.MessageOf(x) +} + +// Deprecated: Use CloudMonitoringConfig.ProtoReflect.Descriptor instead. +func (*CloudMonitoringConfig) Descriptor() ([]byte, []int) { + return file_google_cloud_gkemulticloud_v1_common_resources_proto_rawDescGZIP(), []int{11} +} + +func (x *CloudMonitoringConfig) GetEnabled() bool { + if x != nil && x.Enabled != nil { + return *x.Enabled + } + return false +} + // Configuration for Binary Authorization. type BinaryAuthorization struct { state protoimpl.MessageState @@ -1052,7 +1113,7 @@ type BinaryAuthorization struct { func (x *BinaryAuthorization) Reset() { *x = BinaryAuthorization{} - mi := &file_google_cloud_gkemulticloud_v1_common_resources_proto_msgTypes[11] + mi := &file_google_cloud_gkemulticloud_v1_common_resources_proto_msgTypes[12] ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) ms.StoreMessageInfo(mi) } @@ -1064,7 +1125,7 @@ func (x *BinaryAuthorization) String() string { func (*BinaryAuthorization) ProtoMessage() {} func (x *BinaryAuthorization) ProtoReflect() protoreflect.Message { - mi := &file_google_cloud_gkemulticloud_v1_common_resources_proto_msgTypes[11] + mi := &file_google_cloud_gkemulticloud_v1_common_resources_proto_msgTypes[12] if x != nil { ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) if ms.LoadMessageInfo() == nil { @@ -1077,7 +1138,7 @@ func (x *BinaryAuthorization) ProtoReflect() protoreflect.Message { // Deprecated: Use BinaryAuthorization.ProtoReflect.Descriptor instead. func (*BinaryAuthorization) Descriptor() ([]byte, []int) { - return file_google_cloud_gkemulticloud_v1_common_resources_proto_rawDescGZIP(), []int{11} + return file_google_cloud_gkemulticloud_v1_common_resources_proto_rawDescGZIP(), []int{12} } func (x *BinaryAuthorization) GetEvaluationMode() BinaryAuthorization_EvaluationMode { @@ -1100,7 +1161,7 @@ type SecurityPostureConfig struct { func (x *SecurityPostureConfig) Reset() { *x = SecurityPostureConfig{} - mi := &file_google_cloud_gkemulticloud_v1_common_resources_proto_msgTypes[12] + mi := &file_google_cloud_gkemulticloud_v1_common_resources_proto_msgTypes[13] ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) ms.StoreMessageInfo(mi) } @@ -1112,7 +1173,7 @@ func (x *SecurityPostureConfig) String() string { func (*SecurityPostureConfig) ProtoMessage() {} func (x *SecurityPostureConfig) ProtoReflect() protoreflect.Message { - mi := &file_google_cloud_gkemulticloud_v1_common_resources_proto_msgTypes[12] + mi := &file_google_cloud_gkemulticloud_v1_common_resources_proto_msgTypes[13] if x != nil { ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) if ms.LoadMessageInfo() == nil { @@ -1125,7 +1186,7 @@ func (x *SecurityPostureConfig) ProtoReflect() protoreflect.Message { // Deprecated: Use SecurityPostureConfig.ProtoReflect.Descriptor instead. func (*SecurityPostureConfig) Descriptor() ([]byte, []int) { - return file_google_cloud_gkemulticloud_v1_common_resources_proto_rawDescGZIP(), []int{12} + return file_google_cloud_gkemulticloud_v1_common_resources_proto_rawDescGZIP(), []int{13} } func (x *SecurityPostureConfig) GetVulnerabilityMode() SecurityPostureConfig_VulnerabilityMode { @@ -1257,7 +1318,7 @@ var file_google_cloud_gkemulticloud_v1_common_resources_proto_rawDesc = []byte{ 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x15, 0x0a, 0x11, 0x53, 0x59, 0x53, 0x54, 0x45, 0x4d, 0x5f, 0x43, 0x4f, 0x4d, 0x50, 0x4f, 0x4e, 0x45, 0x4e, 0x54, 0x53, 0x10, 0x01, 0x12, 0x0d, 0x0a, 0x09, 0x57, 0x4f, 0x52, 0x4b, 0x4c, 0x4f, 0x41, 0x44, 0x53, 0x10, 0x02, 0x22, - 0x86, 0x01, 0x0a, 0x10, 0x4d, 0x6f, 0x6e, 0x69, 0x74, 0x6f, 0x72, 0x69, 0x6e, 0x67, 0x43, 0x6f, + 0xf4, 0x01, 0x0a, 0x10, 0x4d, 0x6f, 0x6e, 0x69, 0x74, 0x6f, 0x72, 0x69, 0x6e, 0x67, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x72, 0x0a, 0x19, 0x6d, 0x61, 0x6e, 0x61, 0x67, 0x65, 0x64, 0x5f, 0x70, 0x72, 0x6f, 0x6d, 0x65, 0x74, 0x68, 0x65, 0x75, 0x73, 0x5f, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x36, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, @@ -1265,56 +1326,67 @@ var file_google_cloud_gkemulticloud_v1_common_resources_proto_rawDesc = []byte{ 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x76, 0x31, 0x2e, 0x4d, 0x61, 0x6e, 0x61, 0x67, 0x65, 0x64, 0x50, 0x72, 0x6f, 0x6d, 0x65, 0x74, 0x68, 0x65, 0x75, 0x73, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x52, 0x17, 0x6d, 0x61, 0x6e, 0x61, 0x67, 0x65, 0x64, 0x50, 0x72, 0x6f, 0x6d, 0x65, 0x74, 0x68, 0x65, - 0x75, 0x73, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x22, 0x33, 0x0a, 0x17, 0x4d, 0x61, 0x6e, 0x61, - 0x67, 0x65, 0x64, 0x50, 0x72, 0x6f, 0x6d, 0x65, 0x74, 0x68, 0x65, 0x75, 0x73, 0x43, 0x6f, 0x6e, - 0x66, 0x69, 0x67, 0x12, 0x18, 0x0a, 0x07, 0x65, 0x6e, 0x61, 0x62, 0x6c, 0x65, 0x64, 0x18, 0x01, - 0x20, 0x01, 0x28, 0x08, 0x52, 0x07, 0x65, 0x6e, 0x61, 0x62, 0x6c, 0x65, 0x64, 0x22, 0xe8, 0x01, - 0x0a, 0x13, 0x42, 0x69, 0x6e, 0x61, 0x72, 0x79, 0x41, 0x75, 0x74, 0x68, 0x6f, 0x72, 0x69, 0x7a, - 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x12, 0x6a, 0x0a, 0x0f, 0x65, 0x76, 0x61, 0x6c, 0x75, 0x61, 0x74, - 0x69, 0x6f, 0x6e, 0x5f, 0x6d, 0x6f, 0x64, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0e, 0x32, 0x41, - 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x67, 0x6b, - 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x76, 0x31, 0x2e, 0x42, - 0x69, 0x6e, 0x61, 0x72, 0x79, 0x41, 0x75, 0x74, 0x68, 0x6f, 0x72, 0x69, 0x7a, 0x61, 0x74, 0x69, - 0x6f, 0x6e, 0x2e, 0x45, 0x76, 0x61, 0x6c, 0x75, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x6f, 0x64, - 0x65, 0x52, 0x0e, 0x65, 0x76, 0x61, 0x6c, 0x75, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x6f, 0x64, - 0x65, 0x22, 0x65, 0x0a, 0x0e, 0x45, 0x76, 0x61, 0x6c, 0x75, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, - 0x6f, 0x64, 0x65, 0x12, 0x1f, 0x0a, 0x1b, 0x45, 0x56, 0x41, 0x4c, 0x55, 0x41, 0x54, 0x49, 0x4f, - 0x4e, 0x5f, 0x4d, 0x4f, 0x44, 0x45, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, - 0x45, 0x44, 0x10, 0x00, 0x12, 0x0c, 0x0a, 0x08, 0x44, 0x49, 0x53, 0x41, 0x42, 0x4c, 0x45, 0x44, - 0x10, 0x01, 0x12, 0x24, 0x0a, 0x20, 0x50, 0x52, 0x4f, 0x4a, 0x45, 0x43, 0x54, 0x5f, 0x53, 0x49, - 0x4e, 0x47, 0x4c, 0x45, 0x54, 0x4f, 0x4e, 0x5f, 0x50, 0x4f, 0x4c, 0x49, 0x43, 0x59, 0x5f, 0x45, - 0x4e, 0x46, 0x4f, 0x52, 0x43, 0x45, 0x10, 0x02, 0x22, 0x81, 0x02, 0x0a, 0x15, 0x53, 0x65, 0x63, - 0x75, 0x72, 0x69, 0x74, 0x79, 0x50, 0x6f, 0x73, 0x74, 0x75, 0x72, 0x65, 0x43, 0x6f, 0x6e, 0x66, - 0x69, 0x67, 0x12, 0x75, 0x0a, 0x12, 0x76, 0x75, 0x6c, 0x6e, 0x65, 0x72, 0x61, 0x62, 0x69, 0x6c, - 0x69, 0x74, 0x79, 0x5f, 0x6d, 0x6f, 0x64, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0e, 0x32, 0x46, - 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x67, 0x6b, - 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x76, 0x31, 0x2e, 0x53, + 0x75, 0x73, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x6c, 0x0a, 0x17, 0x63, 0x6c, 0x6f, 0x75, + 0x64, 0x5f, 0x6d, 0x6f, 0x6e, 0x69, 0x74, 0x6f, 0x72, 0x69, 0x6e, 0x67, 0x5f, 0x63, 0x6f, 0x6e, + 0x66, 0x69, 0x67, 0x18, 0x04, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x34, 0x2e, 0x67, 0x6f, 0x6f, 0x67, + 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x67, 0x6b, 0x65, 0x6d, 0x75, 0x6c, 0x74, + 0x69, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x76, 0x31, 0x2e, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x4d, + 0x6f, 0x6e, 0x69, 0x74, 0x6f, 0x72, 0x69, 0x6e, 0x67, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x52, + 0x15, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x4d, 0x6f, 0x6e, 0x69, 0x74, 0x6f, 0x72, 0x69, 0x6e, 0x67, + 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x22, 0x33, 0x0a, 0x17, 0x4d, 0x61, 0x6e, 0x61, 0x67, 0x65, + 0x64, 0x50, 0x72, 0x6f, 0x6d, 0x65, 0x74, 0x68, 0x65, 0x75, 0x73, 0x43, 0x6f, 0x6e, 0x66, 0x69, + 0x67, 0x12, 0x18, 0x0a, 0x07, 0x65, 0x6e, 0x61, 0x62, 0x6c, 0x65, 0x64, 0x18, 0x01, 0x20, 0x01, + 0x28, 0x08, 0x52, 0x07, 0x65, 0x6e, 0x61, 0x62, 0x6c, 0x65, 0x64, 0x22, 0x42, 0x0a, 0x15, 0x43, + 0x6c, 0x6f, 0x75, 0x64, 0x4d, 0x6f, 0x6e, 0x69, 0x74, 0x6f, 0x72, 0x69, 0x6e, 0x67, 0x43, 0x6f, + 0x6e, 0x66, 0x69, 0x67, 0x12, 0x1d, 0x0a, 0x07, 0x65, 0x6e, 0x61, 0x62, 0x6c, 0x65, 0x64, 0x18, + 0x01, 0x20, 0x01, 0x28, 0x08, 0x48, 0x00, 0x52, 0x07, 0x65, 0x6e, 0x61, 0x62, 0x6c, 0x65, 0x64, + 0x88, 0x01, 0x01, 0x42, 0x0a, 0x0a, 0x08, 0x5f, 0x65, 0x6e, 0x61, 0x62, 0x6c, 0x65, 0x64, 0x22, + 0xe8, 0x01, 0x0a, 0x13, 0x42, 0x69, 0x6e, 0x61, 0x72, 0x79, 0x41, 0x75, 0x74, 0x68, 0x6f, 0x72, + 0x69, 0x7a, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x12, 0x6a, 0x0a, 0x0f, 0x65, 0x76, 0x61, 0x6c, 0x75, + 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x5f, 0x6d, 0x6f, 0x64, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0e, + 0x32, 0x41, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, + 0x67, 0x6b, 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x76, 0x31, + 0x2e, 0x42, 0x69, 0x6e, 0x61, 0x72, 0x79, 0x41, 0x75, 0x74, 0x68, 0x6f, 0x72, 0x69, 0x7a, 0x61, + 0x74, 0x69, 0x6f, 0x6e, 0x2e, 0x45, 0x76, 0x61, 0x6c, 0x75, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, + 0x6f, 0x64, 0x65, 0x52, 0x0e, 0x65, 0x76, 0x61, 0x6c, 0x75, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, + 0x6f, 0x64, 0x65, 0x22, 0x65, 0x0a, 0x0e, 0x45, 0x76, 0x61, 0x6c, 0x75, 0x61, 0x74, 0x69, 0x6f, + 0x6e, 0x4d, 0x6f, 0x64, 0x65, 0x12, 0x1f, 0x0a, 0x1b, 0x45, 0x56, 0x41, 0x4c, 0x55, 0x41, 0x54, + 0x49, 0x4f, 0x4e, 0x5f, 0x4d, 0x4f, 0x44, 0x45, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, + 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x0c, 0x0a, 0x08, 0x44, 0x49, 0x53, 0x41, 0x42, 0x4c, + 0x45, 0x44, 0x10, 0x01, 0x12, 0x24, 0x0a, 0x20, 0x50, 0x52, 0x4f, 0x4a, 0x45, 0x43, 0x54, 0x5f, + 0x53, 0x49, 0x4e, 0x47, 0x4c, 0x45, 0x54, 0x4f, 0x4e, 0x5f, 0x50, 0x4f, 0x4c, 0x49, 0x43, 0x59, + 0x5f, 0x45, 0x4e, 0x46, 0x4f, 0x52, 0x43, 0x45, 0x10, 0x02, 0x22, 0x81, 0x02, 0x0a, 0x15, 0x53, 0x65, 0x63, 0x75, 0x72, 0x69, 0x74, 0x79, 0x50, 0x6f, 0x73, 0x74, 0x75, 0x72, 0x65, 0x43, 0x6f, - 0x6e, 0x66, 0x69, 0x67, 0x2e, 0x56, 0x75, 0x6c, 0x6e, 0x65, 0x72, 0x61, 0x62, 0x69, 0x6c, 0x69, - 0x74, 0x79, 0x4d, 0x6f, 0x64, 0x65, 0x52, 0x11, 0x76, 0x75, 0x6c, 0x6e, 0x65, 0x72, 0x61, 0x62, - 0x69, 0x6c, 0x69, 0x74, 0x79, 0x4d, 0x6f, 0x64, 0x65, 0x22, 0x71, 0x0a, 0x11, 0x56, 0x75, 0x6c, - 0x6e, 0x65, 0x72, 0x61, 0x62, 0x69, 0x6c, 0x69, 0x74, 0x79, 0x4d, 0x6f, 0x64, 0x65, 0x12, 0x22, - 0x0a, 0x1e, 0x56, 0x55, 0x4c, 0x4e, 0x45, 0x52, 0x41, 0x42, 0x49, 0x4c, 0x49, 0x54, 0x59, 0x5f, - 0x4d, 0x4f, 0x44, 0x45, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, - 0x10, 0x00, 0x12, 0x1a, 0x0a, 0x16, 0x56, 0x55, 0x4c, 0x4e, 0x45, 0x52, 0x41, 0x42, 0x49, 0x4c, - 0x49, 0x54, 0x59, 0x5f, 0x44, 0x49, 0x53, 0x41, 0x42, 0x4c, 0x45, 0x44, 0x10, 0x01, 0x12, 0x1c, - 0x0a, 0x18, 0x56, 0x55, 0x4c, 0x4e, 0x45, 0x52, 0x41, 0x42, 0x49, 0x4c, 0x49, 0x54, 0x59, 0x5f, - 0x45, 0x4e, 0x54, 0x45, 0x52, 0x50, 0x52, 0x49, 0x53, 0x45, 0x10, 0x02, 0x42, 0xe7, 0x01, 0x0a, - 0x21, 0x63, 0x6f, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, - 0x64, 0x2e, 0x67, 0x6b, 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, - 0x76, 0x31, 0x42, 0x14, 0x43, 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, 0x52, 0x65, 0x73, 0x6f, 0x75, 0x72, - 0x63, 0x65, 0x73, 0x50, 0x72, 0x6f, 0x74, 0x6f, 0x50, 0x01, 0x5a, 0x47, 0x63, 0x6c, 0x6f, 0x75, - 0x64, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x67, 0x6f, 0x2f, - 0x67, 0x6b, 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2f, 0x61, 0x70, - 0x69, 0x76, 0x31, 0x2f, 0x67, 0x6b, 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, - 0x64, 0x70, 0x62, 0x3b, 0x67, 0x6b, 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, - 0x64, 0x70, 0x62, 0xaa, 0x02, 0x1d, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x43, 0x6c, 0x6f, - 0x75, 0x64, 0x2e, 0x47, 0x6b, 0x65, 0x4d, 0x75, 0x6c, 0x74, 0x69, 0x43, 0x6c, 0x6f, 0x75, 0x64, - 0x2e, 0x56, 0x31, 0xca, 0x02, 0x1d, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x5c, 0x43, 0x6c, 0x6f, - 0x75, 0x64, 0x5c, 0x47, 0x6b, 0x65, 0x4d, 0x75, 0x6c, 0x74, 0x69, 0x43, 0x6c, 0x6f, 0x75, 0x64, - 0x5c, 0x56, 0x31, 0xea, 0x02, 0x20, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x3a, 0x3a, 0x43, 0x6c, - 0x6f, 0x75, 0x64, 0x3a, 0x3a, 0x47, 0x6b, 0x65, 0x4d, 0x75, 0x6c, 0x74, 0x69, 0x43, 0x6c, 0x6f, - 0x75, 0x64, 0x3a, 0x3a, 0x56, 0x31, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, + 0x6e, 0x66, 0x69, 0x67, 0x12, 0x75, 0x0a, 0x12, 0x76, 0x75, 0x6c, 0x6e, 0x65, 0x72, 0x61, 0x62, + 0x69, 0x6c, 0x69, 0x74, 0x79, 0x5f, 0x6d, 0x6f, 0x64, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0e, + 0x32, 0x46, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, + 0x67, 0x6b, 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x76, 0x31, + 0x2e, 0x53, 0x65, 0x63, 0x75, 0x72, 0x69, 0x74, 0x79, 0x50, 0x6f, 0x73, 0x74, 0x75, 0x72, 0x65, + 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x2e, 0x56, 0x75, 0x6c, 0x6e, 0x65, 0x72, 0x61, 0x62, 0x69, + 0x6c, 0x69, 0x74, 0x79, 0x4d, 0x6f, 0x64, 0x65, 0x52, 0x11, 0x76, 0x75, 0x6c, 0x6e, 0x65, 0x72, + 0x61, 0x62, 0x69, 0x6c, 0x69, 0x74, 0x79, 0x4d, 0x6f, 0x64, 0x65, 0x22, 0x71, 0x0a, 0x11, 0x56, + 0x75, 0x6c, 0x6e, 0x65, 0x72, 0x61, 0x62, 0x69, 0x6c, 0x69, 0x74, 0x79, 0x4d, 0x6f, 0x64, 0x65, + 0x12, 0x22, 0x0a, 0x1e, 0x56, 0x55, 0x4c, 0x4e, 0x45, 0x52, 0x41, 0x42, 0x49, 0x4c, 0x49, 0x54, + 0x59, 0x5f, 0x4d, 0x4f, 0x44, 0x45, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, + 0x45, 0x44, 0x10, 0x00, 0x12, 0x1a, 0x0a, 0x16, 0x56, 0x55, 0x4c, 0x4e, 0x45, 0x52, 0x41, 0x42, + 0x49, 0x4c, 0x49, 0x54, 0x59, 0x5f, 0x44, 0x49, 0x53, 0x41, 0x42, 0x4c, 0x45, 0x44, 0x10, 0x01, + 0x12, 0x1c, 0x0a, 0x18, 0x56, 0x55, 0x4c, 0x4e, 0x45, 0x52, 0x41, 0x42, 0x49, 0x4c, 0x49, 0x54, + 0x59, 0x5f, 0x45, 0x4e, 0x54, 0x45, 0x52, 0x50, 0x52, 0x49, 0x53, 0x45, 0x10, 0x02, 0x42, 0xe7, + 0x01, 0x0a, 0x21, 0x63, 0x6f, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, + 0x6f, 0x75, 0x64, 0x2e, 0x67, 0x6b, 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, + 0x64, 0x2e, 0x76, 0x31, 0x42, 0x14, 0x43, 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, 0x52, 0x65, 0x73, 0x6f, + 0x75, 0x72, 0x63, 0x65, 0x73, 0x50, 0x72, 0x6f, 0x74, 0x6f, 0x50, 0x01, 0x5a, 0x47, 0x63, 0x6c, + 0x6f, 0x75, 0x64, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x67, + 0x6f, 0x2f, 0x67, 0x6b, 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2f, + 0x61, 0x70, 0x69, 0x76, 0x31, 0x2f, 0x67, 0x6b, 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, + 0x6f, 0x75, 0x64, 0x70, 0x62, 0x3b, 0x67, 0x6b, 0x65, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x63, 0x6c, + 0x6f, 0x75, 0x64, 0x70, 0x62, 0xaa, 0x02, 0x1d, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x43, + 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x47, 0x6b, 0x65, 0x4d, 0x75, 0x6c, 0x74, 0x69, 0x43, 0x6c, 0x6f, + 0x75, 0x64, 0x2e, 0x56, 0x31, 0xca, 0x02, 0x1d, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x5c, 0x43, + 0x6c, 0x6f, 0x75, 0x64, 0x5c, 0x47, 0x6b, 0x65, 0x4d, 0x75, 0x6c, 0x74, 0x69, 0x43, 0x6c, 0x6f, + 0x75, 0x64, 0x5c, 0x56, 0x31, 0xea, 0x02, 0x20, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x3a, 0x3a, + 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x3a, 0x3a, 0x47, 0x6b, 0x65, 0x4d, 0x75, 0x6c, 0x74, 0x69, 0x43, + 0x6c, 0x6f, 0x75, 0x64, 0x3a, 0x3a, 0x56, 0x31, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, } var ( @@ -1330,7 +1402,7 @@ func file_google_cloud_gkemulticloud_v1_common_resources_proto_rawDescGZIP() []b } var file_google_cloud_gkemulticloud_v1_common_resources_proto_enumTypes = make([]protoimpl.EnumInfo, 4) -var file_google_cloud_gkemulticloud_v1_common_resources_proto_msgTypes = make([]protoimpl.MessageInfo, 13) +var file_google_cloud_gkemulticloud_v1_common_resources_proto_msgTypes = make([]protoimpl.MessageInfo, 14) var file_google_cloud_gkemulticloud_v1_common_resources_proto_goTypes = []any{ (NodeTaint_Effect)(0), // 0: google.cloud.gkemulticloud.v1.NodeTaint.Effect (LoggingComponentConfig_Component)(0), // 1: google.cloud.gkemulticloud.v1.LoggingComponentConfig.Component @@ -1347,24 +1419,26 @@ var file_google_cloud_gkemulticloud_v1_common_resources_proto_goTypes = []any{ (*LoggingComponentConfig)(nil), // 12: google.cloud.gkemulticloud.v1.LoggingComponentConfig (*MonitoringConfig)(nil), // 13: google.cloud.gkemulticloud.v1.MonitoringConfig (*ManagedPrometheusConfig)(nil), // 14: google.cloud.gkemulticloud.v1.ManagedPrometheusConfig - (*BinaryAuthorization)(nil), // 15: google.cloud.gkemulticloud.v1.BinaryAuthorization - (*SecurityPostureConfig)(nil), // 16: google.cloud.gkemulticloud.v1.SecurityPostureConfig - (*timestamppb.Timestamp)(nil), // 17: google.protobuf.Timestamp + (*CloudMonitoringConfig)(nil), // 15: google.cloud.gkemulticloud.v1.CloudMonitoringConfig + (*BinaryAuthorization)(nil), // 16: google.cloud.gkemulticloud.v1.BinaryAuthorization + (*SecurityPostureConfig)(nil), // 17: google.cloud.gkemulticloud.v1.SecurityPostureConfig + (*timestamppb.Timestamp)(nil), // 18: google.protobuf.Timestamp } var file_google_cloud_gkemulticloud_v1_common_resources_proto_depIdxs = []int32{ - 17, // 0: google.cloud.gkemulticloud.v1.OperationMetadata.create_time:type_name -> google.protobuf.Timestamp - 17, // 1: google.cloud.gkemulticloud.v1.OperationMetadata.end_time:type_name -> google.protobuf.Timestamp + 18, // 0: google.cloud.gkemulticloud.v1.OperationMetadata.create_time:type_name -> google.protobuf.Timestamp + 18, // 1: google.cloud.gkemulticloud.v1.OperationMetadata.end_time:type_name -> google.protobuf.Timestamp 0, // 2: google.cloud.gkemulticloud.v1.NodeTaint.effect:type_name -> google.cloud.gkemulticloud.v1.NodeTaint.Effect 12, // 3: google.cloud.gkemulticloud.v1.LoggingConfig.component_config:type_name -> google.cloud.gkemulticloud.v1.LoggingComponentConfig 1, // 4: google.cloud.gkemulticloud.v1.LoggingComponentConfig.enable_components:type_name -> google.cloud.gkemulticloud.v1.LoggingComponentConfig.Component 14, // 5: google.cloud.gkemulticloud.v1.MonitoringConfig.managed_prometheus_config:type_name -> google.cloud.gkemulticloud.v1.ManagedPrometheusConfig - 2, // 6: google.cloud.gkemulticloud.v1.BinaryAuthorization.evaluation_mode:type_name -> google.cloud.gkemulticloud.v1.BinaryAuthorization.EvaluationMode - 3, // 7: google.cloud.gkemulticloud.v1.SecurityPostureConfig.vulnerability_mode:type_name -> google.cloud.gkemulticloud.v1.SecurityPostureConfig.VulnerabilityMode - 8, // [8:8] is the sub-list for method output_type - 8, // [8:8] is the sub-list for method input_type - 8, // [8:8] is the sub-list for extension type_name - 8, // [8:8] is the sub-list for extension extendee - 0, // [0:8] is the sub-list for field type_name + 15, // 6: google.cloud.gkemulticloud.v1.MonitoringConfig.cloud_monitoring_config:type_name -> google.cloud.gkemulticloud.v1.CloudMonitoringConfig + 2, // 7: google.cloud.gkemulticloud.v1.BinaryAuthorization.evaluation_mode:type_name -> google.cloud.gkemulticloud.v1.BinaryAuthorization.EvaluationMode + 3, // 8: google.cloud.gkemulticloud.v1.SecurityPostureConfig.vulnerability_mode:type_name -> google.cloud.gkemulticloud.v1.SecurityPostureConfig.VulnerabilityMode + 9, // [9:9] is the sub-list for method output_type + 9, // [9:9] is the sub-list for method input_type + 9, // [9:9] is the sub-list for extension type_name + 9, // [9:9] is the sub-list for extension extendee + 0, // [0:9] is the sub-list for field type_name } func init() { file_google_cloud_gkemulticloud_v1_common_resources_proto_init() } @@ -1373,13 +1447,14 @@ func file_google_cloud_gkemulticloud_v1_common_resources_proto_init() { return } file_google_cloud_gkemulticloud_v1_common_resources_proto_msgTypes[5].OneofWrappers = []any{} + file_google_cloud_gkemulticloud_v1_common_resources_proto_msgTypes[11].OneofWrappers = []any{} type x struct{} out := protoimpl.TypeBuilder{ File: protoimpl.DescBuilder{ GoPackagePath: reflect.TypeOf(x{}).PkgPath(), RawDescriptor: file_google_cloud_gkemulticloud_v1_common_resources_proto_rawDesc, NumEnums: 4, - NumMessages: 13, + NumMessages: 14, NumExtensions: 0, NumServices: 0, }, diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/DeployPublisherModel/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/DeployPublisherModel/main.go new file mode 100644 index 000000000000..6cd552d44020 --- /dev/null +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/DeployPublisherModel/main.go @@ -0,0 +1,58 @@ +// Copyright 2024 Google LLC +// +// Licensed under the Apache License, Version 2.0 (the "License"); +// you may not use this file except in compliance with the License. +// You may obtain a copy of the License at +// +// https://www.apache.org/licenses/LICENSE-2.0 +// +// Unless required by applicable law or agreed to in writing, software +// distributed under the License is distributed on an "AS IS" BASIS, +// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. +// See the License for the specific language governing permissions and +// limitations under the License. + +// Code generated by protoc-gen-go_gapic. DO NOT EDIT. + +// [START aiplatform_v1beta1_generated_ModelGardenService_DeployPublisherModel_sync] + +package main + +import ( + "context" + + aiplatform "cloud.google.com/go/aiplatform/apiv1beta1" + aiplatformpb "cloud.google.com/go/aiplatform/apiv1beta1/aiplatformpb" +) + +func main() { + ctx := context.Background() + // This snippet has been automatically generated and should be regarded as a code template only. + // It will require modifications to work: + // - It may require correct/in-range values for request initialization. + // - It may require specifying regional endpoints when creating the service client as shown in: + // https://pkg.go.dev/cloud.google.com/go#hdr-Client_Options + c, err := aiplatform.NewModelGardenClient(ctx) + if err != nil { + // TODO: Handle error. + } + defer c.Close() + + req := &aiplatformpb.DeployPublisherModelRequest{ + // TODO: Fill request struct fields. + // See https://pkg.go.dev/cloud.google.com/go/aiplatform/apiv1beta1/aiplatformpb#DeployPublisherModelRequest. + } + op, err := c.DeployPublisherModel(ctx, req) + if err != nil { + // TODO: Handle error. + } + + resp, err := op.Wait(ctx) + if err != nil { + // TODO: Handle error. + } + // TODO: Use resp. + _ = resp +} + +// [END aiplatform_v1beta1_generated_ModelGardenService_DeployPublisherModel_sync] diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/snippet_metadata.google.cloud.aiplatform.v1beta1.json b/internal/generated/snippets/aiplatform/apiv1beta1/snippet_metadata.google.cloud.aiplatform.v1beta1.json index fcee0974be4b..ba7cebbc2288 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/snippet_metadata.google.cloud.aiplatform.v1beta1.json +++ b/internal/generated/snippets/aiplatform/apiv1beta1/snippet_metadata.google.cloud.aiplatform.v1beta1.json @@ -18264,6 +18264,52 @@ } ] }, + { + "regionTag": "aiplatform_v1beta1_generated_ModelGardenService_DeployPublisherModel_sync", + "title": "aiplatform DeployPublisherModel Sample", + "description": "DeployPublisherModel deploys publisher models.", + "file": "ModelGardenClient/DeployPublisherModel/main.go", + "language": "GO", + "clientMethod": { + "shortName": "DeployPublisherModel", + "fullName": "google.cloud.aiplatform.v1beta1.ModelGardenClient.DeployPublisherModel", + "parameters": [ + { + "type": "context.Context", + "name": "ctx" + }, + { + "type": "aiplatformpb.DeployPublisherModelRequest", + "name": "req" + }, + { + "type": "...gax.CallOption", + "name": "opts" + } + ], + "resultType": "DeployPublisherModelOperation", + "client": { + "shortName": "ModelGardenClient", + "fullName": "google.cloud.aiplatform.v1beta1.ModelGardenClient" + }, + "method": { + "shortName": "DeployPublisherModel", + "fullName": "google.cloud.aiplatform.v1beta1.ModelGardenService.DeployPublisherModel", + "service": { + "shortName": "ModelGardenService", + "fullName": "google.cloud.aiplatform.v1beta1.ModelGardenService" + } + } + }, + "origin": "API_DEFINITION", + "segments": [ + { + "start": 18, + "end": 58, + "type": "FULL" + } + ] + }, { "regionTag": "aiplatform_v1beta1_generated_ModelGardenService_GetIamPolicy_sync", "title": "aiplatform GetIamPolicy Sample", diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/snippet_metadata.google.cloud.contactcenterinsights.v1.json b/internal/generated/snippets/contactcenterinsights/apiv1/snippet_metadata.google.cloud.contactcenterinsights.v1.json index 2a751e3bd574..49cddeb33a5a 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/snippet_metadata.google.cloud.contactcenterinsights.v1.json +++ b/internal/generated/snippets/contactcenterinsights/apiv1/snippet_metadata.google.cloud.contactcenterinsights.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/contactcenterinsights/apiv1", - "version": "1.16.0", + "version": "1.17.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/datacatalog/apiv1/snippet_metadata.google.cloud.datacatalog.v1.json b/internal/generated/snippets/datacatalog/apiv1/snippet_metadata.google.cloud.datacatalog.v1.json index 544a563eade6..c55bf51e77f1 100644 --- a/internal/generated/snippets/datacatalog/apiv1/snippet_metadata.google.cloud.datacatalog.v1.json +++ b/internal/generated/snippets/datacatalog/apiv1/snippet_metadata.google.cloud.datacatalog.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/datacatalog/apiv1", - "version": "1.24.0", + "version": "1.24.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/snippet_metadata.google.cloud.datacatalog.v1beta1.json b/internal/generated/snippets/datacatalog/apiv1beta1/snippet_metadata.google.cloud.datacatalog.v1beta1.json index ab5f461252e2..e59d4e9002ab 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/snippet_metadata.google.cloud.datacatalog.v1beta1.json +++ b/internal/generated/snippets/datacatalog/apiv1beta1/snippet_metadata.google.cloud.datacatalog.v1beta1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/datacatalog/apiv1beta1", - "version": "1.24.0", + "version": "1.24.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/datacatalog/lineage/apiv1/snippet_metadata.google.cloud.datacatalog.lineage.v1.json b/internal/generated/snippets/datacatalog/lineage/apiv1/snippet_metadata.google.cloud.datacatalog.lineage.v1.json index 4e450f7d9399..48bb8907ab43 100644 --- a/internal/generated/snippets/datacatalog/lineage/apiv1/snippet_metadata.google.cloud.datacatalog.lineage.v1.json +++ b/internal/generated/snippets/datacatalog/lineage/apiv1/snippet_metadata.google.cloud.datacatalog.lineage.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/datacatalog/lineage/apiv1", - "version": "1.24.0", + "version": "1.24.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/dialogflow/apiv2/snippet_metadata.google.cloud.dialogflow.v2.json b/internal/generated/snippets/dialogflow/apiv2/snippet_metadata.google.cloud.dialogflow.v2.json index a1cd9103e7ad..fea81c00c880 100644 --- a/internal/generated/snippets/dialogflow/apiv2/snippet_metadata.google.cloud.dialogflow.v2.json +++ b/internal/generated/snippets/dialogflow/apiv2/snippet_metadata.google.cloud.dialogflow.v2.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/dialogflow/apiv2", - "version": "1.63.0", + "version": "1.64.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/snippet_metadata.google.cloud.dialogflow.v2beta1.json b/internal/generated/snippets/dialogflow/apiv2beta1/snippet_metadata.google.cloud.dialogflow.v2beta1.json index 9f78b5a2848d..d1a67d738926 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/snippet_metadata.google.cloud.dialogflow.v2beta1.json +++ b/internal/generated/snippets/dialogflow/apiv2beta1/snippet_metadata.google.cloud.dialogflow.v2beta1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/dialogflow/apiv2beta1", - "version": "1.63.0", + "version": "1.64.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/snippet_metadata.google.cloud.dialogflow.cx.v3.json b/internal/generated/snippets/dialogflow/cx/apiv3/snippet_metadata.google.cloud.dialogflow.cx.v3.json index b783d9b7138a..1aa22a1106f0 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/snippet_metadata.google.cloud.dialogflow.cx.v3.json +++ b/internal/generated/snippets/dialogflow/cx/apiv3/snippet_metadata.google.cloud.dialogflow.cx.v3.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/dialogflow/cx/apiv3", - "version": "1.63.0", + "version": "1.64.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/snippet_metadata.google.cloud.dialogflow.cx.v3beta1.json b/internal/generated/snippets/dialogflow/cx/apiv3beta1/snippet_metadata.google.cloud.dialogflow.cx.v3beta1.json index 1bdd4c61e87b..e855836fd71f 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/snippet_metadata.google.cloud.dialogflow.cx.v3beta1.json +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/snippet_metadata.google.cloud.dialogflow.cx.v3beta1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/dialogflow/cx/apiv3beta1", - "version": "1.63.0", + "version": "1.64.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/kms/apiv1/snippet_metadata.google.cloud.kms.v1.json b/internal/generated/snippets/kms/apiv1/snippet_metadata.google.cloud.kms.v1.json index dc10be03483f..ccc8c6d6ac4b 100644 --- a/internal/generated/snippets/kms/apiv1/snippet_metadata.google.cloud.kms.v1.json +++ b/internal/generated/snippets/kms/apiv1/snippet_metadata.google.cloud.kms.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/kms/apiv1", - "version": "1.20.2", + "version": "1.20.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/kms/inventory/apiv1/snippet_metadata.google.cloud.kms.inventory.v1.json b/internal/generated/snippets/kms/inventory/apiv1/snippet_metadata.google.cloud.kms.inventory.v1.json index 04dd2fb208fa..01d519a3fbf0 100644 --- a/internal/generated/snippets/kms/inventory/apiv1/snippet_metadata.google.cloud.kms.inventory.v1.json +++ b/internal/generated/snippets/kms/inventory/apiv1/snippet_metadata.google.cloud.kms.inventory.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/kms/inventory/apiv1", - "version": "1.20.2", + "version": "1.20.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/memorystore/apiv1/snippet_metadata.google.cloud.memorystore.v1.json b/internal/generated/snippets/memorystore/apiv1/snippet_metadata.google.cloud.memorystore.v1.json index f4a4323c2ef3..d7ebc091e120 100644 --- a/internal/generated/snippets/memorystore/apiv1/snippet_metadata.google.cloud.memorystore.v1.json +++ b/internal/generated/snippets/memorystore/apiv1/snippet_metadata.google.cloud.memorystore.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/memorystore/apiv1", - "version": "0.0.0", + "version": "0.1.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/memorystore/apiv1beta/snippet_metadata.google.cloud.memorystore.v1beta.json b/internal/generated/snippets/memorystore/apiv1beta/snippet_metadata.google.cloud.memorystore.v1beta.json index b6101fbbd94d..e618b9f2e7b9 100644 --- a/internal/generated/snippets/memorystore/apiv1beta/snippet_metadata.google.cloud.memorystore.v1beta.json +++ b/internal/generated/snippets/memorystore/apiv1beta/snippet_metadata.google.cloud.memorystore.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/memorystore/apiv1beta", - "version": "0.0.0", + "version": "0.1.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/shopping/css/apiv1/CssProductInputsClient/UpdateCssProductInput/main.go b/internal/generated/snippets/shopping/css/apiv1/CssProductInputsClient/UpdateCssProductInput/main.go new file mode 100644 index 000000000000..20cf9fa8c5e2 --- /dev/null +++ b/internal/generated/snippets/shopping/css/apiv1/CssProductInputsClient/UpdateCssProductInput/main.go @@ -0,0 +1,53 @@ +// Copyright 2024 Google LLC +// +// Licensed under the Apache License, Version 2.0 (the "License"); +// you may not use this file except in compliance with the License. +// You may obtain a copy of the License at +// +// https://www.apache.org/licenses/LICENSE-2.0 +// +// Unless required by applicable law or agreed to in writing, software +// distributed under the License is distributed on an "AS IS" BASIS, +// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. +// See the License for the specific language governing permissions and +// limitations under the License. + +// Code generated by protoc-gen-go_gapic. DO NOT EDIT. + +// [START css_v1_generated_CssProductInputsService_UpdateCssProductInput_sync] + +package main + +import ( + "context" + + css "cloud.google.com/go/shopping/css/apiv1" + csspb "cloud.google.com/go/shopping/css/apiv1/csspb" +) + +func main() { + ctx := context.Background() + // This snippet has been automatically generated and should be regarded as a code template only. + // It will require modifications to work: + // - It may require correct/in-range values for request initialization. + // - It may require specifying regional endpoints when creating the service client as shown in: + // https://pkg.go.dev/cloud.google.com/go#hdr-Client_Options + c, err := css.NewCssProductInputsClient(ctx) + if err != nil { + // TODO: Handle error. + } + defer c.Close() + + req := &csspb.UpdateCssProductInputRequest{ + // TODO: Fill request struct fields. + // See https://pkg.go.dev/cloud.google.com/go/shopping/css/apiv1/csspb#UpdateCssProductInputRequest. + } + resp, err := c.UpdateCssProductInput(ctx, req) + if err != nil { + // TODO: Handle error. + } + // TODO: Use resp. + _ = resp +} + +// [END css_v1_generated_CssProductInputsService_UpdateCssProductInput_sync] diff --git a/internal/generated/snippets/shopping/css/apiv1/snippet_metadata.google.shopping.css.v1.json b/internal/generated/snippets/shopping/css/apiv1/snippet_metadata.google.shopping.css.v1.json index f42543067ca4..9ac603052400 100644 --- a/internal/generated/snippets/shopping/css/apiv1/snippet_metadata.google.shopping.css.v1.json +++ b/internal/generated/snippets/shopping/css/apiv1/snippet_metadata.google.shopping.css.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/shopping/css/apiv1", - "version": "0.13.0", + "version": "0.14.0", "language": "GO", "apis": [ { @@ -423,6 +423,52 @@ } ] }, + { + "regionTag": "css_v1_generated_CssProductInputsService_UpdateCssProductInput_sync", + "title": "css UpdateCssProductInput Sample", + "description": "UpdateCssProductInput updates the existing Css Product input in your CSS Center account.\n\nAfter inserting, updating, or deleting a CSS Product input, it may take\nseveral minutes before the processed Css Product can be retrieved.", + "file": "CssProductInputsClient/UpdateCssProductInput/main.go", + "language": "GO", + "clientMethod": { + "shortName": "UpdateCssProductInput", + "fullName": "google.shopping.css.v1.CssProductInputsClient.UpdateCssProductInput", + "parameters": [ + { + "type": "context.Context", + "name": "ctx" + }, + { + "type": "csspb.UpdateCssProductInputRequest", + "name": "req" + }, + { + "type": "...gax.CallOption", + "name": "opts" + } + ], + "resultType": "*csspb.CssProductInput", + "client": { + "shortName": "CssProductInputsClient", + "fullName": "google.shopping.css.v1.CssProductInputsClient" + }, + "method": { + "shortName": "UpdateCssProductInput", + "fullName": "google.shopping.css.v1.CssProductInputsService.UpdateCssProductInput", + "service": { + "shortName": "CssProductInputsService", + "fullName": "google.shopping.css.v1.CssProductInputsService" + } + } + }, + "origin": "API_DEFINITION", + "segments": [ + { + "start": 18, + "end": 53, + "type": "FULL" + } + ] + }, { "regionTag": "css_v1_generated_CssProductsService_GetCssProduct_sync", "title": "css GetCssProduct Sample", diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/snippet_metadata.google.shopping.merchant.accounts.v1beta.json b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/snippet_metadata.google.shopping.merchant.accounts.v1beta.json index 167845d3fede..bd4da6d17fa5 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/snippet_metadata.google.shopping.merchant.accounts.v1beta.json +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/snippet_metadata.google.shopping.merchant.accounts.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/shopping/merchant/accounts/apiv1beta", - "version": "0.13.0", + "version": "0.14.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/snippet_metadata.google.shopping.merchant.conversions.v1beta.json b/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/snippet_metadata.google.shopping.merchant.conversions.v1beta.json index 54aec41b67a2..4e9edbec6b28 100644 --- a/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/snippet_metadata.google.shopping.merchant.conversions.v1beta.json +++ b/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/snippet_metadata.google.shopping.merchant.conversions.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/shopping/merchant/conversions/apiv1beta", - "version": "0.13.0", + "version": "0.14.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/snippet_metadata.google.shopping.merchant.datasources.v1beta.json b/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/snippet_metadata.google.shopping.merchant.datasources.v1beta.json index dbdcd5ac2b8e..3b091c1b9f69 100644 --- a/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/snippet_metadata.google.shopping.merchant.datasources.v1beta.json +++ b/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/snippet_metadata.google.shopping.merchant.datasources.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/shopping/merchant/datasources/apiv1beta", - "version": "0.13.0", + "version": "0.14.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/snippet_metadata.google.shopping.merchant.inventories.v1beta.json b/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/snippet_metadata.google.shopping.merchant.inventories.v1beta.json index f164129a4bc4..10c2a54c3ebf 100644 --- a/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/snippet_metadata.google.shopping.merchant.inventories.v1beta.json +++ b/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/snippet_metadata.google.shopping.merchant.inventories.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/shopping/merchant/inventories/apiv1beta", - "version": "0.13.0", + "version": "0.14.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/snippet_metadata.google.shopping.merchant.lfp.v1beta.json b/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/snippet_metadata.google.shopping.merchant.lfp.v1beta.json index e48290d4579f..7030d0730588 100644 --- a/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/snippet_metadata.google.shopping.merchant.lfp.v1beta.json +++ b/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/snippet_metadata.google.shopping.merchant.lfp.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/shopping/merchant/lfp/apiv1beta", - "version": "0.13.0", + "version": "0.14.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/shopping/merchant/notifications/apiv1beta/snippet_metadata.google.shopping.merchant.notifications.v1beta.json b/internal/generated/snippets/shopping/merchant/notifications/apiv1beta/snippet_metadata.google.shopping.merchant.notifications.v1beta.json index bf2985873647..753f0ba8b393 100644 --- a/internal/generated/snippets/shopping/merchant/notifications/apiv1beta/snippet_metadata.google.shopping.merchant.notifications.v1beta.json +++ b/internal/generated/snippets/shopping/merchant/notifications/apiv1beta/snippet_metadata.google.shopping.merchant.notifications.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/shopping/merchant/notifications/apiv1beta", - "version": "0.13.0", + "version": "0.14.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/shopping/merchant/products/apiv1beta/snippet_metadata.google.shopping.merchant.products.v1beta.json b/internal/generated/snippets/shopping/merchant/products/apiv1beta/snippet_metadata.google.shopping.merchant.products.v1beta.json index 631882b49c40..f978446e03fc 100644 --- a/internal/generated/snippets/shopping/merchant/products/apiv1beta/snippet_metadata.google.shopping.merchant.products.v1beta.json +++ b/internal/generated/snippets/shopping/merchant/products/apiv1beta/snippet_metadata.google.shopping.merchant.products.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/shopping/merchant/products/apiv1beta", - "version": "0.13.0", + "version": "0.14.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/shopping/merchant/promotions/apiv1beta/snippet_metadata.google.shopping.merchant.promotions.v1beta.json b/internal/generated/snippets/shopping/merchant/promotions/apiv1beta/snippet_metadata.google.shopping.merchant.promotions.v1beta.json index c8fc896eb945..e5132b00e628 100644 --- a/internal/generated/snippets/shopping/merchant/promotions/apiv1beta/snippet_metadata.google.shopping.merchant.promotions.v1beta.json +++ b/internal/generated/snippets/shopping/merchant/promotions/apiv1beta/snippet_metadata.google.shopping.merchant.promotions.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/shopping/merchant/promotions/apiv1beta", - "version": "0.13.0", + "version": "0.14.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/shopping/merchant/quota/apiv1beta/snippet_metadata.google.shopping.merchant.quota.v1beta.json b/internal/generated/snippets/shopping/merchant/quota/apiv1beta/snippet_metadata.google.shopping.merchant.quota.v1beta.json index f7160d2c7575..dbdaa55831bb 100644 --- a/internal/generated/snippets/shopping/merchant/quota/apiv1beta/snippet_metadata.google.shopping.merchant.quota.v1beta.json +++ b/internal/generated/snippets/shopping/merchant/quota/apiv1beta/snippet_metadata.google.shopping.merchant.quota.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/shopping/merchant/quota/apiv1beta", - "version": "0.13.0", + "version": "0.14.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/shopping/merchant/reports/apiv1beta/snippet_metadata.google.shopping.merchant.reports.v1beta.json b/internal/generated/snippets/shopping/merchant/reports/apiv1beta/snippet_metadata.google.shopping.merchant.reports.v1beta.json index efedfa3c57cc..ba803529fec3 100644 --- a/internal/generated/snippets/shopping/merchant/reports/apiv1beta/snippet_metadata.google.shopping.merchant.reports.v1beta.json +++ b/internal/generated/snippets/shopping/merchant/reports/apiv1beta/snippet_metadata.google.shopping.merchant.reports.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/shopping/merchant/reports/apiv1beta", - "version": "0.13.0", + "version": "0.14.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/snippet_metadata.google.shopping.merchant.reviews.v1beta.json b/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/snippet_metadata.google.shopping.merchant.reviews.v1beta.json index b58b8b3d2b4b..0e5fdb20bfab 100644 --- a/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/snippet_metadata.google.shopping.merchant.reviews.v1beta.json +++ b/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/snippet_metadata.google.shopping.merchant.reviews.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/shopping/merchant/reviews/apiv1beta", - "version": "0.13.0", + "version": "0.14.0", "language": "GO", "apis": [ { diff --git a/servicehealth/apiv1/servicehealthpb/event_resources.pb.go b/servicehealth/apiv1/servicehealthpb/event_resources.pb.go index 174eba14ff9f..fa5296635a91 100755 --- a/servicehealth/apiv1/servicehealthpb/event_resources.pb.go +++ b/servicehealth/apiv1/servicehealthpb/event_resources.pb.go @@ -1451,7 +1451,7 @@ func (x *Asset) GetAssetType() string { return "" } -// Message for requesting list of events. +// Requests list of events. type ListEventsRequest struct { state protoimpl.MessageState sizeCache protoimpl.SizeCache @@ -1563,7 +1563,7 @@ func (x *ListEventsRequest) GetView() EventView { return EventView_EVENT_VIEW_UNSPECIFIED } -// Message for response to listing events. +// Response to request for listing events. type ListEventsResponse struct { state protoimpl.MessageState sizeCache protoimpl.SizeCache @@ -1632,7 +1632,7 @@ func (x *ListEventsResponse) GetUnreachable() []string { return nil } -// Message for getting an event. +// Gets information about a specific event. type GetEventRequest struct { state protoimpl.MessageState sizeCache protoimpl.SizeCache @@ -1685,7 +1685,7 @@ func (x *GetEventRequest) GetName() string { return "" } -// Message for requesting list of organization events. +// Requests list of events that affect an organization. type ListOrganizationEventsRequest struct { state protoimpl.MessageState sizeCache protoimpl.SizeCache @@ -1802,7 +1802,7 @@ func (x *ListOrganizationEventsRequest) GetView() OrganizationEventView { return OrganizationEventView_ORGANIZATION_EVENT_VIEW_UNSPECIFIED } -// Message for response to listing organization events. +// Response to request for listing organization events. type ListOrganizationEventsResponse struct { state protoimpl.MessageState sizeCache protoimpl.SizeCache @@ -1871,7 +1871,7 @@ func (x *ListOrganizationEventsResponse) GetUnreachable() []string { return nil } -// Message for getting an organization event. +// Gets information about a specific event affecting an organization. type GetOrganizationEventRequest struct { state protoimpl.MessageState sizeCache protoimpl.SizeCache @@ -1926,7 +1926,7 @@ func (x *GetOrganizationEventRequest) GetName() string { return "" } -// Message for requesting list of organization impacts. +// Requests list of projects under an organization affected by an event. type ListOrganizationImpactsRequest struct { state protoimpl.MessageState sizeCache protoimpl.SizeCache @@ -2035,7 +2035,8 @@ func (x *ListOrganizationImpactsRequest) GetFilter() string { return "" } -// Message for response to listing organization impacts. +// Response to request for listing projects under an organization affected by an +// event. type ListOrganizationImpactsResponse struct { state protoimpl.MessageState sizeCache protoimpl.SizeCache @@ -2106,7 +2107,7 @@ func (x *ListOrganizationImpactsResponse) GetUnreachable() []string { return nil } -// Message for getting an organization impact. +// Gets information about an event that affects a project under an organization. type GetOrganizationImpactRequest struct { state protoimpl.MessageState sizeCache protoimpl.SizeCache diff --git a/shopping/css/apiv1/css_product_inputs_client.go b/shopping/css/apiv1/css_product_inputs_client.go index f11b3684583c..5eddb8064e5e 100755 --- a/shopping/css/apiv1/css_product_inputs_client.go +++ b/shopping/css/apiv1/css_product_inputs_client.go @@ -41,6 +41,7 @@ var newCssProductInputsClientHook clientHook // CssProductInputsCallOptions contains the retry settings for each method of CssProductInputsClient. type CssProductInputsCallOptions struct { InsertCssProductInput []gax.CallOption + UpdateCssProductInput []gax.CallOption DeleteCssProductInput []gax.CallOption } @@ -64,6 +65,9 @@ func defaultCssProductInputsCallOptions() *CssProductInputsCallOptions { InsertCssProductInput: []gax.CallOption{ gax.WithTimeout(60000 * time.Millisecond), }, + UpdateCssProductInput: []gax.CallOption{ + gax.WithTimeout(60000 * time.Millisecond), + }, DeleteCssProductInput: []gax.CallOption{ gax.WithTimeout(60000 * time.Millisecond), }, @@ -75,6 +79,9 @@ func defaultCssProductInputsRESTCallOptions() *CssProductInputsCallOptions { InsertCssProductInput: []gax.CallOption{ gax.WithTimeout(60000 * time.Millisecond), }, + UpdateCssProductInput: []gax.CallOption{ + gax.WithTimeout(60000 * time.Millisecond), + }, DeleteCssProductInput: []gax.CallOption{ gax.WithTimeout(60000 * time.Millisecond), }, @@ -87,6 +94,7 @@ type internalCssProductInputsClient interface { setGoogleClientInfo(...string) Connection() *grpc.ClientConn InsertCssProductInput(context.Context, *csspb.InsertCssProductInputRequest, ...gax.CallOption) (*csspb.CssProductInput, error) + UpdateCssProductInput(context.Context, *csspb.UpdateCssProductInputRequest, ...gax.CallOption) (*csspb.CssProductInput, error) DeleteCssProductInput(context.Context, *csspb.DeleteCssProductInputRequest, ...gax.CallOption) error } @@ -136,6 +144,14 @@ func (c *CssProductInputsClient) InsertCssProductInput(ctx context.Context, req return c.internalClient.InsertCssProductInput(ctx, req, opts...) } +// UpdateCssProductInput updates the existing Css Product input in your CSS Center account. +// +// After inserting, updating, or deleting a CSS Product input, it may take +// several minutes before the processed Css Product can be retrieved. +func (c *CssProductInputsClient) UpdateCssProductInput(ctx context.Context, req *csspb.UpdateCssProductInputRequest, opts ...gax.CallOption) (*csspb.CssProductInput, error) { + return c.internalClient.UpdateCssProductInput(ctx, req, opts...) +} + // DeleteCssProductInput deletes a CSS Product input from your CSS Center account. // // After a delete it may take several minutes until the input is no longer @@ -317,6 +333,24 @@ func (c *cssProductInputsGRPCClient) InsertCssProductInput(ctx context.Context, return resp, nil } +func (c *cssProductInputsGRPCClient) UpdateCssProductInput(ctx context.Context, req *csspb.UpdateCssProductInputRequest, opts ...gax.CallOption) (*csspb.CssProductInput, error) { + hds := []string{"x-goog-request-params", fmt.Sprintf("%s=%v", "css_product_input.name", url.QueryEscape(req.GetCssProductInput().GetName()))} + + hds = append(c.xGoogHeaders, hds...) + ctx = gax.InsertMetadataIntoOutgoingContext(ctx, hds...) + opts = append((*c.CallOptions).UpdateCssProductInput[0:len((*c.CallOptions).UpdateCssProductInput):len((*c.CallOptions).UpdateCssProductInput)], opts...) + var resp *csspb.CssProductInput + err := gax.Invoke(ctx, func(ctx context.Context, settings gax.CallSettings) error { + var err error + resp, err = executeRPC(ctx, c.cssProductInputsClient.UpdateCssProductInput, req, settings.GRPC, c.logger, "UpdateCssProductInput") + return err + }, opts...) + if err != nil { + return nil, err + } + return resp, nil +} + func (c *cssProductInputsGRPCClient) DeleteCssProductInput(ctx context.Context, req *csspb.DeleteCssProductInputRequest, opts ...gax.CallOption) error { hds := []string{"x-goog-request-params", fmt.Sprintf("%s=%v", "name", url.QueryEscape(req.GetName()))} @@ -353,7 +387,9 @@ func (c *cssProductInputsRESTClient) InsertCssProductInput(ctx context.Context, params := url.Values{} params.Add("$alt", "json;enum-encoding=int") - params.Add("feedId", fmt.Sprintf("%v", req.GetFeedId())) + if req.GetFeedId() != 0 { + params.Add("feedId", fmt.Sprintf("%v", req.GetFeedId())) + } baseUrl.RawQuery = params.Encode() @@ -394,6 +430,73 @@ func (c *cssProductInputsRESTClient) InsertCssProductInput(ctx context.Context, return resp, nil } +// UpdateCssProductInput updates the existing Css Product input in your CSS Center account. +// +// After inserting, updating, or deleting a CSS Product input, it may take +// several minutes before the processed Css Product can be retrieved. +func (c *cssProductInputsRESTClient) UpdateCssProductInput(ctx context.Context, req *csspb.UpdateCssProductInputRequest, opts ...gax.CallOption) (*csspb.CssProductInput, error) { + m := protojson.MarshalOptions{AllowPartial: true, UseEnumNumbers: true} + body := req.GetCssProductInput() + jsonReq, err := m.Marshal(body) + if err != nil { + return nil, err + } + + baseUrl, err := url.Parse(c.endpoint) + if err != nil { + return nil, err + } + baseUrl.Path += fmt.Sprintf("/v1/%v", req.GetCssProductInput().GetName()) + + params := url.Values{} + params.Add("$alt", "json;enum-encoding=int") + if req.GetUpdateMask() != nil { + field, err := protojson.Marshal(req.GetUpdateMask()) + if err != nil { + return nil, err + } + params.Add("updateMask", string(field[1:len(field)-1])) + } + + baseUrl.RawQuery = params.Encode() + + // Build HTTP headers from client and context metadata. + hds := []string{"x-goog-request-params", fmt.Sprintf("%s=%v", "css_product_input.name", url.QueryEscape(req.GetCssProductInput().GetName()))} + + hds = append(c.xGoogHeaders, hds...) + hds = append(hds, "Content-Type", "application/json") + headers := gax.BuildHeaders(ctx, hds...) + opts = append((*c.CallOptions).UpdateCssProductInput[0:len((*c.CallOptions).UpdateCssProductInput):len((*c.CallOptions).UpdateCssProductInput)], opts...) + unm := protojson.UnmarshalOptions{AllowPartial: true, DiscardUnknown: true} + resp := &csspb.CssProductInput{} + e := gax.Invoke(ctx, func(ctx context.Context, settings gax.CallSettings) error { + if settings.Path != "" { + baseUrl.Path = settings.Path + } + httpReq, err := http.NewRequest("PATCH", baseUrl.String(), bytes.NewReader(jsonReq)) + if err != nil { + return err + } + httpReq = httpReq.WithContext(ctx) + httpReq.Header = headers + + buf, err := executeHTTPRequest(ctx, c.httpClient, httpReq, c.logger, jsonReq, "UpdateCssProductInput") + if err != nil { + return err + } + + if err := unm.Unmarshal(buf, resp); err != nil { + return err + } + + return nil + }, opts...) + if e != nil { + return nil, e + } + return resp, nil +} + // DeleteCssProductInput deletes a CSS Product input from your CSS Center account. // // After a delete it may take several minutes until the input is no longer diff --git a/shopping/css/apiv1/css_product_inputs_client_example_test.go b/shopping/css/apiv1/css_product_inputs_client_example_test.go index 7b706251de05..847984991c09 100644 --- a/shopping/css/apiv1/css_product_inputs_client_example_test.go +++ b/shopping/css/apiv1/css_product_inputs_client_example_test.go @@ -104,3 +104,28 @@ func ExampleCssProductInputsClient_InsertCssProductInput() { // TODO: Use resp. _ = resp } + +func ExampleCssProductInputsClient_UpdateCssProductInput() { + ctx := context.Background() + // This snippet has been automatically generated and should be regarded as a code template only. + // It will require modifications to work: + // - It may require correct/in-range values for request initialization. + // - It may require specifying regional endpoints when creating the service client as shown in: + // https://pkg.go.dev/cloud.google.com/go#hdr-Client_Options + c, err := css.NewCssProductInputsClient(ctx) + if err != nil { + // TODO: Handle error. + } + defer c.Close() + + req := &csspb.UpdateCssProductInputRequest{ + // TODO: Fill request struct fields. + // See https://pkg.go.dev/cloud.google.com/go/shopping/css/apiv1/csspb#UpdateCssProductInputRequest. + } + resp, err := c.UpdateCssProductInput(ctx, req) + if err != nil { + // TODO: Handle error. + } + // TODO: Use resp. + _ = resp +} diff --git a/shopping/css/apiv1/csspb/accounts.pb.go b/shopping/css/apiv1/csspb/accounts.pb.go index 9ffbc5d498a8..fc6a335e612e 100755 --- a/shopping/css/apiv1/csspb/accounts.pb.go +++ b/shopping/css/apiv1/csspb/accounts.pb.go @@ -133,8 +133,8 @@ type ListChildAccountsRequest struct { FullName *string `protobuf:"bytes,3,opt,name=full_name,json=fullName,proto3,oneof" json:"full_name,omitempty"` // Optional. The maximum number of accounts to return. The service may return // fewer than this value. If unspecified, at most 50 accounts will be - // returned. The maximum value is 1000; values above 1000 will be coerced to - // 1000. + // returned. The maximum value is 100; values above 100 will be coerced to + // 100. PageSize int32 `protobuf:"varint,4,opt,name=page_size,json=pageSize,proto3" json:"page_size,omitempty"` // Optional. A page token, received from a previous `ListChildAccounts` call. // Provide this to retrieve the subsequent page. diff --git a/shopping/css/apiv1/csspb/css_product_common.pb.go b/shopping/css/apiv1/csspb/css_product_common.pb.go index fd774ab22510..29f365b32d1b 100755 --- a/shopping/css/apiv1/csspb/css_product_common.pb.go +++ b/shopping/css/apiv1/csspb/css_product_common.pb.go @@ -104,21 +104,21 @@ type Attributes struct { // Allows advertisers to override the item URL when the product is shown // within the context of Product Ads. CppAdsRedirect *string `protobuf:"bytes,42,opt,name=cpp_ads_redirect,json=cppAdsRedirect,proto3,oneof" json:"cpp_ads_redirect,omitempty"` - // Low Price of the aggregate offer. + // Low Price of the CSS Product. LowPrice *typepb.Price `protobuf:"bytes,3,opt,name=low_price,json=lowPrice,proto3" json:"low_price,omitempty"` - // High Price of the aggregate offer. + // High Price of the CSS Product. HighPrice *typepb.Price `protobuf:"bytes,4,opt,name=high_price,json=highPrice,proto3" json:"high_price,omitempty"` - // The number of aggregate offers. + // The number of CSS Products. NumberOfOffers *int64 `protobuf:"varint,5,opt,name=number_of_offers,json=numberOfOffers,proto3,oneof" json:"number_of_offers,omitempty"` // Condition of the headline offer. HeadlineOfferCondition *string `protobuf:"bytes,6,opt,name=headline_offer_condition,json=headlineOfferCondition,proto3,oneof" json:"headline_offer_condition,omitempty"` - // Headline Price of the aggregate offer. + // Headline Price of the CSS Product. HeadlineOfferPrice *typepb.Price `protobuf:"bytes,7,opt,name=headline_offer_price,json=headlineOfferPrice,proto3" json:"headline_offer_price,omitempty"` // Link to the headline offer. HeadlineOfferLink *string `protobuf:"bytes,8,opt,name=headline_offer_link,json=headlineOfferLink,proto3,oneof" json:"headline_offer_link,omitempty"` // Mobile Link to the headline offer. HeadlineOfferMobileLink *string `protobuf:"bytes,9,opt,name=headline_offer_mobile_link,json=headlineOfferMobileLink,proto3,oneof" json:"headline_offer_mobile_link,omitempty"` - // Headline Price of the aggregate offer. + // Headline Price of the CSS Product. HeadlineOfferShippingPrice *typepb.Price `protobuf:"bytes,41,opt,name=headline_offer_shipping_price,json=headlineOfferShippingPrice,proto3" json:"headline_offer_shipping_price,omitempty"` // Title of the item. Title *string `protobuf:"bytes,10,opt,name=title,proto3,oneof" json:"title,omitempty"` @@ -1099,13 +1099,13 @@ type CssProductStatus_DestinationStatus struct { // The name of the destination Destination string `protobuf:"bytes,1,opt,name=destination,proto3" json:"destination,omitempty"` - // List of country codes (ISO 3166-1 alpha-2) where the aggregate offer is + // List of country codes (ISO 3166-1 alpha-2) where the CSS Product is // approved. ApprovedCountries []string `protobuf:"bytes,2,rep,name=approved_countries,json=approvedCountries,proto3" json:"approved_countries,omitempty"` - // List of country codes (ISO 3166-1 alpha-2) where the aggregate offer is + // List of country codes (ISO 3166-1 alpha-2) where the CSS Product is // pending approval. PendingCountries []string `protobuf:"bytes,3,rep,name=pending_countries,json=pendingCountries,proto3" json:"pending_countries,omitempty"` - // List of country codes (ISO 3166-1 alpha-2) where the aggregate offer is + // List of country codes (ISO 3166-1 alpha-2) where the CSS Product is // disapproved. DisapprovedCountries []string `protobuf:"bytes,4,rep,name=disapproved_countries,json=disapprovedCountries,proto3" json:"disapproved_countries,omitempty"` } @@ -1176,7 +1176,7 @@ type CssProductStatus_ItemLevelIssue struct { // The error code of the issue. Code string `protobuf:"bytes,1,opt,name=code,proto3" json:"code,omitempty"` - // How this issue affects serving of the aggregate offer. + // How this issue affects serving of the CSS Product. Servability string `protobuf:"bytes,2,opt,name=servability,proto3" json:"servability,omitempty"` // Whether the issue can be resolved by the merchant. Resolution string `protobuf:"bytes,3,opt,name=resolution,proto3" json:"resolution,omitempty"` @@ -1191,7 +1191,7 @@ type CssProductStatus_ItemLevelIssue struct { // The URL of a web page to help with resolving this issue. Documentation string `protobuf:"bytes,8,opt,name=documentation,proto3" json:"documentation,omitempty"` // List of country codes (ISO 3166-1 alpha-2) where issue applies to the - // aggregate offer. + // CSS Product. ApplicableCountries []string `protobuf:"bytes,9,rep,name=applicable_countries,json=applicableCountries,proto3" json:"applicable_countries,omitempty"` } diff --git a/shopping/css/apiv1/csspb/css_product_inputs.pb.go b/shopping/css/apiv1/csspb/css_product_inputs.pb.go index db763762cecf..791ce0426e23 100755 --- a/shopping/css/apiv1/csspb/css_product_inputs.pb.go +++ b/shopping/css/apiv1/csspb/css_product_inputs.pb.go @@ -33,6 +33,7 @@ import ( protoreflect "google.golang.org/protobuf/reflect/protoreflect" protoimpl "google.golang.org/protobuf/runtime/protoimpl" emptypb "google.golang.org/protobuf/types/known/emptypb" + fieldmaskpb "google.golang.org/protobuf/types/known/fieldmaskpb" timestamppb "google.golang.org/protobuf/types/known/timestamppb" ) @@ -76,6 +77,7 @@ type CssProductInput struct { // Feed Label is synonymous to "target country" and hence should always be a // valid region code. For example: 'DE' for Germany, 'FR' for France. FeedLabel string `protobuf:"bytes,5,opt,name=feed_label,json=feedLabel,proto3" json:"feed_label,omitempty"` + // DEPRECATED. Use expiration_date instead. // Represents the existing version (freshness) of the CSS Product, which // can be used to preserve the right order when multiple updates are done at // the same time. @@ -93,6 +95,8 @@ type CssProductInput struct { // // If the operation is prevented, the aborted exception will be // thrown. + // + // Deprecated: Marked as deprecated in google/shopping/css/v1/css_product_inputs.proto. FreshnessTime *timestamppb.Timestamp `protobuf:"bytes,6,opt,name=freshness_time,json=freshnessTime,proto3" json:"freshness_time,omitempty"` // A list of CSS Product attributes. Attributes *Attributes `protobuf:"bytes,7,opt,name=attributes,proto3" json:"attributes,omitempty"` @@ -170,6 +174,7 @@ func (x *CssProductInput) GetFeedLabel() string { return "" } +// Deprecated: Marked as deprecated in google/shopping/css/v1/css_product_inputs.proto. func (x *CssProductInput) GetFreshnessTime() *timestamppb.Timestamp { if x != nil { return x.FreshnessTime @@ -202,11 +207,15 @@ type InsertCssProductInputRequest struct { Parent string `protobuf:"bytes,1,opt,name=parent,proto3" json:"parent,omitempty"` // Required. The CSS Product Input to insert. CssProductInput *CssProductInput `protobuf:"bytes,2,opt,name=css_product_input,json=cssProductInput,proto3" json:"css_product_input,omitempty"` - // Required. The primary or supplemental feed id. If CSS Product already - // exists and feed id provided is different, then the CSS Product will be - // moved to a new feed. Note: For now, CSSs do not need to provide feed ids as - // we create feeds on the fly. We do not have supplemental feed support for - // CSS Products yet. + // Optional. DEPRECATED. Feed id is not required for CSS Products. + // The primary or supplemental feed id. If CSS Product already exists and + // feed id provided is different, then the CSS Product will be moved to a + // new feed. + // Note: For now, CSSs do not need to provide feed ids as we create + // feeds on the fly. + // We do not have supplemental feed support for CSS Products yet. + // + // Deprecated: Marked as deprecated in google/shopping/css/v1/css_product_inputs.proto. FeedId int64 `protobuf:"varint,3,opt,name=feed_id,json=feedId,proto3" json:"feed_id,omitempty"` } @@ -254,6 +263,7 @@ func (x *InsertCssProductInputRequest) GetCssProductInput() *CssProductInput { return nil } +// Deprecated: Marked as deprecated in google/shopping/css/v1/css_product_inputs.proto. func (x *InsertCssProductInputRequest) GetFeedId() int64 { if x != nil { return x.FeedId @@ -261,6 +271,78 @@ func (x *InsertCssProductInputRequest) GetFeedId() int64 { return 0 } +// Request message for the UpdateCssProductInput method. +type UpdateCssProductInputRequest struct { + state protoimpl.MessageState + sizeCache protoimpl.SizeCache + unknownFields protoimpl.UnknownFields + + // Required. The CSS product input resource to update. Information you submit + // will be applied to the processed CSS product as well. + CssProductInput *CssProductInput `protobuf:"bytes,1,opt,name=css_product_input,json=cssProductInput,proto3" json:"css_product_input,omitempty"` + // The list of CSS product attributes to be updated. + // + // If the update mask is omitted, then it is treated as implied field mask + // equivalent to all fields that are populated (have a non-empty value). + // + // Attributes specified in the update mask without a value specified in the + // body will be deleted from the CSS product. + // + // Update mask can only be specified for top level fields in + // attributes and custom attributes. + // + // To specify the update mask for custom attributes you need to add the + // `custom_attribute.` prefix. + // + // Providing special "*" value for full CSS product replacement is not + // supported. + UpdateMask *fieldmaskpb.FieldMask `protobuf:"bytes,2,opt,name=update_mask,json=updateMask,proto3" json:"update_mask,omitempty"` +} + +func (x *UpdateCssProductInputRequest) Reset() { + *x = UpdateCssProductInputRequest{} + mi := &file_google_shopping_css_v1_css_product_inputs_proto_msgTypes[2] + ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) + ms.StoreMessageInfo(mi) +} + +func (x *UpdateCssProductInputRequest) String() string { + return protoimpl.X.MessageStringOf(x) +} + +func (*UpdateCssProductInputRequest) ProtoMessage() {} + +func (x *UpdateCssProductInputRequest) ProtoReflect() protoreflect.Message { + mi := &file_google_shopping_css_v1_css_product_inputs_proto_msgTypes[2] + if x != nil { + ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) + if ms.LoadMessageInfo() == nil { + ms.StoreMessageInfo(mi) + } + return ms + } + return mi.MessageOf(x) +} + +// Deprecated: Use UpdateCssProductInputRequest.ProtoReflect.Descriptor instead. +func (*UpdateCssProductInputRequest) Descriptor() ([]byte, []int) { + return file_google_shopping_css_v1_css_product_inputs_proto_rawDescGZIP(), []int{2} +} + +func (x *UpdateCssProductInputRequest) GetCssProductInput() *CssProductInput { + if x != nil { + return x.CssProductInput + } + return nil +} + +func (x *UpdateCssProductInputRequest) GetUpdateMask() *fieldmaskpb.FieldMask { + if x != nil { + return x.UpdateMask + } + return nil +} + // Request message for the DeleteCssProductInput method. type DeleteCssProductInputRequest struct { state protoimpl.MessageState @@ -279,7 +361,7 @@ type DeleteCssProductInputRequest struct { func (x *DeleteCssProductInputRequest) Reset() { *x = DeleteCssProductInputRequest{} - mi := &file_google_shopping_css_v1_css_product_inputs_proto_msgTypes[2] + mi := &file_google_shopping_css_v1_css_product_inputs_proto_msgTypes[3] ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) ms.StoreMessageInfo(mi) } @@ -291,7 +373,7 @@ func (x *DeleteCssProductInputRequest) String() string { func (*DeleteCssProductInputRequest) ProtoMessage() {} func (x *DeleteCssProductInputRequest) ProtoReflect() protoreflect.Message { - mi := &file_google_shopping_css_v1_css_product_inputs_proto_msgTypes[2] + mi := &file_google_shopping_css_v1_css_product_inputs_proto_msgTypes[3] if x != nil { ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) if ms.LoadMessageInfo() == nil { @@ -304,7 +386,7 @@ func (x *DeleteCssProductInputRequest) ProtoReflect() protoreflect.Message { // Deprecated: Use DeleteCssProductInputRequest.ProtoReflect.Descriptor instead. func (*DeleteCssProductInputRequest) Descriptor() ([]byte, []int) { - return file_google_shopping_css_v1_css_product_inputs_proto_rawDescGZIP(), []int{2} + return file_google_shopping_css_v1_css_product_inputs_proto_rawDescGZIP(), []int{3} } func (x *DeleteCssProductInputRequest) GetName() string { @@ -337,61 +419,75 @@ var file_google_shopping_css_v1_css_product_inputs_proto_rawDesc = []byte{ 0x6f, 0x1a, 0x19, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x61, 0x70, 0x69, 0x2f, 0x72, 0x65, 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x1b, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2f, 0x65, 0x6d, - 0x70, 0x74, 0x79, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x1f, 0x67, 0x6f, 0x6f, 0x67, 0x6c, - 0x65, 0x2f, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2f, 0x74, 0x69, 0x6d, 0x65, 0x73, - 0x74, 0x61, 0x6d, 0x70, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x2f, 0x67, 0x6f, 0x6f, 0x67, - 0x6c, 0x65, 0x2f, 0x73, 0x68, 0x6f, 0x70, 0x70, 0x69, 0x6e, 0x67, 0x2f, 0x63, 0x73, 0x73, 0x2f, - 0x76, 0x31, 0x2f, 0x63, 0x73, 0x73, 0x5f, 0x70, 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, 0x5f, 0x63, - 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x20, 0x67, 0x6f, 0x6f, - 0x67, 0x6c, 0x65, 0x2f, 0x73, 0x68, 0x6f, 0x70, 0x70, 0x69, 0x6e, 0x67, 0x2f, 0x74, 0x79, 0x70, - 0x65, 0x2f, 0x74, 0x79, 0x70, 0x65, 0x73, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x22, 0x87, 0x04, - 0x0a, 0x0f, 0x43, 0x73, 0x73, 0x50, 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, 0x49, 0x6e, 0x70, 0x75, - 0x74, 0x12, 0x12, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, - 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x22, 0x0a, 0x0a, 0x66, 0x69, 0x6e, 0x61, 0x6c, 0x5f, 0x6e, - 0x61, 0x6d, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x09, - 0x66, 0x69, 0x6e, 0x61, 0x6c, 0x4e, 0x61, 0x6d, 0x65, 0x12, 0x2b, 0x0a, 0x0f, 0x72, 0x61, 0x77, - 0x5f, 0x70, 0x72, 0x6f, 0x76, 0x69, 0x64, 0x65, 0x64, 0x5f, 0x69, 0x64, 0x18, 0x03, 0x20, 0x01, - 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x0d, 0x72, 0x61, 0x77, 0x50, 0x72, 0x6f, 0x76, - 0x69, 0x64, 0x65, 0x64, 0x49, 0x64, 0x12, 0x2e, 0x0a, 0x10, 0x63, 0x6f, 0x6e, 0x74, 0x65, 0x6e, - 0x74, 0x5f, 0x6c, 0x61, 0x6e, 0x67, 0x75, 0x61, 0x67, 0x65, 0x18, 0x04, 0x20, 0x01, 0x28, 0x09, - 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x0f, 0x63, 0x6f, 0x6e, 0x74, 0x65, 0x6e, 0x74, 0x4c, 0x61, - 0x6e, 0x67, 0x75, 0x61, 0x67, 0x65, 0x12, 0x22, 0x0a, 0x0a, 0x66, 0x65, 0x65, 0x64, 0x5f, 0x6c, - 0x61, 0x62, 0x65, 0x6c, 0x18, 0x05, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, - 0x09, 0x66, 0x65, 0x65, 0x64, 0x4c, 0x61, 0x62, 0x65, 0x6c, 0x12, 0x41, 0x0a, 0x0e, 0x66, 0x72, - 0x65, 0x73, 0x68, 0x6e, 0x65, 0x73, 0x73, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x18, 0x06, 0x20, 0x01, - 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, - 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x52, 0x0d, - 0x66, 0x72, 0x65, 0x73, 0x68, 0x6e, 0x65, 0x73, 0x73, 0x54, 0x69, 0x6d, 0x65, 0x12, 0x42, 0x0a, - 0x0a, 0x61, 0x74, 0x74, 0x72, 0x69, 0x62, 0x75, 0x74, 0x65, 0x73, 0x18, 0x07, 0x20, 0x01, 0x28, - 0x0b, 0x32, 0x22, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x73, 0x68, 0x6f, 0x70, 0x70, - 0x69, 0x6e, 0x67, 0x2e, 0x63, 0x73, 0x73, 0x2e, 0x76, 0x31, 0x2e, 0x41, 0x74, 0x74, 0x72, 0x69, - 0x62, 0x75, 0x74, 0x65, 0x73, 0x52, 0x0a, 0x61, 0x74, 0x74, 0x72, 0x69, 0x62, 0x75, 0x74, 0x65, - 0x73, 0x12, 0x52, 0x0a, 0x11, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x5f, 0x61, 0x74, 0x74, 0x72, - 0x69, 0x62, 0x75, 0x74, 0x65, 0x73, 0x18, 0x08, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x25, 0x2e, 0x67, - 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x73, 0x68, 0x6f, 0x70, 0x70, 0x69, 0x6e, 0x67, 0x2e, 0x74, - 0x79, 0x70, 0x65, 0x2e, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x41, 0x74, 0x74, 0x72, 0x69, 0x62, - 0x75, 0x74, 0x65, 0x52, 0x10, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x41, 0x74, 0x74, 0x72, 0x69, - 0x62, 0x75, 0x74, 0x65, 0x73, 0x3a, 0x60, 0xea, 0x41, 0x5d, 0x0a, 0x22, 0x63, 0x73, 0x73, 0x2e, - 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x43, - 0x73, 0x73, 0x50, 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, 0x49, 0x6e, 0x70, 0x75, 0x74, 0x12, 0x37, - 0x61, 0x63, 0x63, 0x6f, 0x75, 0x6e, 0x74, 0x73, 0x2f, 0x7b, 0x61, 0x63, 0x63, 0x6f, 0x75, 0x6e, - 0x74, 0x7d, 0x2f, 0x63, 0x73, 0x73, 0x50, 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, 0x49, 0x6e, 0x70, - 0x75, 0x74, 0x73, 0x2f, 0x7b, 0x63, 0x73, 0x73, 0x5f, 0x70, 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, - 0x5f, 0x69, 0x6e, 0x70, 0x75, 0x74, 0x7d, 0x22, 0xda, 0x01, 0x0a, 0x1c, 0x49, 0x6e, 0x73, 0x65, - 0x72, 0x74, 0x43, 0x73, 0x73, 0x50, 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, 0x49, 0x6e, 0x70, 0x75, - 0x74, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x42, 0x0a, 0x06, 0x70, 0x61, 0x72, 0x65, - 0x6e, 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x2a, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x24, - 0x12, 0x22, 0x63, 0x73, 0x73, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, - 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x43, 0x73, 0x73, 0x50, 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, 0x49, - 0x6e, 0x70, 0x75, 0x74, 0x52, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x12, 0x58, 0x0a, 0x11, - 0x63, 0x73, 0x73, 0x5f, 0x70, 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, 0x5f, 0x69, 0x6e, 0x70, 0x75, - 0x74, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x27, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, + 0x70, 0x74, 0x79, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x20, 0x67, 0x6f, 0x6f, 0x67, 0x6c, + 0x65, 0x2f, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2f, 0x66, 0x69, 0x65, 0x6c, 0x64, + 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x1f, 0x67, 0x6f, 0x6f, + 0x67, 0x6c, 0x65, 0x2f, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2f, 0x74, 0x69, 0x6d, + 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x2f, 0x67, 0x6f, + 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x73, 0x68, 0x6f, 0x70, 0x70, 0x69, 0x6e, 0x67, 0x2f, 0x63, 0x73, + 0x73, 0x2f, 0x76, 0x31, 0x2f, 0x63, 0x73, 0x73, 0x5f, 0x70, 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, + 0x5f, 0x63, 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x20, 0x67, + 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x73, 0x68, 0x6f, 0x70, 0x70, 0x69, 0x6e, 0x67, 0x2f, 0x74, + 0x79, 0x70, 0x65, 0x2f, 0x74, 0x79, 0x70, 0x65, 0x73, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x22, + 0x8b, 0x04, 0x0a, 0x0f, 0x43, 0x73, 0x73, 0x50, 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, 0x49, 0x6e, + 0x70, 0x75, 0x74, 0x12, 0x12, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, + 0x09, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x22, 0x0a, 0x0a, 0x66, 0x69, 0x6e, 0x61, 0x6c, + 0x5f, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x03, + 0x52, 0x09, 0x66, 0x69, 0x6e, 0x61, 0x6c, 0x4e, 0x61, 0x6d, 0x65, 0x12, 0x2b, 0x0a, 0x0f, 0x72, + 0x61, 0x77, 0x5f, 0x70, 0x72, 0x6f, 0x76, 0x69, 0x64, 0x65, 0x64, 0x5f, 0x69, 0x64, 0x18, 0x03, + 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x0d, 0x72, 0x61, 0x77, 0x50, 0x72, + 0x6f, 0x76, 0x69, 0x64, 0x65, 0x64, 0x49, 0x64, 0x12, 0x2e, 0x0a, 0x10, 0x63, 0x6f, 0x6e, 0x74, + 0x65, 0x6e, 0x74, 0x5f, 0x6c, 0x61, 0x6e, 0x67, 0x75, 0x61, 0x67, 0x65, 0x18, 0x04, 0x20, 0x01, + 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x0f, 0x63, 0x6f, 0x6e, 0x74, 0x65, 0x6e, 0x74, + 0x4c, 0x61, 0x6e, 0x67, 0x75, 0x61, 0x67, 0x65, 0x12, 0x22, 0x0a, 0x0a, 0x66, 0x65, 0x65, 0x64, + 0x5f, 0x6c, 0x61, 0x62, 0x65, 0x6c, 0x18, 0x05, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, + 0x02, 0x52, 0x09, 0x66, 0x65, 0x65, 0x64, 0x4c, 0x61, 0x62, 0x65, 0x6c, 0x12, 0x45, 0x0a, 0x0e, + 0x66, 0x72, 0x65, 0x73, 0x68, 0x6e, 0x65, 0x73, 0x73, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x18, 0x06, + 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, + 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, + 0x42, 0x02, 0x18, 0x01, 0x52, 0x0d, 0x66, 0x72, 0x65, 0x73, 0x68, 0x6e, 0x65, 0x73, 0x73, 0x54, + 0x69, 0x6d, 0x65, 0x12, 0x42, 0x0a, 0x0a, 0x61, 0x74, 0x74, 0x72, 0x69, 0x62, 0x75, 0x74, 0x65, + 0x73, 0x18, 0x07, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x22, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x73, 0x68, 0x6f, 0x70, 0x70, 0x69, 0x6e, 0x67, 0x2e, 0x63, 0x73, 0x73, 0x2e, 0x76, 0x31, - 0x2e, 0x43, 0x73, 0x73, 0x50, 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, 0x49, 0x6e, 0x70, 0x75, 0x74, - 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x0f, 0x63, 0x73, 0x73, 0x50, 0x72, 0x6f, 0x64, 0x75, 0x63, - 0x74, 0x49, 0x6e, 0x70, 0x75, 0x74, 0x12, 0x1c, 0x0a, 0x07, 0x66, 0x65, 0x65, 0x64, 0x5f, 0x69, - 0x64, 0x18, 0x03, 0x20, 0x01, 0x28, 0x03, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x06, 0x66, 0x65, - 0x65, 0x64, 0x49, 0x64, 0x22, 0xae, 0x01, 0x0a, 0x1c, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x43, + 0x2e, 0x41, 0x74, 0x74, 0x72, 0x69, 0x62, 0x75, 0x74, 0x65, 0x73, 0x52, 0x0a, 0x61, 0x74, 0x74, + 0x72, 0x69, 0x62, 0x75, 0x74, 0x65, 0x73, 0x12, 0x52, 0x0a, 0x11, 0x63, 0x75, 0x73, 0x74, 0x6f, + 0x6d, 0x5f, 0x61, 0x74, 0x74, 0x72, 0x69, 0x62, 0x75, 0x74, 0x65, 0x73, 0x18, 0x08, 0x20, 0x03, + 0x28, 0x0b, 0x32, 0x25, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x73, 0x68, 0x6f, 0x70, + 0x70, 0x69, 0x6e, 0x67, 0x2e, 0x74, 0x79, 0x70, 0x65, 0x2e, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, + 0x41, 0x74, 0x74, 0x72, 0x69, 0x62, 0x75, 0x74, 0x65, 0x52, 0x10, 0x63, 0x75, 0x73, 0x74, 0x6f, + 0x6d, 0x41, 0x74, 0x74, 0x72, 0x69, 0x62, 0x75, 0x74, 0x65, 0x73, 0x3a, 0x60, 0xea, 0x41, 0x5d, + 0x0a, 0x22, 0x63, 0x73, 0x73, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, + 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x43, 0x73, 0x73, 0x50, 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, 0x49, + 0x6e, 0x70, 0x75, 0x74, 0x12, 0x37, 0x61, 0x63, 0x63, 0x6f, 0x75, 0x6e, 0x74, 0x73, 0x2f, 0x7b, + 0x61, 0x63, 0x63, 0x6f, 0x75, 0x6e, 0x74, 0x7d, 0x2f, 0x63, 0x73, 0x73, 0x50, 0x72, 0x6f, 0x64, + 0x75, 0x63, 0x74, 0x49, 0x6e, 0x70, 0x75, 0x74, 0x73, 0x2f, 0x7b, 0x63, 0x73, 0x73, 0x5f, 0x70, + 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, 0x5f, 0x69, 0x6e, 0x70, 0x75, 0x74, 0x7d, 0x22, 0xdc, 0x01, + 0x0a, 0x1c, 0x49, 0x6e, 0x73, 0x65, 0x72, 0x74, 0x43, 0x73, 0x73, 0x50, 0x72, 0x6f, 0x64, 0x75, + 0x63, 0x74, 0x49, 0x6e, 0x70, 0x75, 0x74, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x42, + 0x0a, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x2a, + 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x24, 0x12, 0x22, 0x63, 0x73, 0x73, 0x2e, 0x67, 0x6f, 0x6f, 0x67, + 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x43, 0x73, 0x73, 0x50, 0x72, + 0x6f, 0x64, 0x75, 0x63, 0x74, 0x49, 0x6e, 0x70, 0x75, 0x74, 0x52, 0x06, 0x70, 0x61, 0x72, 0x65, + 0x6e, 0x74, 0x12, 0x58, 0x0a, 0x11, 0x63, 0x73, 0x73, 0x5f, 0x70, 0x72, 0x6f, 0x64, 0x75, 0x63, + 0x74, 0x5f, 0x69, 0x6e, 0x70, 0x75, 0x74, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x27, 0x2e, + 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x73, 0x68, 0x6f, 0x70, 0x70, 0x69, 0x6e, 0x67, 0x2e, + 0x63, 0x73, 0x73, 0x2e, 0x76, 0x31, 0x2e, 0x43, 0x73, 0x73, 0x50, 0x72, 0x6f, 0x64, 0x75, 0x63, + 0x74, 0x49, 0x6e, 0x70, 0x75, 0x74, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x0f, 0x63, 0x73, 0x73, + 0x50, 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, 0x49, 0x6e, 0x70, 0x75, 0x74, 0x12, 0x1e, 0x0a, 0x07, + 0x66, 0x65, 0x65, 0x64, 0x5f, 0x69, 0x64, 0x18, 0x03, 0x20, 0x01, 0x28, 0x03, 0x42, 0x05, 0xe0, + 0x41, 0x01, 0x18, 0x01, 0x52, 0x06, 0x66, 0x65, 0x65, 0x64, 0x49, 0x64, 0x22, 0xb5, 0x01, 0x0a, + 0x1c, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x43, 0x73, 0x73, 0x50, 0x72, 0x6f, 0x64, 0x75, 0x63, + 0x74, 0x49, 0x6e, 0x70, 0x75, 0x74, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x58, 0x0a, + 0x11, 0x63, 0x73, 0x73, 0x5f, 0x70, 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, 0x5f, 0x69, 0x6e, 0x70, + 0x75, 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x27, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, + 0x65, 0x2e, 0x73, 0x68, 0x6f, 0x70, 0x70, 0x69, 0x6e, 0x67, 0x2e, 0x63, 0x73, 0x73, 0x2e, 0x76, + 0x31, 0x2e, 0x43, 0x73, 0x73, 0x50, 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, 0x49, 0x6e, 0x70, 0x75, + 0x74, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x0f, 0x63, 0x73, 0x73, 0x50, 0x72, 0x6f, 0x64, 0x75, + 0x63, 0x74, 0x49, 0x6e, 0x70, 0x75, 0x74, 0x12, 0x3b, 0x0a, 0x0b, 0x75, 0x70, 0x64, 0x61, 0x74, + 0x65, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, + 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x46, + 0x69, 0x65, 0x6c, 0x64, 0x4d, 0x61, 0x73, 0x6b, 0x52, 0x0a, 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, + 0x4d, 0x61, 0x73, 0x6b, 0x22, 0xae, 0x01, 0x0a, 0x1c, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x43, 0x73, 0x73, 0x50, 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, 0x49, 0x6e, 0x70, 0x75, 0x74, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x3e, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x2a, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x24, 0x0a, 0x22, 0x63, 0x73, 0x73, @@ -402,7 +498,7 @@ var file_google_shopping_css_v1_css_product_inputs_proto_rawDesc = []byte{ 0x01, 0x28, 0x03, 0x48, 0x00, 0x52, 0x12, 0x73, 0x75, 0x70, 0x70, 0x6c, 0x65, 0x6d, 0x65, 0x6e, 0x74, 0x61, 0x6c, 0x46, 0x65, 0x65, 0x64, 0x49, 0x64, 0x88, 0x01, 0x01, 0x42, 0x17, 0x0a, 0x15, 0x5f, 0x73, 0x75, 0x70, 0x70, 0x6c, 0x65, 0x6d, 0x65, 0x6e, 0x74, 0x61, 0x6c, 0x5f, 0x66, 0x65, - 0x65, 0x64, 0x5f, 0x69, 0x64, 0x32, 0xc0, 0x03, 0x0a, 0x17, 0x43, 0x73, 0x73, 0x50, 0x72, 0x6f, + 0x65, 0x64, 0x5f, 0x69, 0x64, 0x32, 0xb0, 0x05, 0x0a, 0x17, 0x43, 0x73, 0x73, 0x50, 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, 0x49, 0x6e, 0x70, 0x75, 0x74, 0x73, 0x53, 0x65, 0x72, 0x76, 0x69, 0x63, 0x65, 0x12, 0xc2, 0x01, 0x0a, 0x15, 0x49, 0x6e, 0x73, 0x65, 0x72, 0x74, 0x43, 0x73, 0x73, 0x50, 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, 0x49, 0x6e, 0x70, 0x75, 0x74, 0x12, 0x34, 0x2e, 0x67, 0x6f, @@ -416,7 +512,22 @@ var file_google_shopping_css_v1_css_product_inputs_proto_rawDesc = []byte{ 0x69, 0x6e, 0x70, 0x75, 0x74, 0x22, 0x2f, 0x2f, 0x76, 0x31, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x61, 0x63, 0x63, 0x6f, 0x75, 0x6e, 0x74, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x63, 0x73, 0x73, 0x50, 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, 0x49, 0x6e, 0x70, 0x75, 0x74, 0x73, 0x3a, - 0x69, 0x6e, 0x73, 0x65, 0x72, 0x74, 0x12, 0x9e, 0x01, 0x0a, 0x15, 0x44, 0x65, 0x6c, 0x65, 0x74, + 0x69, 0x6e, 0x73, 0x65, 0x72, 0x74, 0x12, 0xed, 0x01, 0x0a, 0x15, 0x55, 0x70, 0x64, 0x61, 0x74, + 0x65, 0x43, 0x73, 0x73, 0x50, 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, 0x49, 0x6e, 0x70, 0x75, 0x74, + 0x12, 0x34, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x73, 0x68, 0x6f, 0x70, 0x70, 0x69, + 0x6e, 0x67, 0x2e, 0x63, 0x73, 0x73, 0x2e, 0x76, 0x31, 0x2e, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, + 0x43, 0x73, 0x73, 0x50, 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, 0x49, 0x6e, 0x70, 0x75, 0x74, 0x52, + 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x27, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, + 0x73, 0x68, 0x6f, 0x70, 0x70, 0x69, 0x6e, 0x67, 0x2e, 0x63, 0x73, 0x73, 0x2e, 0x76, 0x31, 0x2e, + 0x43, 0x73, 0x73, 0x50, 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, 0x49, 0x6e, 0x70, 0x75, 0x74, 0x22, + 0x75, 0xda, 0x41, 0x1d, 0x63, 0x73, 0x73, 0x5f, 0x70, 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, 0x5f, + 0x69, 0x6e, 0x70, 0x75, 0x74, 0x2c, 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, 0x5f, 0x6d, 0x61, 0x73, + 0x6b, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x4f, 0x3a, 0x11, 0x63, 0x73, 0x73, 0x5f, 0x70, 0x72, 0x6f, + 0x64, 0x75, 0x63, 0x74, 0x5f, 0x69, 0x6e, 0x70, 0x75, 0x74, 0x32, 0x3a, 0x2f, 0x76, 0x31, 0x2f, + 0x7b, 0x63, 0x73, 0x73, 0x5f, 0x70, 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, 0x5f, 0x69, 0x6e, 0x70, + 0x75, 0x74, 0x2e, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x61, 0x63, 0x63, 0x6f, 0x75, 0x6e, 0x74, 0x73, + 0x2f, 0x2a, 0x2f, 0x63, 0x73, 0x73, 0x50, 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, 0x49, 0x6e, 0x70, + 0x75, 0x74, 0x73, 0x2f, 0x2a, 0x7d, 0x12, 0x9e, 0x01, 0x0a, 0x15, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x43, 0x73, 0x73, 0x50, 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, 0x49, 0x6e, 0x70, 0x75, 0x74, 0x12, 0x34, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x73, 0x68, 0x6f, 0x70, 0x70, 0x69, 0x6e, 0x67, 0x2e, 0x63, 0x73, 0x73, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, @@ -457,30 +568,36 @@ func file_google_shopping_css_v1_css_product_inputs_proto_rawDescGZIP() []byte { return file_google_shopping_css_v1_css_product_inputs_proto_rawDescData } -var file_google_shopping_css_v1_css_product_inputs_proto_msgTypes = make([]protoimpl.MessageInfo, 3) +var file_google_shopping_css_v1_css_product_inputs_proto_msgTypes = make([]protoimpl.MessageInfo, 4) var file_google_shopping_css_v1_css_product_inputs_proto_goTypes = []any{ (*CssProductInput)(nil), // 0: google.shopping.css.v1.CssProductInput (*InsertCssProductInputRequest)(nil), // 1: google.shopping.css.v1.InsertCssProductInputRequest - (*DeleteCssProductInputRequest)(nil), // 2: google.shopping.css.v1.DeleteCssProductInputRequest - (*timestamppb.Timestamp)(nil), // 3: google.protobuf.Timestamp - (*Attributes)(nil), // 4: google.shopping.css.v1.Attributes - (*typepb.CustomAttribute)(nil), // 5: google.shopping.type.CustomAttribute - (*emptypb.Empty)(nil), // 6: google.protobuf.Empty + (*UpdateCssProductInputRequest)(nil), // 2: google.shopping.css.v1.UpdateCssProductInputRequest + (*DeleteCssProductInputRequest)(nil), // 3: google.shopping.css.v1.DeleteCssProductInputRequest + (*timestamppb.Timestamp)(nil), // 4: google.protobuf.Timestamp + (*Attributes)(nil), // 5: google.shopping.css.v1.Attributes + (*typepb.CustomAttribute)(nil), // 6: google.shopping.type.CustomAttribute + (*fieldmaskpb.FieldMask)(nil), // 7: google.protobuf.FieldMask + (*emptypb.Empty)(nil), // 8: google.protobuf.Empty } var file_google_shopping_css_v1_css_product_inputs_proto_depIdxs = []int32{ - 3, // 0: google.shopping.css.v1.CssProductInput.freshness_time:type_name -> google.protobuf.Timestamp - 4, // 1: google.shopping.css.v1.CssProductInput.attributes:type_name -> google.shopping.css.v1.Attributes - 5, // 2: google.shopping.css.v1.CssProductInput.custom_attributes:type_name -> google.shopping.type.CustomAttribute + 4, // 0: google.shopping.css.v1.CssProductInput.freshness_time:type_name -> google.protobuf.Timestamp + 5, // 1: google.shopping.css.v1.CssProductInput.attributes:type_name -> google.shopping.css.v1.Attributes + 6, // 2: google.shopping.css.v1.CssProductInput.custom_attributes:type_name -> google.shopping.type.CustomAttribute 0, // 3: google.shopping.css.v1.InsertCssProductInputRequest.css_product_input:type_name -> google.shopping.css.v1.CssProductInput - 1, // 4: google.shopping.css.v1.CssProductInputsService.InsertCssProductInput:input_type -> google.shopping.css.v1.InsertCssProductInputRequest - 2, // 5: google.shopping.css.v1.CssProductInputsService.DeleteCssProductInput:input_type -> google.shopping.css.v1.DeleteCssProductInputRequest - 0, // 6: google.shopping.css.v1.CssProductInputsService.InsertCssProductInput:output_type -> google.shopping.css.v1.CssProductInput - 6, // 7: google.shopping.css.v1.CssProductInputsService.DeleteCssProductInput:output_type -> google.protobuf.Empty - 6, // [6:8] is the sub-list for method output_type - 4, // [4:6] is the sub-list for method input_type - 4, // [4:4] is the sub-list for extension type_name - 4, // [4:4] is the sub-list for extension extendee - 0, // [0:4] is the sub-list for field type_name + 0, // 4: google.shopping.css.v1.UpdateCssProductInputRequest.css_product_input:type_name -> google.shopping.css.v1.CssProductInput + 7, // 5: google.shopping.css.v1.UpdateCssProductInputRequest.update_mask:type_name -> google.protobuf.FieldMask + 1, // 6: google.shopping.css.v1.CssProductInputsService.InsertCssProductInput:input_type -> google.shopping.css.v1.InsertCssProductInputRequest + 2, // 7: google.shopping.css.v1.CssProductInputsService.UpdateCssProductInput:input_type -> google.shopping.css.v1.UpdateCssProductInputRequest + 3, // 8: google.shopping.css.v1.CssProductInputsService.DeleteCssProductInput:input_type -> google.shopping.css.v1.DeleteCssProductInputRequest + 0, // 9: google.shopping.css.v1.CssProductInputsService.InsertCssProductInput:output_type -> google.shopping.css.v1.CssProductInput + 0, // 10: google.shopping.css.v1.CssProductInputsService.UpdateCssProductInput:output_type -> google.shopping.css.v1.CssProductInput + 8, // 11: google.shopping.css.v1.CssProductInputsService.DeleteCssProductInput:output_type -> google.protobuf.Empty + 9, // [9:12] is the sub-list for method output_type + 6, // [6:9] is the sub-list for method input_type + 6, // [6:6] is the sub-list for extension type_name + 6, // [6:6] is the sub-list for extension extendee + 0, // [0:6] is the sub-list for field type_name } func init() { file_google_shopping_css_v1_css_product_inputs_proto_init() } @@ -489,14 +606,14 @@ func file_google_shopping_css_v1_css_product_inputs_proto_init() { return } file_google_shopping_css_v1_css_product_common_proto_init() - file_google_shopping_css_v1_css_product_inputs_proto_msgTypes[2].OneofWrappers = []any{} + file_google_shopping_css_v1_css_product_inputs_proto_msgTypes[3].OneofWrappers = []any{} type x struct{} out := protoimpl.TypeBuilder{ File: protoimpl.DescBuilder{ GoPackagePath: reflect.TypeOf(x{}).PkgPath(), RawDescriptor: file_google_shopping_css_v1_css_product_inputs_proto_rawDesc, NumEnums: 0, - NumMessages: 3, + NumMessages: 4, NumExtensions: 0, NumServices: 1, }, @@ -529,6 +646,11 @@ type CssProductInputsServiceClient interface { // After inserting, updating, or deleting a CSS Product input, it may // take several minutes before the processed CSS Product can be retrieved. InsertCssProductInput(ctx context.Context, in *InsertCssProductInputRequest, opts ...grpc.CallOption) (*CssProductInput, error) + // Updates the existing Css Product input in your CSS Center account. + // + // After inserting, updating, or deleting a CSS Product input, it may take + // several minutes before the processed Css Product can be retrieved. + UpdateCssProductInput(ctx context.Context, in *UpdateCssProductInputRequest, opts ...grpc.CallOption) (*CssProductInput, error) // Deletes a CSS Product input from your CSS Center account. // // After a delete it may take several minutes until the input is no longer @@ -553,6 +675,15 @@ func (c *cssProductInputsServiceClient) InsertCssProductInput(ctx context.Contex return out, nil } +func (c *cssProductInputsServiceClient) UpdateCssProductInput(ctx context.Context, in *UpdateCssProductInputRequest, opts ...grpc.CallOption) (*CssProductInput, error) { + out := new(CssProductInput) + err := c.cc.Invoke(ctx, "/google.shopping.css.v1.CssProductInputsService/UpdateCssProductInput", in, out, opts...) + if err != nil { + return nil, err + } + return out, nil +} + func (c *cssProductInputsServiceClient) DeleteCssProductInput(ctx context.Context, in *DeleteCssProductInputRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) { out := new(emptypb.Empty) err := c.cc.Invoke(ctx, "/google.shopping.css.v1.CssProductInputsService/DeleteCssProductInput", in, out, opts...) @@ -571,6 +702,11 @@ type CssProductInputsServiceServer interface { // After inserting, updating, or deleting a CSS Product input, it may // take several minutes before the processed CSS Product can be retrieved. InsertCssProductInput(context.Context, *InsertCssProductInputRequest) (*CssProductInput, error) + // Updates the existing Css Product input in your CSS Center account. + // + // After inserting, updating, or deleting a CSS Product input, it may take + // several minutes before the processed Css Product can be retrieved. + UpdateCssProductInput(context.Context, *UpdateCssProductInputRequest) (*CssProductInput, error) // Deletes a CSS Product input from your CSS Center account. // // After a delete it may take several minutes until the input is no longer @@ -585,6 +721,9 @@ type UnimplementedCssProductInputsServiceServer struct { func (*UnimplementedCssProductInputsServiceServer) InsertCssProductInput(context.Context, *InsertCssProductInputRequest) (*CssProductInput, error) { return nil, status.Errorf(codes.Unimplemented, "method InsertCssProductInput not implemented") } +func (*UnimplementedCssProductInputsServiceServer) UpdateCssProductInput(context.Context, *UpdateCssProductInputRequest) (*CssProductInput, error) { + return nil, status.Errorf(codes.Unimplemented, "method UpdateCssProductInput not implemented") +} func (*UnimplementedCssProductInputsServiceServer) DeleteCssProductInput(context.Context, *DeleteCssProductInputRequest) (*emptypb.Empty, error) { return nil, status.Errorf(codes.Unimplemented, "method DeleteCssProductInput not implemented") } @@ -611,6 +750,24 @@ func _CssProductInputsService_InsertCssProductInput_Handler(srv interface{}, ctx return interceptor(ctx, in, info, handler) } +func _CssProductInputsService_UpdateCssProductInput_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { + in := new(UpdateCssProductInputRequest) + if err := dec(in); err != nil { + return nil, err + } + if interceptor == nil { + return srv.(CssProductInputsServiceServer).UpdateCssProductInput(ctx, in) + } + info := &grpc.UnaryServerInfo{ + Server: srv, + FullMethod: "/google.shopping.css.v1.CssProductInputsService/UpdateCssProductInput", + } + handler := func(ctx context.Context, req interface{}) (interface{}, error) { + return srv.(CssProductInputsServiceServer).UpdateCssProductInput(ctx, req.(*UpdateCssProductInputRequest)) + } + return interceptor(ctx, in, info, handler) +} + func _CssProductInputsService_DeleteCssProductInput_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { in := new(DeleteCssProductInputRequest) if err := dec(in); err != nil { @@ -637,6 +794,10 @@ var _CssProductInputsService_serviceDesc = grpc.ServiceDesc{ MethodName: "InsertCssProductInput", Handler: _CssProductInputsService_InsertCssProductInput_Handler, }, + { + MethodName: "UpdateCssProductInput", + Handler: _CssProductInputsService_UpdateCssProductInput_Handler, + }, { MethodName: "DeleteCssProductInput", Handler: _CssProductInputsService_DeleteCssProductInput_Handler, diff --git a/shopping/css/apiv1/csspb/css_products.pb.go b/shopping/css/apiv1/csspb/css_products.pb.go index 9801ef8508c6..061be72bb2d9 100755 --- a/shopping/css/apiv1/csspb/css_products.pb.go +++ b/shopping/css/apiv1/csspb/css_products.pb.go @@ -88,7 +88,7 @@ func (x *GetCssProductRequest) GetName() string { return "" } -// The processed CSS Product(a.k.a Aggregate Offer internally). +// The processed CSS Product. type CssProduct struct { state protoimpl.MessageState sizeCache protoimpl.SizeCache diff --git a/shopping/css/apiv1/gapic_metadata.json b/shopping/css/apiv1/gapic_metadata.json index e29abcc254cc..288e4e8c22c6 100644 --- a/shopping/css/apiv1/gapic_metadata.json +++ b/shopping/css/apiv1/gapic_metadata.json @@ -117,6 +117,11 @@ "methods": [ "InsertCssProductInput" ] + }, + "UpdateCssProductInput": { + "methods": [ + "UpdateCssProductInput" + ] } } }, @@ -132,6 +137,11 @@ "methods": [ "InsertCssProductInput" ] + }, + "UpdateCssProductInput": { + "methods": [ + "UpdateCssProductInput" + ] } } } diff --git a/shopping/merchant/reviews/apiv1beta/reviewspb/merchantreviews.pb.go b/shopping/merchant/reviews/apiv1beta/reviewspb/merchantreviews.pb.go index 799f00841fe0..8975d38139c6 100755 --- a/shopping/merchant/reviews/apiv1beta/reviewspb/merchantreviews.pb.go +++ b/shopping/merchant/reviews/apiv1beta/reviewspb/merchantreviews.pb.go @@ -612,7 +612,7 @@ var file_google_shopping_merchant_reviews_v1beta_merchantreviews_proto_rawDesc = 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0xd2, 0x41, 0x27, 0x68, 0x74, 0x74, 0x70, 0x73, 0x3a, 0x2f, 0x2f, 0x77, 0x77, 0x77, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x61, 0x75, 0x74, 0x68, 0x2f, 0x63, - 0x6f, 0x6e, 0x74, 0x65, 0x6e, 0x74, 0x42, 0xcd, 0x01, 0xea, 0x41, 0x38, 0x0a, 0x22, 0x6d, 0x65, + 0x6f, 0x6e, 0x74, 0x65, 0x6e, 0x74, 0x42, 0xcf, 0x02, 0xea, 0x41, 0x38, 0x0a, 0x22, 0x6d, 0x65, 0x72, 0x63, 0x68, 0x61, 0x6e, 0x74, 0x61, 0x70, 0x69, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x41, 0x63, 0x63, 0x6f, 0x75, 0x6e, 0x74, 0x12, 0x12, 0x61, 0x63, 0x63, 0x6f, 0x75, 0x6e, 0x74, 0x73, 0x2f, 0x7b, 0x61, 0x63, 0x63, 0x6f, @@ -625,7 +625,15 @@ var file_google_shopping_merchant_reviews_v1beta_merchantreviews_proto_rawDesc = 0x68, 0x6f, 0x70, 0x70, 0x69, 0x6e, 0x67, 0x2f, 0x6d, 0x65, 0x72, 0x63, 0x68, 0x61, 0x6e, 0x74, 0x2f, 0x72, 0x65, 0x76, 0x69, 0x65, 0x77, 0x73, 0x2f, 0x61, 0x70, 0x69, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x2f, 0x72, 0x65, 0x76, 0x69, 0x65, 0x77, 0x73, 0x70, 0x62, 0x3b, 0x72, 0x65, 0x76, - 0x69, 0x65, 0x77, 0x73, 0x70, 0x62, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, + 0x69, 0x65, 0x77, 0x73, 0x70, 0x62, 0xaa, 0x02, 0x27, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, + 0x53, 0x68, 0x6f, 0x70, 0x70, 0x69, 0x6e, 0x67, 0x2e, 0x4d, 0x65, 0x72, 0x63, 0x68, 0x61, 0x6e, + 0x74, 0x2e, 0x52, 0x65, 0x76, 0x69, 0x65, 0x77, 0x73, 0x2e, 0x56, 0x31, 0x42, 0x65, 0x74, 0x61, + 0xca, 0x02, 0x27, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x5c, 0x53, 0x68, 0x6f, 0x70, 0x70, 0x69, + 0x6e, 0x67, 0x5c, 0x4d, 0x65, 0x72, 0x63, 0x68, 0x61, 0x6e, 0x74, 0x5c, 0x52, 0x65, 0x76, 0x69, + 0x65, 0x77, 0x73, 0x5c, 0x56, 0x31, 0x62, 0x65, 0x74, 0x61, 0xea, 0x02, 0x2b, 0x47, 0x6f, 0x6f, + 0x67, 0x6c, 0x65, 0x3a, 0x3a, 0x53, 0x68, 0x6f, 0x70, 0x70, 0x69, 0x6e, 0x67, 0x3a, 0x3a, 0x4d, + 0x65, 0x72, 0x63, 0x68, 0x61, 0x6e, 0x74, 0x3a, 0x3a, 0x52, 0x65, 0x76, 0x69, 0x65, 0x77, 0x73, + 0x3a, 0x3a, 0x56, 0x31, 0x62, 0x65, 0x74, 0x61, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, } var ( diff --git a/shopping/merchant/reviews/apiv1beta/reviewspb/merchantreviews_common.pb.go b/shopping/merchant/reviews/apiv1beta/reviewspb/merchantreviews_common.pb.go index fc7a1e705da4..242a3b867744 100755 --- a/shopping/merchant/reviews/apiv1beta/reviewspb/merchantreviews_common.pb.go +++ b/shopping/merchant/reviews/apiv1beta/reviewspb/merchantreviews_common.pb.go @@ -751,7 +751,7 @@ var file_google_shopping_merchant_reviews_v1beta_merchantreviews_common_proto_ra 0x49, 0x54, 0x59, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x10, 0x0a, 0x0c, 0x4e, 0x4f, 0x54, 0x5f, 0x49, 0x4d, 0x50, 0x41, 0x43, 0x54, 0x45, 0x44, 0x10, 0x01, 0x12, 0x0f, 0x0a, 0x0b, 0x44, 0x49, 0x53, 0x41, 0x50, 0x50, 0x52, 0x4f, 0x56, - 0x45, 0x44, 0x10, 0x02, 0x42, 0x98, 0x01, 0x0a, 0x2b, 0x63, 0x6f, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, + 0x45, 0x44, 0x10, 0x02, 0x42, 0x9a, 0x02, 0x0a, 0x2b, 0x63, 0x6f, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x73, 0x68, 0x6f, 0x70, 0x70, 0x69, 0x6e, 0x67, 0x2e, 0x6d, 0x65, 0x72, 0x63, 0x68, 0x61, 0x6e, 0x74, 0x2e, 0x72, 0x65, 0x76, 0x69, 0x65, 0x77, 0x73, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x42, 0x1a, 0x4d, 0x65, 0x72, 0x63, 0x68, 0x61, 0x6e, 0x74, 0x52, 0x65, @@ -760,8 +760,16 @@ var file_google_shopping_merchant_reviews_v1beta_merchantreviews_common_proto_ra 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x67, 0x6f, 0x2f, 0x73, 0x68, 0x6f, 0x70, 0x70, 0x69, 0x6e, 0x67, 0x2f, 0x6d, 0x65, 0x72, 0x63, 0x68, 0x61, 0x6e, 0x74, 0x2f, 0x72, 0x65, 0x76, 0x69, 0x65, 0x77, 0x73, 0x2f, 0x61, 0x70, 0x69, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x2f, 0x72, 0x65, 0x76, 0x69, - 0x65, 0x77, 0x73, 0x70, 0x62, 0x3b, 0x72, 0x65, 0x76, 0x69, 0x65, 0x77, 0x73, 0x70, 0x62, 0x62, - 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, + 0x65, 0x77, 0x73, 0x70, 0x62, 0x3b, 0x72, 0x65, 0x76, 0x69, 0x65, 0x77, 0x73, 0x70, 0x62, 0xaa, + 0x02, 0x27, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x53, 0x68, 0x6f, 0x70, 0x70, 0x69, 0x6e, + 0x67, 0x2e, 0x4d, 0x65, 0x72, 0x63, 0x68, 0x61, 0x6e, 0x74, 0x2e, 0x52, 0x65, 0x76, 0x69, 0x65, + 0x77, 0x73, 0x2e, 0x56, 0x31, 0x42, 0x65, 0x74, 0x61, 0xca, 0x02, 0x27, 0x47, 0x6f, 0x6f, 0x67, + 0x6c, 0x65, 0x5c, 0x53, 0x68, 0x6f, 0x70, 0x70, 0x69, 0x6e, 0x67, 0x5c, 0x4d, 0x65, 0x72, 0x63, + 0x68, 0x61, 0x6e, 0x74, 0x5c, 0x52, 0x65, 0x76, 0x69, 0x65, 0x77, 0x73, 0x5c, 0x56, 0x31, 0x62, + 0x65, 0x74, 0x61, 0xea, 0x02, 0x2b, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x3a, 0x3a, 0x53, 0x68, + 0x6f, 0x70, 0x70, 0x69, 0x6e, 0x67, 0x3a, 0x3a, 0x4d, 0x65, 0x72, 0x63, 0x68, 0x61, 0x6e, 0x74, + 0x3a, 0x3a, 0x52, 0x65, 0x76, 0x69, 0x65, 0x77, 0x73, 0x3a, 0x3a, 0x56, 0x31, 0x62, 0x65, 0x74, + 0x61, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, } var ( diff --git a/shopping/merchant/reviews/apiv1beta/reviewspb/productreviews.pb.go b/shopping/merchant/reviews/apiv1beta/reviewspb/productreviews.pb.go index 63f4fa6055cf..72a3f1e0a34e 100755 --- a/shopping/merchant/reviews/apiv1beta/reviewspb/productreviews.pb.go +++ b/shopping/merchant/reviews/apiv1beta/reviewspb/productreviews.pb.go @@ -597,7 +597,7 @@ var file_google_shopping_merchant_reviews_v1beta_productreviews_proto_rawDesc = 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0xd2, 0x41, 0x27, 0x68, 0x74, 0x74, 0x70, 0x73, 0x3a, 0x2f, 0x2f, 0x77, 0x77, 0x77, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x61, 0x75, 0x74, 0x68, 0x2f, 0x63, 0x6f, 0x6e, 0x74, - 0x65, 0x6e, 0x74, 0x42, 0x91, 0x01, 0x0a, 0x2b, 0x63, 0x6f, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, + 0x65, 0x6e, 0x74, 0x42, 0x93, 0x02, 0x0a, 0x2b, 0x63, 0x6f, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x73, 0x68, 0x6f, 0x70, 0x70, 0x69, 0x6e, 0x67, 0x2e, 0x6d, 0x65, 0x72, 0x63, 0x68, 0x61, 0x6e, 0x74, 0x2e, 0x72, 0x65, 0x76, 0x69, 0x65, 0x77, 0x73, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x42, 0x13, 0x50, 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, 0x52, 0x65, 0x76, 0x69, @@ -606,7 +606,16 @@ var file_google_shopping_merchant_reviews_v1beta_productreviews_proto_rawDesc = 0x73, 0x68, 0x6f, 0x70, 0x70, 0x69, 0x6e, 0x67, 0x2f, 0x6d, 0x65, 0x72, 0x63, 0x68, 0x61, 0x6e, 0x74, 0x2f, 0x72, 0x65, 0x76, 0x69, 0x65, 0x77, 0x73, 0x2f, 0x61, 0x70, 0x69, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x2f, 0x72, 0x65, 0x76, 0x69, 0x65, 0x77, 0x73, 0x70, 0x62, 0x3b, 0x72, 0x65, - 0x76, 0x69, 0x65, 0x77, 0x73, 0x70, 0x62, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, + 0x76, 0x69, 0x65, 0x77, 0x73, 0x70, 0x62, 0xaa, 0x02, 0x27, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, + 0x2e, 0x53, 0x68, 0x6f, 0x70, 0x70, 0x69, 0x6e, 0x67, 0x2e, 0x4d, 0x65, 0x72, 0x63, 0x68, 0x61, + 0x6e, 0x74, 0x2e, 0x52, 0x65, 0x76, 0x69, 0x65, 0x77, 0x73, 0x2e, 0x56, 0x31, 0x42, 0x65, 0x74, + 0x61, 0xca, 0x02, 0x27, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x5c, 0x53, 0x68, 0x6f, 0x70, 0x70, + 0x69, 0x6e, 0x67, 0x5c, 0x4d, 0x65, 0x72, 0x63, 0x68, 0x61, 0x6e, 0x74, 0x5c, 0x52, 0x65, 0x76, + 0x69, 0x65, 0x77, 0x73, 0x5c, 0x56, 0x31, 0x62, 0x65, 0x74, 0x61, 0xea, 0x02, 0x2b, 0x47, 0x6f, + 0x6f, 0x67, 0x6c, 0x65, 0x3a, 0x3a, 0x53, 0x68, 0x6f, 0x70, 0x70, 0x69, 0x6e, 0x67, 0x3a, 0x3a, + 0x4d, 0x65, 0x72, 0x63, 0x68, 0x61, 0x6e, 0x74, 0x3a, 0x3a, 0x52, 0x65, 0x76, 0x69, 0x65, 0x77, + 0x73, 0x3a, 0x3a, 0x56, 0x31, 0x62, 0x65, 0x74, 0x61, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, + 0x33, } var ( diff --git a/shopping/merchant/reviews/apiv1beta/reviewspb/productreviews_common.pb.go b/shopping/merchant/reviews/apiv1beta/reviewspb/productreviews_common.pb.go index 1234d3d68a75..cb2d12ec46ca 100755 --- a/shopping/merchant/reviews/apiv1beta/reviewspb/productreviews_common.pb.go +++ b/shopping/merchant/reviews/apiv1beta/reviewspb/productreviews_common.pb.go @@ -1033,7 +1033,7 @@ var file_google_shopping_merchant_reviews_v1beta_productreviews_common_proto_raw 0x54, 0x59, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x10, 0x0a, 0x0c, 0x4e, 0x4f, 0x54, 0x5f, 0x49, 0x4d, 0x50, 0x41, 0x43, 0x54, 0x45, 0x44, 0x10, 0x01, 0x12, 0x0f, 0x0a, 0x0b, 0x44, 0x49, 0x53, 0x41, 0x50, 0x50, 0x52, 0x4f, 0x56, 0x45, - 0x44, 0x10, 0x02, 0x42, 0x97, 0x01, 0x0a, 0x2b, 0x63, 0x6f, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, + 0x44, 0x10, 0x02, 0x42, 0x99, 0x02, 0x0a, 0x2b, 0x63, 0x6f, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x73, 0x68, 0x6f, 0x70, 0x70, 0x69, 0x6e, 0x67, 0x2e, 0x6d, 0x65, 0x72, 0x63, 0x68, 0x61, 0x6e, 0x74, 0x2e, 0x72, 0x65, 0x76, 0x69, 0x65, 0x77, 0x73, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x42, 0x19, 0x50, 0x72, 0x6f, 0x64, 0x75, 0x63, 0x74, 0x52, 0x65, 0x76, 0x69, @@ -1042,8 +1042,16 @@ var file_google_shopping_merchant_reviews_v1beta_productreviews_common_proto_raw 0x6f, 0x6d, 0x2f, 0x67, 0x6f, 0x2f, 0x73, 0x68, 0x6f, 0x70, 0x70, 0x69, 0x6e, 0x67, 0x2f, 0x6d, 0x65, 0x72, 0x63, 0x68, 0x61, 0x6e, 0x74, 0x2f, 0x72, 0x65, 0x76, 0x69, 0x65, 0x77, 0x73, 0x2f, 0x61, 0x70, 0x69, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x2f, 0x72, 0x65, 0x76, 0x69, 0x65, 0x77, - 0x73, 0x70, 0x62, 0x3b, 0x72, 0x65, 0x76, 0x69, 0x65, 0x77, 0x73, 0x70, 0x62, 0x62, 0x06, 0x70, - 0x72, 0x6f, 0x74, 0x6f, 0x33, + 0x73, 0x70, 0x62, 0x3b, 0x72, 0x65, 0x76, 0x69, 0x65, 0x77, 0x73, 0x70, 0x62, 0xaa, 0x02, 0x27, + 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x53, 0x68, 0x6f, 0x70, 0x70, 0x69, 0x6e, 0x67, 0x2e, + 0x4d, 0x65, 0x72, 0x63, 0x68, 0x61, 0x6e, 0x74, 0x2e, 0x52, 0x65, 0x76, 0x69, 0x65, 0x77, 0x73, + 0x2e, 0x56, 0x31, 0x42, 0x65, 0x74, 0x61, 0xca, 0x02, 0x27, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, + 0x5c, 0x53, 0x68, 0x6f, 0x70, 0x70, 0x69, 0x6e, 0x67, 0x5c, 0x4d, 0x65, 0x72, 0x63, 0x68, 0x61, + 0x6e, 0x74, 0x5c, 0x52, 0x65, 0x76, 0x69, 0x65, 0x77, 0x73, 0x5c, 0x56, 0x31, 0x62, 0x65, 0x74, + 0x61, 0xea, 0x02, 0x2b, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x3a, 0x3a, 0x53, 0x68, 0x6f, 0x70, + 0x70, 0x69, 0x6e, 0x67, 0x3a, 0x3a, 0x4d, 0x65, 0x72, 0x63, 0x68, 0x61, 0x6e, 0x74, 0x3a, 0x3a, + 0x52, 0x65, 0x76, 0x69, 0x65, 0x77, 0x73, 0x3a, 0x3a, 0x56, 0x31, 0x62, 0x65, 0x74, 0x61, 0x62, + 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, } var ( diff --git a/speech/apiv2/speechpb/cloud_speech.pb.go b/speech/apiv2/speechpb/cloud_speech.pb.go index 0be67e1787ef..ddcb3bcaa05e 100755 --- a/speech/apiv2/speechpb/cloud_speech.pb.go +++ b/speech/apiv2/speechpb/cloud_speech.pb.go @@ -110,21 +110,57 @@ const ( ExplicitDecodingConfig_MULAW ExplicitDecodingConfig_AudioEncoding = 2 // Headerless 8-bit companded alaw samples. ExplicitDecodingConfig_ALAW ExplicitDecodingConfig_AudioEncoding = 3 + // AMR frames with an rfc4867.5 header. + ExplicitDecodingConfig_AMR ExplicitDecodingConfig_AudioEncoding = 4 + // AMR-WB frames with an rfc4867.5 header. + ExplicitDecodingConfig_AMR_WB ExplicitDecodingConfig_AudioEncoding = 5 + // FLAC frames in the "native FLAC" container format. + ExplicitDecodingConfig_FLAC ExplicitDecodingConfig_AudioEncoding = 6 + // MPEG audio frames with optional (ignored) ID3 metadata. + ExplicitDecodingConfig_MP3 ExplicitDecodingConfig_AudioEncoding = 7 + // Opus audio frames in an Ogg container. + ExplicitDecodingConfig_OGG_OPUS ExplicitDecodingConfig_AudioEncoding = 8 + // Opus audio frames in a WebM container. + ExplicitDecodingConfig_WEBM_OPUS ExplicitDecodingConfig_AudioEncoding = 9 + // AAC audio frames in an MP4 container. + ExplicitDecodingConfig_MP4_AAC ExplicitDecodingConfig_AudioEncoding = 10 + // AAC audio frames in an M4A container. + ExplicitDecodingConfig_M4A_AAC ExplicitDecodingConfig_AudioEncoding = 11 + // AAC audio frames in an MOV container. + ExplicitDecodingConfig_MOV_AAC ExplicitDecodingConfig_AudioEncoding = 12 ) // Enum value maps for ExplicitDecodingConfig_AudioEncoding. var ( ExplicitDecodingConfig_AudioEncoding_name = map[int32]string{ - 0: "AUDIO_ENCODING_UNSPECIFIED", - 1: "LINEAR16", - 2: "MULAW", - 3: "ALAW", + 0: "AUDIO_ENCODING_UNSPECIFIED", + 1: "LINEAR16", + 2: "MULAW", + 3: "ALAW", + 4: "AMR", + 5: "AMR_WB", + 6: "FLAC", + 7: "MP3", + 8: "OGG_OPUS", + 9: "WEBM_OPUS", + 10: "MP4_AAC", + 11: "M4A_AAC", + 12: "MOV_AAC", } ExplicitDecodingConfig_AudioEncoding_value = map[string]int32{ "AUDIO_ENCODING_UNSPECIFIED": 0, "LINEAR16": 1, "MULAW": 2, "ALAW": 3, + "AMR": 4, + "AMR_WB": 5, + "FLAC": 6, + "MP3": 7, + "OGG_OPUS": 8, + "WEBM_OPUS": 9, + "MP4_AAC": 10, + "M4A_AAC": 11, + "MOV_AAC": 12, } ) @@ -1601,26 +1637,16 @@ type ExplicitDecodingConfig struct { // Required. Encoding of the audio data sent for recognition. Encoding ExplicitDecodingConfig_AudioEncoding `protobuf:"varint,1,opt,name=encoding,proto3,enum=google.cloud.speech.v2.ExplicitDecodingConfig_AudioEncoding" json:"encoding,omitempty"` - // Sample rate in Hertz of the audio data sent for recognition. Valid - // values are: 8000-48000. 16000 is optimal. For best results, set the + // Optional. Sample rate in Hertz of the audio data sent for recognition. + // Valid values are: 8000-48000. 16000 is optimal. For best results, set the // sampling rate of the audio source to 16000 Hz. If that's not possible, use // the native sample rate of the audio source (instead of re-sampling). - // Supported for the following encodings: - // - // * LINEAR16: Headerless 16-bit signed little-endian PCM samples. - // - // * MULAW: Headerless 8-bit companded mulaw samples. - // - // * ALAW: Headerless 8-bit companded alaw samples. + // Note that this field is marked as OPTIONAL for backward compatibility + // reasons. It is (and has always been) effectively REQUIRED. SampleRateHertz int32 `protobuf:"varint,2,opt,name=sample_rate_hertz,json=sampleRateHertz,proto3" json:"sample_rate_hertz,omitempty"` - // Number of channels present in the audio data sent for recognition. - // Supported for the following encodings: - // - // * LINEAR16: Headerless 16-bit signed little-endian PCM samples. - // - // * MULAW: Headerless 8-bit companded mulaw samples. - // - // * ALAW: Headerless 8-bit companded alaw samples. + // Optional. Number of channels present in the audio data sent for + // recognition. Note that this field is marked as OPTIONAL for backward + // compatibility reasons. It is (and has always been) effectively REQUIRED. // // The maximum allowed value is 8. AudioChannelCount int32 `protobuf:"varint,3,opt,name=audio_channel_count,json=audioChannelCount,proto3" json:"audio_channel_count,omitempty"` @@ -3321,14 +3347,14 @@ type OutputFormatConfig struct { unknownFields protoimpl.UnknownFields // Configuration for the native output format. If this field is set or if no - // other output format field is set then transcripts will be written to the + // other output format field is set, then transcripts will be written to the // sink in the native format. Native *NativeOutputFileFormatConfig `protobuf:"bytes,1,opt,name=native,proto3" json:"native,omitempty"` - // Configuration for the vtt output format. If this field is set then - // transcripts will be written to the sink in the vtt format. + // Configuration for the VTT output format. If this field is set, then + // transcripts will be written to the sink in the VTT format. Vtt *VttOutputFileFormatConfig `protobuf:"bytes,2,opt,name=vtt,proto3" json:"vtt,omitempty"` - // Configuration for the srt output format. If this field is set then - // transcripts will be written to the sink in the srt format. + // Configuration for the SRT output format. If this field is set, then + // transcripts will be written to the sink in the SRT format. Srt *SrtOutputFileFormatConfig `protobuf:"bytes,3,opt,name=srt,proto3" json:"srt,omitempty"` } @@ -6508,1193 +6534,1201 @@ var file_google_cloud_speech_v2_cloud_speech_proto_rawDesc = []byte{ 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x7d, 0x2f, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x73, 0x2f, 0x7b, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x7d, 0x52, 0x01, 0x01, 0x22, 0x1a, 0x0a, 0x18, 0x41, 0x75, 0x74, 0x6f, 0x44, 0x65, 0x74, 0x65, 0x63, 0x74, - 0x44, 0x65, 0x63, 0x6f, 0x64, 0x69, 0x6e, 0x67, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x22, 0xa7, - 0x02, 0x0a, 0x16, 0x45, 0x78, 0x70, 0x6c, 0x69, 0x63, 0x69, 0x74, 0x44, 0x65, 0x63, 0x6f, 0x64, + 0x44, 0x65, 0x63, 0x6f, 0x64, 0x69, 0x6e, 0x67, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x22, 0x9e, + 0x03, 0x0a, 0x16, 0x45, 0x78, 0x70, 0x6c, 0x69, 0x63, 0x69, 0x74, 0x44, 0x65, 0x63, 0x6f, 0x64, 0x69, 0x6e, 0x67, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x5d, 0x0a, 0x08, 0x65, 0x6e, 0x63, 0x6f, 0x64, 0x69, 0x6e, 0x67, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0e, 0x32, 0x3c, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x45, 0x78, 0x70, 0x6c, 0x69, 0x63, 0x69, 0x74, 0x44, 0x65, 0x63, 0x6f, 0x64, 0x69, 0x6e, 0x67, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x2e, 0x41, 0x75, 0x64, 0x69, 0x6f, 0x45, 0x6e, 0x63, 0x6f, 0x64, 0x69, 0x6e, 0x67, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x08, - 0x65, 0x6e, 0x63, 0x6f, 0x64, 0x69, 0x6e, 0x67, 0x12, 0x2a, 0x0a, 0x11, 0x73, 0x61, 0x6d, 0x70, + 0x65, 0x6e, 0x63, 0x6f, 0x64, 0x69, 0x6e, 0x67, 0x12, 0x2f, 0x0a, 0x11, 0x73, 0x61, 0x6d, 0x70, 0x6c, 0x65, 0x5f, 0x72, 0x61, 0x74, 0x65, 0x5f, 0x68, 0x65, 0x72, 0x74, 0x7a, 0x18, 0x02, 0x20, - 0x01, 0x28, 0x05, 0x52, 0x0f, 0x73, 0x61, 0x6d, 0x70, 0x6c, 0x65, 0x52, 0x61, 0x74, 0x65, 0x48, - 0x65, 0x72, 0x74, 0x7a, 0x12, 0x2e, 0x0a, 0x13, 0x61, 0x75, 0x64, 0x69, 0x6f, 0x5f, 0x63, 0x68, - 0x61, 0x6e, 0x6e, 0x65, 0x6c, 0x5f, 0x63, 0x6f, 0x75, 0x6e, 0x74, 0x18, 0x03, 0x20, 0x01, 0x28, - 0x05, 0x52, 0x11, 0x61, 0x75, 0x64, 0x69, 0x6f, 0x43, 0x68, 0x61, 0x6e, 0x6e, 0x65, 0x6c, 0x43, - 0x6f, 0x75, 0x6e, 0x74, 0x22, 0x52, 0x0a, 0x0d, 0x41, 0x75, 0x64, 0x69, 0x6f, 0x45, 0x6e, 0x63, - 0x6f, 0x64, 0x69, 0x6e, 0x67, 0x12, 0x1e, 0x0a, 0x1a, 0x41, 0x55, 0x44, 0x49, 0x4f, 0x5f, 0x45, - 0x4e, 0x43, 0x4f, 0x44, 0x49, 0x4e, 0x47, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, - 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x0c, 0x0a, 0x08, 0x4c, 0x49, 0x4e, 0x45, 0x41, 0x52, 0x31, - 0x36, 0x10, 0x01, 0x12, 0x09, 0x0a, 0x05, 0x4d, 0x55, 0x4c, 0x41, 0x57, 0x10, 0x02, 0x12, 0x08, - 0x0a, 0x04, 0x41, 0x4c, 0x41, 0x57, 0x10, 0x03, 0x22, 0x7c, 0x0a, 0x18, 0x53, 0x70, 0x65, 0x61, - 0x6b, 0x65, 0x72, 0x44, 0x69, 0x61, 0x72, 0x69, 0x7a, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x43, 0x6f, - 0x6e, 0x66, 0x69, 0x67, 0x12, 0x2f, 0x0a, 0x11, 0x6d, 0x69, 0x6e, 0x5f, 0x73, 0x70, 0x65, 0x61, - 0x6b, 0x65, 0x72, 0x5f, 0x63, 0x6f, 0x75, 0x6e, 0x74, 0x18, 0x02, 0x20, 0x01, 0x28, 0x05, 0x42, - 0x03, 0xe0, 0x41, 0x02, 0x52, 0x0f, 0x6d, 0x69, 0x6e, 0x53, 0x70, 0x65, 0x61, 0x6b, 0x65, 0x72, - 0x43, 0x6f, 0x75, 0x6e, 0x74, 0x12, 0x2f, 0x0a, 0x11, 0x6d, 0x61, 0x78, 0x5f, 0x73, 0x70, 0x65, - 0x61, 0x6b, 0x65, 0x72, 0x5f, 0x63, 0x6f, 0x75, 0x6e, 0x74, 0x18, 0x03, 0x20, 0x01, 0x28, 0x05, - 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x0f, 0x6d, 0x61, 0x78, 0x53, 0x70, 0x65, 0x61, 0x6b, 0x65, - 0x72, 0x43, 0x6f, 0x75, 0x6e, 0x74, 0x22, 0xb5, 0x05, 0x0a, 0x13, 0x52, 0x65, 0x63, 0x6f, 0x67, - 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x46, 0x65, 0x61, 0x74, 0x75, 0x72, 0x65, 0x73, 0x12, 0x29, - 0x0a, 0x10, 0x70, 0x72, 0x6f, 0x66, 0x61, 0x6e, 0x69, 0x74, 0x79, 0x5f, 0x66, 0x69, 0x6c, 0x74, - 0x65, 0x72, 0x18, 0x01, 0x20, 0x01, 0x28, 0x08, 0x52, 0x0f, 0x70, 0x72, 0x6f, 0x66, 0x61, 0x6e, - 0x69, 0x74, 0x79, 0x46, 0x69, 0x6c, 0x74, 0x65, 0x72, 0x12, 0x37, 0x0a, 0x18, 0x65, 0x6e, 0x61, - 0x62, 0x6c, 0x65, 0x5f, 0x77, 0x6f, 0x72, 0x64, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x5f, 0x6f, 0x66, - 0x66, 0x73, 0x65, 0x74, 0x73, 0x18, 0x02, 0x20, 0x01, 0x28, 0x08, 0x52, 0x15, 0x65, 0x6e, 0x61, - 0x62, 0x6c, 0x65, 0x57, 0x6f, 0x72, 0x64, 0x54, 0x69, 0x6d, 0x65, 0x4f, 0x66, 0x66, 0x73, 0x65, - 0x74, 0x73, 0x12, 0x34, 0x0a, 0x16, 0x65, 0x6e, 0x61, 0x62, 0x6c, 0x65, 0x5f, 0x77, 0x6f, 0x72, - 0x64, 0x5f, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x64, 0x65, 0x6e, 0x63, 0x65, 0x18, 0x03, 0x20, 0x01, - 0x28, 0x08, 0x52, 0x14, 0x65, 0x6e, 0x61, 0x62, 0x6c, 0x65, 0x57, 0x6f, 0x72, 0x64, 0x43, 0x6f, - 0x6e, 0x66, 0x69, 0x64, 0x65, 0x6e, 0x63, 0x65, 0x12, 0x40, 0x0a, 0x1c, 0x65, 0x6e, 0x61, 0x62, - 0x6c, 0x65, 0x5f, 0x61, 0x75, 0x74, 0x6f, 0x6d, 0x61, 0x74, 0x69, 0x63, 0x5f, 0x70, 0x75, 0x6e, - 0x63, 0x74, 0x75, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x18, 0x04, 0x20, 0x01, 0x28, 0x08, 0x52, 0x1a, - 0x65, 0x6e, 0x61, 0x62, 0x6c, 0x65, 0x41, 0x75, 0x74, 0x6f, 0x6d, 0x61, 0x74, 0x69, 0x63, 0x50, - 0x75, 0x6e, 0x63, 0x74, 0x75, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x12, 0x3a, 0x0a, 0x19, 0x65, 0x6e, - 0x61, 0x62, 0x6c, 0x65, 0x5f, 0x73, 0x70, 0x6f, 0x6b, 0x65, 0x6e, 0x5f, 0x70, 0x75, 0x6e, 0x63, - 0x74, 0x75, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x18, 0x0e, 0x20, 0x01, 0x28, 0x08, 0x52, 0x17, 0x65, - 0x6e, 0x61, 0x62, 0x6c, 0x65, 0x53, 0x70, 0x6f, 0x6b, 0x65, 0x6e, 0x50, 0x75, 0x6e, 0x63, 0x74, - 0x75, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x12, 0x30, 0x0a, 0x14, 0x65, 0x6e, 0x61, 0x62, 0x6c, 0x65, - 0x5f, 0x73, 0x70, 0x6f, 0x6b, 0x65, 0x6e, 0x5f, 0x65, 0x6d, 0x6f, 0x6a, 0x69, 0x73, 0x18, 0x0f, - 0x20, 0x01, 0x28, 0x08, 0x52, 0x12, 0x65, 0x6e, 0x61, 0x62, 0x6c, 0x65, 0x53, 0x70, 0x6f, 0x6b, - 0x65, 0x6e, 0x45, 0x6d, 0x6f, 0x6a, 0x69, 0x73, 0x12, 0x6a, 0x0a, 0x12, 0x6d, 0x75, 0x6c, 0x74, - 0x69, 0x5f, 0x63, 0x68, 0x61, 0x6e, 0x6e, 0x65, 0x6c, 0x5f, 0x6d, 0x6f, 0x64, 0x65, 0x18, 0x11, - 0x20, 0x01, 0x28, 0x0e, 0x32, 0x3c, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, - 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x52, 0x65, - 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x46, 0x65, 0x61, 0x74, 0x75, 0x72, 0x65, - 0x73, 0x2e, 0x4d, 0x75, 0x6c, 0x74, 0x69, 0x43, 0x68, 0x61, 0x6e, 0x6e, 0x65, 0x6c, 0x4d, 0x6f, - 0x64, 0x65, 0x52, 0x10, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x43, 0x68, 0x61, 0x6e, 0x6e, 0x65, 0x6c, - 0x4d, 0x6f, 0x64, 0x65, 0x12, 0x5f, 0x0a, 0x12, 0x64, 0x69, 0x61, 0x72, 0x69, 0x7a, 0x61, 0x74, - 0x69, 0x6f, 0x6e, 0x5f, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x18, 0x09, 0x20, 0x01, 0x28, 0x0b, - 0x32, 0x30, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, - 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x53, 0x70, 0x65, 0x61, 0x6b, 0x65, - 0x72, 0x44, 0x69, 0x61, 0x72, 0x69, 0x7a, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x43, 0x6f, 0x6e, 0x66, - 0x69, 0x67, 0x52, 0x11, 0x64, 0x69, 0x61, 0x72, 0x69, 0x7a, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x43, - 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x29, 0x0a, 0x10, 0x6d, 0x61, 0x78, 0x5f, 0x61, 0x6c, 0x74, - 0x65, 0x72, 0x6e, 0x61, 0x74, 0x69, 0x76, 0x65, 0x73, 0x18, 0x10, 0x20, 0x01, 0x28, 0x05, 0x52, - 0x0f, 0x6d, 0x61, 0x78, 0x41, 0x6c, 0x74, 0x65, 0x72, 0x6e, 0x61, 0x74, 0x69, 0x76, 0x65, 0x73, - 0x22, 0x5c, 0x0a, 0x10, 0x4d, 0x75, 0x6c, 0x74, 0x69, 0x43, 0x68, 0x61, 0x6e, 0x6e, 0x65, 0x6c, - 0x4d, 0x6f, 0x64, 0x65, 0x12, 0x22, 0x0a, 0x1e, 0x4d, 0x55, 0x4c, 0x54, 0x49, 0x5f, 0x43, 0x48, - 0x41, 0x4e, 0x4e, 0x45, 0x4c, 0x5f, 0x4d, 0x4f, 0x44, 0x45, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, - 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x24, 0x0a, 0x20, 0x53, 0x45, 0x50, 0x41, - 0x52, 0x41, 0x54, 0x45, 0x5f, 0x52, 0x45, 0x43, 0x4f, 0x47, 0x4e, 0x49, 0x54, 0x49, 0x4f, 0x4e, - 0x5f, 0x50, 0x45, 0x52, 0x5f, 0x43, 0x48, 0x41, 0x4e, 0x4e, 0x45, 0x4c, 0x10, 0x01, 0x22, 0xcc, - 0x01, 0x0a, 0x17, 0x54, 0x72, 0x61, 0x6e, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x4e, 0x6f, 0x72, - 0x6d, 0x61, 0x6c, 0x69, 0x7a, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x12, 0x4f, 0x0a, 0x07, 0x65, 0x6e, - 0x74, 0x72, 0x69, 0x65, 0x73, 0x18, 0x01, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x35, 0x2e, 0x67, 0x6f, + 0x01, 0x28, 0x05, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0f, 0x73, 0x61, 0x6d, 0x70, 0x6c, 0x65, + 0x52, 0x61, 0x74, 0x65, 0x48, 0x65, 0x72, 0x74, 0x7a, 0x12, 0x33, 0x0a, 0x13, 0x61, 0x75, 0x64, + 0x69, 0x6f, 0x5f, 0x63, 0x68, 0x61, 0x6e, 0x6e, 0x65, 0x6c, 0x5f, 0x63, 0x6f, 0x75, 0x6e, 0x74, + 0x18, 0x03, 0x20, 0x01, 0x28, 0x05, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x11, 0x61, 0x75, 0x64, + 0x69, 0x6f, 0x43, 0x68, 0x61, 0x6e, 0x6e, 0x65, 0x6c, 0x43, 0x6f, 0x75, 0x6e, 0x74, 0x22, 0xbe, + 0x01, 0x0a, 0x0d, 0x41, 0x75, 0x64, 0x69, 0x6f, 0x45, 0x6e, 0x63, 0x6f, 0x64, 0x69, 0x6e, 0x67, + 0x12, 0x1e, 0x0a, 0x1a, 0x41, 0x55, 0x44, 0x49, 0x4f, 0x5f, 0x45, 0x4e, 0x43, 0x4f, 0x44, 0x49, + 0x4e, 0x47, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, + 0x12, 0x0c, 0x0a, 0x08, 0x4c, 0x49, 0x4e, 0x45, 0x41, 0x52, 0x31, 0x36, 0x10, 0x01, 0x12, 0x09, + 0x0a, 0x05, 0x4d, 0x55, 0x4c, 0x41, 0x57, 0x10, 0x02, 0x12, 0x08, 0x0a, 0x04, 0x41, 0x4c, 0x41, + 0x57, 0x10, 0x03, 0x12, 0x07, 0x0a, 0x03, 0x41, 0x4d, 0x52, 0x10, 0x04, 0x12, 0x0a, 0x0a, 0x06, + 0x41, 0x4d, 0x52, 0x5f, 0x57, 0x42, 0x10, 0x05, 0x12, 0x08, 0x0a, 0x04, 0x46, 0x4c, 0x41, 0x43, + 0x10, 0x06, 0x12, 0x07, 0x0a, 0x03, 0x4d, 0x50, 0x33, 0x10, 0x07, 0x12, 0x0c, 0x0a, 0x08, 0x4f, + 0x47, 0x47, 0x5f, 0x4f, 0x50, 0x55, 0x53, 0x10, 0x08, 0x12, 0x0d, 0x0a, 0x09, 0x57, 0x45, 0x42, + 0x4d, 0x5f, 0x4f, 0x50, 0x55, 0x53, 0x10, 0x09, 0x12, 0x0b, 0x0a, 0x07, 0x4d, 0x50, 0x34, 0x5f, + 0x41, 0x41, 0x43, 0x10, 0x0a, 0x12, 0x0b, 0x0a, 0x07, 0x4d, 0x34, 0x41, 0x5f, 0x41, 0x41, 0x43, + 0x10, 0x0b, 0x12, 0x0b, 0x0a, 0x07, 0x4d, 0x4f, 0x56, 0x5f, 0x41, 0x41, 0x43, 0x10, 0x0c, 0x22, + 0x7c, 0x0a, 0x18, 0x53, 0x70, 0x65, 0x61, 0x6b, 0x65, 0x72, 0x44, 0x69, 0x61, 0x72, 0x69, 0x7a, + 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x2f, 0x0a, 0x11, 0x6d, + 0x69, 0x6e, 0x5f, 0x73, 0x70, 0x65, 0x61, 0x6b, 0x65, 0x72, 0x5f, 0x63, 0x6f, 0x75, 0x6e, 0x74, + 0x18, 0x02, 0x20, 0x01, 0x28, 0x05, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x0f, 0x6d, 0x69, 0x6e, + 0x53, 0x70, 0x65, 0x61, 0x6b, 0x65, 0x72, 0x43, 0x6f, 0x75, 0x6e, 0x74, 0x12, 0x2f, 0x0a, 0x11, + 0x6d, 0x61, 0x78, 0x5f, 0x73, 0x70, 0x65, 0x61, 0x6b, 0x65, 0x72, 0x5f, 0x63, 0x6f, 0x75, 0x6e, + 0x74, 0x18, 0x03, 0x20, 0x01, 0x28, 0x05, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x0f, 0x6d, 0x61, + 0x78, 0x53, 0x70, 0x65, 0x61, 0x6b, 0x65, 0x72, 0x43, 0x6f, 0x75, 0x6e, 0x74, 0x22, 0xb5, 0x05, + 0x0a, 0x13, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x46, 0x65, 0x61, + 0x74, 0x75, 0x72, 0x65, 0x73, 0x12, 0x29, 0x0a, 0x10, 0x70, 0x72, 0x6f, 0x66, 0x61, 0x6e, 0x69, + 0x74, 0x79, 0x5f, 0x66, 0x69, 0x6c, 0x74, 0x65, 0x72, 0x18, 0x01, 0x20, 0x01, 0x28, 0x08, 0x52, + 0x0f, 0x70, 0x72, 0x6f, 0x66, 0x61, 0x6e, 0x69, 0x74, 0x79, 0x46, 0x69, 0x6c, 0x74, 0x65, 0x72, + 0x12, 0x37, 0x0a, 0x18, 0x65, 0x6e, 0x61, 0x62, 0x6c, 0x65, 0x5f, 0x77, 0x6f, 0x72, 0x64, 0x5f, + 0x74, 0x69, 0x6d, 0x65, 0x5f, 0x6f, 0x66, 0x66, 0x73, 0x65, 0x74, 0x73, 0x18, 0x02, 0x20, 0x01, + 0x28, 0x08, 0x52, 0x15, 0x65, 0x6e, 0x61, 0x62, 0x6c, 0x65, 0x57, 0x6f, 0x72, 0x64, 0x54, 0x69, + 0x6d, 0x65, 0x4f, 0x66, 0x66, 0x73, 0x65, 0x74, 0x73, 0x12, 0x34, 0x0a, 0x16, 0x65, 0x6e, 0x61, + 0x62, 0x6c, 0x65, 0x5f, 0x77, 0x6f, 0x72, 0x64, 0x5f, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x64, 0x65, + 0x6e, 0x63, 0x65, 0x18, 0x03, 0x20, 0x01, 0x28, 0x08, 0x52, 0x14, 0x65, 0x6e, 0x61, 0x62, 0x6c, + 0x65, 0x57, 0x6f, 0x72, 0x64, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x64, 0x65, 0x6e, 0x63, 0x65, 0x12, + 0x40, 0x0a, 0x1c, 0x65, 0x6e, 0x61, 0x62, 0x6c, 0x65, 0x5f, 0x61, 0x75, 0x74, 0x6f, 0x6d, 0x61, + 0x74, 0x69, 0x63, 0x5f, 0x70, 0x75, 0x6e, 0x63, 0x74, 0x75, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x18, + 0x04, 0x20, 0x01, 0x28, 0x08, 0x52, 0x1a, 0x65, 0x6e, 0x61, 0x62, 0x6c, 0x65, 0x41, 0x75, 0x74, + 0x6f, 0x6d, 0x61, 0x74, 0x69, 0x63, 0x50, 0x75, 0x6e, 0x63, 0x74, 0x75, 0x61, 0x74, 0x69, 0x6f, + 0x6e, 0x12, 0x3a, 0x0a, 0x19, 0x65, 0x6e, 0x61, 0x62, 0x6c, 0x65, 0x5f, 0x73, 0x70, 0x6f, 0x6b, + 0x65, 0x6e, 0x5f, 0x70, 0x75, 0x6e, 0x63, 0x74, 0x75, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x18, 0x0e, + 0x20, 0x01, 0x28, 0x08, 0x52, 0x17, 0x65, 0x6e, 0x61, 0x62, 0x6c, 0x65, 0x53, 0x70, 0x6f, 0x6b, + 0x65, 0x6e, 0x50, 0x75, 0x6e, 0x63, 0x74, 0x75, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x12, 0x30, 0x0a, + 0x14, 0x65, 0x6e, 0x61, 0x62, 0x6c, 0x65, 0x5f, 0x73, 0x70, 0x6f, 0x6b, 0x65, 0x6e, 0x5f, 0x65, + 0x6d, 0x6f, 0x6a, 0x69, 0x73, 0x18, 0x0f, 0x20, 0x01, 0x28, 0x08, 0x52, 0x12, 0x65, 0x6e, 0x61, + 0x62, 0x6c, 0x65, 0x53, 0x70, 0x6f, 0x6b, 0x65, 0x6e, 0x45, 0x6d, 0x6f, 0x6a, 0x69, 0x73, 0x12, + 0x6a, 0x0a, 0x12, 0x6d, 0x75, 0x6c, 0x74, 0x69, 0x5f, 0x63, 0x68, 0x61, 0x6e, 0x6e, 0x65, 0x6c, + 0x5f, 0x6d, 0x6f, 0x64, 0x65, 0x18, 0x11, 0x20, 0x01, 0x28, 0x0e, 0x32, 0x3c, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, - 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x54, 0x72, 0x61, 0x6e, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x4e, - 0x6f, 0x72, 0x6d, 0x61, 0x6c, 0x69, 0x7a, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x2e, 0x45, 0x6e, 0x74, - 0x72, 0x79, 0x52, 0x07, 0x65, 0x6e, 0x74, 0x72, 0x69, 0x65, 0x73, 0x1a, 0x60, 0x0a, 0x05, 0x45, - 0x6e, 0x74, 0x72, 0x79, 0x12, 0x16, 0x0a, 0x06, 0x73, 0x65, 0x61, 0x72, 0x63, 0x68, 0x18, 0x01, - 0x20, 0x01, 0x28, 0x09, 0x52, 0x06, 0x73, 0x65, 0x61, 0x72, 0x63, 0x68, 0x12, 0x18, 0x0a, 0x07, - 0x72, 0x65, 0x70, 0x6c, 0x61, 0x63, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x07, 0x72, - 0x65, 0x70, 0x6c, 0x61, 0x63, 0x65, 0x12, 0x25, 0x0a, 0x0e, 0x63, 0x61, 0x73, 0x65, 0x5f, 0x73, - 0x65, 0x6e, 0x73, 0x69, 0x74, 0x69, 0x76, 0x65, 0x18, 0x03, 0x20, 0x01, 0x28, 0x08, 0x52, 0x0d, - 0x63, 0x61, 0x73, 0x65, 0x53, 0x65, 0x6e, 0x73, 0x69, 0x74, 0x69, 0x76, 0x65, 0x22, 0x41, 0x0a, - 0x11, 0x54, 0x72, 0x61, 0x6e, 0x73, 0x6c, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x43, 0x6f, 0x6e, 0x66, - 0x69, 0x67, 0x12, 0x2c, 0x0a, 0x0f, 0x74, 0x61, 0x72, 0x67, 0x65, 0x74, 0x5f, 0x6c, 0x61, 0x6e, - 0x67, 0x75, 0x61, 0x67, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x02, - 0x52, 0x0e, 0x74, 0x61, 0x72, 0x67, 0x65, 0x74, 0x4c, 0x61, 0x6e, 0x67, 0x75, 0x61, 0x67, 0x65, - 0x22, 0xf6, 0x02, 0x0a, 0x10, 0x53, 0x70, 0x65, 0x65, 0x63, 0x68, 0x41, 0x64, 0x61, 0x70, 0x74, - 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x12, 0x5d, 0x0a, 0x0b, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x5f, - 0x73, 0x65, 0x74, 0x73, 0x18, 0x01, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x3c, 0x2e, 0x67, 0x6f, 0x6f, - 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, - 0x2e, 0x76, 0x32, 0x2e, 0x53, 0x70, 0x65, 0x65, 0x63, 0x68, 0x41, 0x64, 0x61, 0x70, 0x74, 0x61, - 0x74, 0x69, 0x6f, 0x6e, 0x2e, 0x41, 0x64, 0x61, 0x70, 0x74, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x50, - 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x52, 0x0a, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, - 0x53, 0x65, 0x74, 0x73, 0x12, 0x4a, 0x0a, 0x0e, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x5f, 0x63, - 0x6c, 0x61, 0x73, 0x73, 0x65, 0x73, 0x18, 0x02, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x23, 0x2e, 0x67, - 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, - 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, - 0x73, 0x52, 0x0d, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x65, 0x73, - 0x1a, 0xb6, 0x01, 0x0a, 0x13, 0x41, 0x64, 0x61, 0x70, 0x74, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x50, - 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x12, 0x45, 0x0a, 0x0a, 0x70, 0x68, 0x72, 0x61, - 0x73, 0x65, 0x5f, 0x73, 0x65, 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x24, 0xfa, 0x41, - 0x21, 0x0a, 0x1f, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, - 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, - 0x65, 0x74, 0x48, 0x00, 0x52, 0x09, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x12, - 0x4f, 0x0a, 0x11, 0x69, 0x6e, 0x6c, 0x69, 0x6e, 0x65, 0x5f, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, - 0x5f, 0x73, 0x65, 0x74, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x21, 0x2e, 0x67, 0x6f, 0x6f, - 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, - 0x2e, 0x76, 0x32, 0x2e, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x48, 0x00, 0x52, - 0x0f, 0x69, 0x6e, 0x6c, 0x69, 0x6e, 0x65, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, - 0x42, 0x07, 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x22, 0xa2, 0x05, 0x0a, 0x11, 0x52, 0x65, - 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, - 0x64, 0x0a, 0x14, 0x61, 0x75, 0x74, 0x6f, 0x5f, 0x64, 0x65, 0x63, 0x6f, 0x64, 0x69, 0x6e, 0x67, - 0x5f, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x18, 0x07, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x30, 0x2e, - 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, - 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x41, 0x75, 0x74, 0x6f, 0x44, 0x65, 0x74, 0x65, 0x63, - 0x74, 0x44, 0x65, 0x63, 0x6f, 0x64, 0x69, 0x6e, 0x67, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x48, - 0x00, 0x52, 0x12, 0x61, 0x75, 0x74, 0x6f, 0x44, 0x65, 0x63, 0x6f, 0x64, 0x69, 0x6e, 0x67, 0x43, - 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x6a, 0x0a, 0x18, 0x65, 0x78, 0x70, 0x6c, 0x69, 0x63, 0x69, - 0x74, 0x5f, 0x64, 0x65, 0x63, 0x6f, 0x64, 0x69, 0x6e, 0x67, 0x5f, 0x63, 0x6f, 0x6e, 0x66, 0x69, - 0x67, 0x18, 0x08, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x2e, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, + 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, + 0x46, 0x65, 0x61, 0x74, 0x75, 0x72, 0x65, 0x73, 0x2e, 0x4d, 0x75, 0x6c, 0x74, 0x69, 0x43, 0x68, + 0x61, 0x6e, 0x6e, 0x65, 0x6c, 0x4d, 0x6f, 0x64, 0x65, 0x52, 0x10, 0x6d, 0x75, 0x6c, 0x74, 0x69, + 0x43, 0x68, 0x61, 0x6e, 0x6e, 0x65, 0x6c, 0x4d, 0x6f, 0x64, 0x65, 0x12, 0x5f, 0x0a, 0x12, 0x64, + 0x69, 0x61, 0x72, 0x69, 0x7a, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x5f, 0x63, 0x6f, 0x6e, 0x66, 0x69, + 0x67, 0x18, 0x09, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x30, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, - 0x2e, 0x45, 0x78, 0x70, 0x6c, 0x69, 0x63, 0x69, 0x74, 0x44, 0x65, 0x63, 0x6f, 0x64, 0x69, 0x6e, - 0x67, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x48, 0x00, 0x52, 0x16, 0x65, 0x78, 0x70, 0x6c, 0x69, - 0x63, 0x69, 0x74, 0x44, 0x65, 0x63, 0x6f, 0x64, 0x69, 0x6e, 0x67, 0x43, 0x6f, 0x6e, 0x66, 0x69, - 0x67, 0x12, 0x19, 0x0a, 0x05, 0x6d, 0x6f, 0x64, 0x65, 0x6c, 0x18, 0x09, 0x20, 0x01, 0x28, 0x09, - 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x05, 0x6d, 0x6f, 0x64, 0x65, 0x6c, 0x12, 0x2a, 0x0a, 0x0e, - 0x6c, 0x61, 0x6e, 0x67, 0x75, 0x61, 0x67, 0x65, 0x5f, 0x63, 0x6f, 0x64, 0x65, 0x73, 0x18, 0x0a, - 0x20, 0x03, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0d, 0x6c, 0x61, 0x6e, 0x67, 0x75, - 0x61, 0x67, 0x65, 0x43, 0x6f, 0x64, 0x65, 0x73, 0x12, 0x47, 0x0a, 0x08, 0x66, 0x65, 0x61, 0x74, - 0x75, 0x72, 0x65, 0x73, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x2b, 0x2e, 0x67, 0x6f, 0x6f, - 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, - 0x2e, 0x76, 0x32, 0x2e, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x46, - 0x65, 0x61, 0x74, 0x75, 0x72, 0x65, 0x73, 0x52, 0x08, 0x66, 0x65, 0x61, 0x74, 0x75, 0x72, 0x65, - 0x73, 0x12, 0x48, 0x0a, 0x0a, 0x61, 0x64, 0x61, 0x70, 0x74, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x18, - 0x06, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x28, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, - 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x53, - 0x70, 0x65, 0x65, 0x63, 0x68, 0x41, 0x64, 0x61, 0x70, 0x74, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, - 0x0a, 0x61, 0x64, 0x61, 0x70, 0x74, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x12, 0x6f, 0x0a, 0x18, 0x74, - 0x72, 0x61, 0x6e, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x5f, 0x6e, 0x6f, 0x72, 0x6d, 0x61, 0x6c, - 0x69, 0x7a, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x18, 0x0b, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x2f, 0x2e, - 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, - 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x54, 0x72, 0x61, 0x6e, 0x73, 0x63, 0x72, 0x69, 0x70, - 0x74, 0x4e, 0x6f, 0x72, 0x6d, 0x61, 0x6c, 0x69, 0x7a, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x42, 0x03, - 0xe0, 0x41, 0x01, 0x52, 0x17, 0x74, 0x72, 0x61, 0x6e, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x4e, - 0x6f, 0x72, 0x6d, 0x61, 0x6c, 0x69, 0x7a, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x12, 0x5d, 0x0a, 0x12, - 0x74, 0x72, 0x61, 0x6e, 0x73, 0x6c, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x5f, 0x63, 0x6f, 0x6e, 0x66, - 0x69, 0x67, 0x18, 0x0f, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x29, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, - 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, - 0x32, 0x2e, 0x54, 0x72, 0x61, 0x6e, 0x73, 0x6c, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x43, 0x6f, 0x6e, - 0x66, 0x69, 0x67, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x11, 0x74, 0x72, 0x61, 0x6e, 0x73, 0x6c, - 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x42, 0x11, 0x0a, 0x0f, 0x64, - 0x65, 0x63, 0x6f, 0x64, 0x69, 0x6e, 0x67, 0x5f, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x22, 0x9c, - 0x02, 0x0a, 0x10, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x52, 0x65, 0x71, 0x75, - 0x65, 0x73, 0x74, 0x12, 0x48, 0x0a, 0x0a, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, - 0x72, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x42, 0x28, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x22, 0x0a, - 0x20, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, - 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, - 0x72, 0x52, 0x0a, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x12, 0x41, 0x0a, - 0x06, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x29, 0x2e, - 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, - 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, - 0x6f, 0x6e, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x52, 0x06, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, - 0x12, 0x3b, 0x0a, 0x0b, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x18, - 0x08, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, - 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x46, 0x69, 0x65, 0x6c, 0x64, 0x4d, 0x61, 0x73, - 0x6b, 0x52, 0x0a, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x4d, 0x61, 0x73, 0x6b, 0x12, 0x1a, 0x0a, - 0x07, 0x63, 0x6f, 0x6e, 0x74, 0x65, 0x6e, 0x74, 0x18, 0x05, 0x20, 0x01, 0x28, 0x0c, 0x48, 0x00, - 0x52, 0x07, 0x63, 0x6f, 0x6e, 0x74, 0x65, 0x6e, 0x74, 0x12, 0x12, 0x0a, 0x03, 0x75, 0x72, 0x69, - 0x18, 0x06, 0x20, 0x01, 0x28, 0x09, 0x48, 0x00, 0x52, 0x03, 0x75, 0x72, 0x69, 0x42, 0x0e, 0x0a, - 0x0c, 0x61, 0x75, 0x64, 0x69, 0x6f, 0x5f, 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, 0x22, 0x95, 0x01, - 0x0a, 0x1b, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x73, - 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x12, 0x27, 0x0a, - 0x0a, 0x72, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x5f, 0x69, 0x64, 0x18, 0x09, 0x20, 0x01, 0x28, - 0x09, 0x42, 0x08, 0xe2, 0x8c, 0xcf, 0xd7, 0x08, 0x02, 0x08, 0x01, 0x52, 0x09, 0x72, 0x65, 0x71, - 0x75, 0x65, 0x73, 0x74, 0x49, 0x64, 0x12, 0x4d, 0x0a, 0x15, 0x74, 0x6f, 0x74, 0x61, 0x6c, 0x5f, - 0x62, 0x69, 0x6c, 0x6c, 0x65, 0x64, 0x5f, 0x64, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x18, - 0x06, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x19, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, - 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x44, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, - 0x52, 0x13, 0x74, 0x6f, 0x74, 0x61, 0x6c, 0x42, 0x69, 0x6c, 0x6c, 0x65, 0x64, 0x44, 0x75, 0x72, - 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x22, 0x96, 0x01, 0x0a, 0x1c, 0x53, 0x70, 0x65, 0x65, 0x63, 0x68, - 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x41, 0x6c, 0x74, 0x65, 0x72, - 0x6e, 0x61, 0x74, 0x69, 0x76, 0x65, 0x12, 0x1e, 0x0a, 0x0a, 0x74, 0x72, 0x61, 0x6e, 0x73, 0x63, - 0x72, 0x69, 0x70, 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0a, 0x74, 0x72, 0x61, 0x6e, - 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x12, 0x1e, 0x0a, 0x0a, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x64, - 0x65, 0x6e, 0x63, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x02, 0x52, 0x0a, 0x63, 0x6f, 0x6e, 0x66, - 0x69, 0x64, 0x65, 0x6e, 0x63, 0x65, 0x12, 0x36, 0x0a, 0x05, 0x77, 0x6f, 0x72, 0x64, 0x73, 0x18, - 0x03, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x20, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, - 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x57, - 0x6f, 0x72, 0x64, 0x49, 0x6e, 0x66, 0x6f, 0x52, 0x05, 0x77, 0x6f, 0x72, 0x64, 0x73, 0x22, 0xdb, - 0x01, 0x0a, 0x08, 0x57, 0x6f, 0x72, 0x64, 0x49, 0x6e, 0x66, 0x6f, 0x12, 0x3c, 0x0a, 0x0c, 0x73, - 0x74, 0x61, 0x72, 0x74, 0x5f, 0x6f, 0x66, 0x66, 0x73, 0x65, 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, - 0x0b, 0x32, 0x19, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, - 0x62, 0x75, 0x66, 0x2e, 0x44, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x0b, 0x73, 0x74, - 0x61, 0x72, 0x74, 0x4f, 0x66, 0x66, 0x73, 0x65, 0x74, 0x12, 0x38, 0x0a, 0x0a, 0x65, 0x6e, 0x64, - 0x5f, 0x6f, 0x66, 0x66, 0x73, 0x65, 0x74, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x19, 0x2e, - 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, - 0x44, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x09, 0x65, 0x6e, 0x64, 0x4f, 0x66, 0x66, - 0x73, 0x65, 0x74, 0x12, 0x12, 0x0a, 0x04, 0x77, 0x6f, 0x72, 0x64, 0x18, 0x03, 0x20, 0x01, 0x28, - 0x09, 0x52, 0x04, 0x77, 0x6f, 0x72, 0x64, 0x12, 0x1e, 0x0a, 0x0a, 0x63, 0x6f, 0x6e, 0x66, 0x69, - 0x64, 0x65, 0x6e, 0x63, 0x65, 0x18, 0x04, 0x20, 0x01, 0x28, 0x02, 0x52, 0x0a, 0x63, 0x6f, 0x6e, - 0x66, 0x69, 0x64, 0x65, 0x6e, 0x63, 0x65, 0x12, 0x23, 0x0a, 0x0d, 0x73, 0x70, 0x65, 0x61, 0x6b, - 0x65, 0x72, 0x5f, 0x6c, 0x61, 0x62, 0x65, 0x6c, 0x18, 0x06, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0c, - 0x73, 0x70, 0x65, 0x61, 0x6b, 0x65, 0x72, 0x4c, 0x61, 0x62, 0x65, 0x6c, 0x22, 0x85, 0x02, 0x0a, - 0x17, 0x53, 0x70, 0x65, 0x65, 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, - 0x6f, 0x6e, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x12, 0x58, 0x0a, 0x0c, 0x61, 0x6c, 0x74, 0x65, - 0x72, 0x6e, 0x61, 0x74, 0x69, 0x76, 0x65, 0x73, 0x18, 0x01, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x34, + 0x2e, 0x53, 0x70, 0x65, 0x61, 0x6b, 0x65, 0x72, 0x44, 0x69, 0x61, 0x72, 0x69, 0x7a, 0x61, 0x74, + 0x69, 0x6f, 0x6e, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x52, 0x11, 0x64, 0x69, 0x61, 0x72, 0x69, + 0x7a, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x29, 0x0a, 0x10, + 0x6d, 0x61, 0x78, 0x5f, 0x61, 0x6c, 0x74, 0x65, 0x72, 0x6e, 0x61, 0x74, 0x69, 0x76, 0x65, 0x73, + 0x18, 0x10, 0x20, 0x01, 0x28, 0x05, 0x52, 0x0f, 0x6d, 0x61, 0x78, 0x41, 0x6c, 0x74, 0x65, 0x72, + 0x6e, 0x61, 0x74, 0x69, 0x76, 0x65, 0x73, 0x22, 0x5c, 0x0a, 0x10, 0x4d, 0x75, 0x6c, 0x74, 0x69, + 0x43, 0x68, 0x61, 0x6e, 0x6e, 0x65, 0x6c, 0x4d, 0x6f, 0x64, 0x65, 0x12, 0x22, 0x0a, 0x1e, 0x4d, + 0x55, 0x4c, 0x54, 0x49, 0x5f, 0x43, 0x48, 0x41, 0x4e, 0x4e, 0x45, 0x4c, 0x5f, 0x4d, 0x4f, 0x44, + 0x45, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, + 0x24, 0x0a, 0x20, 0x53, 0x45, 0x50, 0x41, 0x52, 0x41, 0x54, 0x45, 0x5f, 0x52, 0x45, 0x43, 0x4f, + 0x47, 0x4e, 0x49, 0x54, 0x49, 0x4f, 0x4e, 0x5f, 0x50, 0x45, 0x52, 0x5f, 0x43, 0x48, 0x41, 0x4e, + 0x4e, 0x45, 0x4c, 0x10, 0x01, 0x22, 0xcc, 0x01, 0x0a, 0x17, 0x54, 0x72, 0x61, 0x6e, 0x73, 0x63, + 0x72, 0x69, 0x70, 0x74, 0x4e, 0x6f, 0x72, 0x6d, 0x61, 0x6c, 0x69, 0x7a, 0x61, 0x74, 0x69, 0x6f, + 0x6e, 0x12, 0x4f, 0x0a, 0x07, 0x65, 0x6e, 0x74, 0x72, 0x69, 0x65, 0x73, 0x18, 0x01, 0x20, 0x03, + 0x28, 0x0b, 0x32, 0x35, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, + 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x54, 0x72, 0x61, 0x6e, + 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x4e, 0x6f, 0x72, 0x6d, 0x61, 0x6c, 0x69, 0x7a, 0x61, 0x74, + 0x69, 0x6f, 0x6e, 0x2e, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x52, 0x07, 0x65, 0x6e, 0x74, 0x72, 0x69, + 0x65, 0x73, 0x1a, 0x60, 0x0a, 0x05, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x16, 0x0a, 0x06, 0x73, + 0x65, 0x61, 0x72, 0x63, 0x68, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x06, 0x73, 0x65, 0x61, + 0x72, 0x63, 0x68, 0x12, 0x18, 0x0a, 0x07, 0x72, 0x65, 0x70, 0x6c, 0x61, 0x63, 0x65, 0x18, 0x02, + 0x20, 0x01, 0x28, 0x09, 0x52, 0x07, 0x72, 0x65, 0x70, 0x6c, 0x61, 0x63, 0x65, 0x12, 0x25, 0x0a, + 0x0e, 0x63, 0x61, 0x73, 0x65, 0x5f, 0x73, 0x65, 0x6e, 0x73, 0x69, 0x74, 0x69, 0x76, 0x65, 0x18, + 0x03, 0x20, 0x01, 0x28, 0x08, 0x52, 0x0d, 0x63, 0x61, 0x73, 0x65, 0x53, 0x65, 0x6e, 0x73, 0x69, + 0x74, 0x69, 0x76, 0x65, 0x22, 0x41, 0x0a, 0x11, 0x54, 0x72, 0x61, 0x6e, 0x73, 0x6c, 0x61, 0x74, + 0x69, 0x6f, 0x6e, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x2c, 0x0a, 0x0f, 0x74, 0x61, 0x72, + 0x67, 0x65, 0x74, 0x5f, 0x6c, 0x61, 0x6e, 0x67, 0x75, 0x61, 0x67, 0x65, 0x18, 0x01, 0x20, 0x01, + 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x0e, 0x74, 0x61, 0x72, 0x67, 0x65, 0x74, 0x4c, + 0x61, 0x6e, 0x67, 0x75, 0x61, 0x67, 0x65, 0x22, 0xf6, 0x02, 0x0a, 0x10, 0x53, 0x70, 0x65, 0x65, + 0x63, 0x68, 0x41, 0x64, 0x61, 0x70, 0x74, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x12, 0x5d, 0x0a, 0x0b, + 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x5f, 0x73, 0x65, 0x74, 0x73, 0x18, 0x01, 0x20, 0x03, 0x28, + 0x0b, 0x32, 0x3c, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, + 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x53, 0x70, 0x65, 0x65, 0x63, + 0x68, 0x41, 0x64, 0x61, 0x70, 0x74, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x2e, 0x41, 0x64, 0x61, 0x70, + 0x74, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x52, + 0x0a, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x73, 0x12, 0x4a, 0x0a, 0x0e, 0x63, + 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x5f, 0x63, 0x6c, 0x61, 0x73, 0x73, 0x65, 0x73, 0x18, 0x02, 0x20, + 0x03, 0x28, 0x0b, 0x32, 0x23, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, + 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x43, 0x75, 0x73, + 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x52, 0x0d, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, + 0x43, 0x6c, 0x61, 0x73, 0x73, 0x65, 0x73, 0x1a, 0xb6, 0x01, 0x0a, 0x13, 0x41, 0x64, 0x61, 0x70, + 0x74, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x12, + 0x45, 0x0a, 0x0a, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x5f, 0x73, 0x65, 0x74, 0x18, 0x01, 0x20, + 0x01, 0x28, 0x09, 0x42, 0x24, 0xfa, 0x41, 0x21, 0x0a, 0x1f, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, + 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, + 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x48, 0x00, 0x52, 0x09, 0x70, 0x68, 0x72, + 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x12, 0x4f, 0x0a, 0x11, 0x69, 0x6e, 0x6c, 0x69, 0x6e, 0x65, + 0x5f, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x5f, 0x73, 0x65, 0x74, 0x18, 0x02, 0x20, 0x01, 0x28, + 0x0b, 0x32, 0x21, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, + 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x50, 0x68, 0x72, 0x61, 0x73, + 0x65, 0x53, 0x65, 0x74, 0x48, 0x00, 0x52, 0x0f, 0x69, 0x6e, 0x6c, 0x69, 0x6e, 0x65, 0x50, 0x68, + 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x42, 0x07, 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, + 0x22, 0xa2, 0x05, 0x0a, 0x11, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, + 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x64, 0x0a, 0x14, 0x61, 0x75, 0x74, 0x6f, 0x5f, 0x64, + 0x65, 0x63, 0x6f, 0x64, 0x69, 0x6e, 0x67, 0x5f, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x18, 0x07, + 0x20, 0x01, 0x28, 0x0b, 0x32, 0x30, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, + 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x41, 0x75, + 0x74, 0x6f, 0x44, 0x65, 0x74, 0x65, 0x63, 0x74, 0x44, 0x65, 0x63, 0x6f, 0x64, 0x69, 0x6e, 0x67, + 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x48, 0x00, 0x52, 0x12, 0x61, 0x75, 0x74, 0x6f, 0x44, 0x65, + 0x63, 0x6f, 0x64, 0x69, 0x6e, 0x67, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x6a, 0x0a, 0x18, + 0x65, 0x78, 0x70, 0x6c, 0x69, 0x63, 0x69, 0x74, 0x5f, 0x64, 0x65, 0x63, 0x6f, 0x64, 0x69, 0x6e, + 0x67, 0x5f, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x18, 0x08, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x2e, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, - 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x53, 0x70, 0x65, 0x65, 0x63, 0x68, 0x52, 0x65, - 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x41, 0x6c, 0x74, 0x65, 0x72, 0x6e, 0x61, - 0x74, 0x69, 0x76, 0x65, 0x52, 0x0c, 0x61, 0x6c, 0x74, 0x65, 0x72, 0x6e, 0x61, 0x74, 0x69, 0x76, - 0x65, 0x73, 0x12, 0x1f, 0x0a, 0x0b, 0x63, 0x68, 0x61, 0x6e, 0x6e, 0x65, 0x6c, 0x5f, 0x74, 0x61, - 0x67, 0x18, 0x02, 0x20, 0x01, 0x28, 0x05, 0x52, 0x0a, 0x63, 0x68, 0x61, 0x6e, 0x6e, 0x65, 0x6c, - 0x54, 0x61, 0x67, 0x12, 0x45, 0x0a, 0x11, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x5f, 0x65, 0x6e, - 0x64, 0x5f, 0x6f, 0x66, 0x66, 0x73, 0x65, 0x74, 0x18, 0x04, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x19, - 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, - 0x2e, 0x44, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x0f, 0x72, 0x65, 0x73, 0x75, 0x6c, - 0x74, 0x45, 0x6e, 0x64, 0x4f, 0x66, 0x66, 0x73, 0x65, 0x74, 0x12, 0x28, 0x0a, 0x0d, 0x6c, 0x61, - 0x6e, 0x67, 0x75, 0x61, 0x67, 0x65, 0x5f, 0x63, 0x6f, 0x64, 0x65, 0x18, 0x05, 0x20, 0x01, 0x28, - 0x09, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x0c, 0x6c, 0x61, 0x6e, 0x67, 0x75, 0x61, 0x67, 0x65, - 0x43, 0x6f, 0x64, 0x65, 0x22, 0xaf, 0x01, 0x0a, 0x11, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, - 0x7a, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x49, 0x0a, 0x07, 0x72, 0x65, - 0x73, 0x75, 0x6c, 0x74, 0x73, 0x18, 0x03, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x2f, 0x2e, 0x67, 0x6f, - 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, - 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x53, 0x70, 0x65, 0x65, 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, - 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x52, 0x07, 0x72, 0x65, - 0x73, 0x75, 0x6c, 0x74, 0x73, 0x12, 0x4f, 0x0a, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, - 0x61, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x33, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, - 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, - 0x2e, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x73, 0x70, - 0x6f, 0x6e, 0x73, 0x65, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x52, 0x08, 0x6d, 0x65, - 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x22, 0xb8, 0x03, 0x0a, 0x1c, 0x53, 0x74, 0x72, 0x65, 0x61, - 0x6d, 0x69, 0x6e, 0x67, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x46, - 0x65, 0x61, 0x74, 0x75, 0x72, 0x65, 0x73, 0x12, 0x3f, 0x0a, 0x1c, 0x65, 0x6e, 0x61, 0x62, 0x6c, - 0x65, 0x5f, 0x76, 0x6f, 0x69, 0x63, 0x65, 0x5f, 0x61, 0x63, 0x74, 0x69, 0x76, 0x69, 0x74, 0x79, - 0x5f, 0x65, 0x76, 0x65, 0x6e, 0x74, 0x73, 0x18, 0x01, 0x20, 0x01, 0x28, 0x08, 0x52, 0x19, 0x65, - 0x6e, 0x61, 0x62, 0x6c, 0x65, 0x56, 0x6f, 0x69, 0x63, 0x65, 0x41, 0x63, 0x74, 0x69, 0x76, 0x69, - 0x74, 0x79, 0x45, 0x76, 0x65, 0x6e, 0x74, 0x73, 0x12, 0x27, 0x0a, 0x0f, 0x69, 0x6e, 0x74, 0x65, - 0x72, 0x69, 0x6d, 0x5f, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x73, 0x18, 0x02, 0x20, 0x01, 0x28, - 0x08, 0x52, 0x0e, 0x69, 0x6e, 0x74, 0x65, 0x72, 0x69, 0x6d, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, - 0x73, 0x12, 0x7f, 0x0a, 0x16, 0x76, 0x6f, 0x69, 0x63, 0x65, 0x5f, 0x61, 0x63, 0x74, 0x69, 0x76, - 0x69, 0x74, 0x79, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x6f, 0x75, 0x74, 0x18, 0x03, 0x20, 0x01, 0x28, - 0x0b, 0x32, 0x49, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, - 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x53, 0x74, 0x72, 0x65, 0x61, - 0x6d, 0x69, 0x6e, 0x67, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x46, - 0x65, 0x61, 0x74, 0x75, 0x72, 0x65, 0x73, 0x2e, 0x56, 0x6f, 0x69, 0x63, 0x65, 0x41, 0x63, 0x74, - 0x69, 0x76, 0x69, 0x74, 0x79, 0x54, 0x69, 0x6d, 0x65, 0x6f, 0x75, 0x74, 0x52, 0x14, 0x76, 0x6f, - 0x69, 0x63, 0x65, 0x41, 0x63, 0x74, 0x69, 0x76, 0x69, 0x74, 0x79, 0x54, 0x69, 0x6d, 0x65, 0x6f, - 0x75, 0x74, 0x1a, 0xac, 0x01, 0x0a, 0x14, 0x56, 0x6f, 0x69, 0x63, 0x65, 0x41, 0x63, 0x74, 0x69, - 0x76, 0x69, 0x74, 0x79, 0x54, 0x69, 0x6d, 0x65, 0x6f, 0x75, 0x74, 0x12, 0x4b, 0x0a, 0x14, 0x73, - 0x70, 0x65, 0x65, 0x63, 0x68, 0x5f, 0x73, 0x74, 0x61, 0x72, 0x74, 0x5f, 0x74, 0x69, 0x6d, 0x65, - 0x6f, 0x75, 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x19, 0x2e, 0x67, 0x6f, 0x6f, 0x67, - 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x44, 0x75, 0x72, 0x61, - 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x12, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x53, 0x74, 0x61, 0x72, - 0x74, 0x54, 0x69, 0x6d, 0x65, 0x6f, 0x75, 0x74, 0x12, 0x47, 0x0a, 0x12, 0x73, 0x70, 0x65, 0x65, - 0x63, 0x68, 0x5f, 0x65, 0x6e, 0x64, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x6f, 0x75, 0x74, 0x18, 0x02, - 0x20, 0x01, 0x28, 0x0b, 0x32, 0x19, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, - 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x44, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, - 0x10, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x45, 0x6e, 0x64, 0x54, 0x69, 0x6d, 0x65, 0x6f, 0x75, - 0x74, 0x22, 0x86, 0x02, 0x0a, 0x1a, 0x53, 0x74, 0x72, 0x65, 0x61, 0x6d, 0x69, 0x6e, 0x67, 0x52, - 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, - 0x12, 0x46, 0x0a, 0x06, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, - 0x32, 0x29, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, - 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, - 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x42, 0x03, 0xe0, 0x41, 0x02, - 0x52, 0x06, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x3b, 0x0a, 0x0b, 0x63, 0x6f, 0x6e, 0x66, - 0x69, 0x67, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x18, 0x03, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, - 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, - 0x46, 0x69, 0x65, 0x6c, 0x64, 0x4d, 0x61, 0x73, 0x6b, 0x52, 0x0a, 0x63, 0x6f, 0x6e, 0x66, 0x69, - 0x67, 0x4d, 0x61, 0x73, 0x6b, 0x12, 0x63, 0x0a, 0x12, 0x73, 0x74, 0x72, 0x65, 0x61, 0x6d, 0x69, - 0x6e, 0x67, 0x5f, 0x66, 0x65, 0x61, 0x74, 0x75, 0x72, 0x65, 0x73, 0x18, 0x02, 0x20, 0x01, 0x28, - 0x0b, 0x32, 0x34, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, - 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x53, 0x74, 0x72, 0x65, 0x61, - 0x6d, 0x69, 0x6e, 0x67, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x46, - 0x65, 0x61, 0x74, 0x75, 0x72, 0x65, 0x73, 0x52, 0x11, 0x73, 0x74, 0x72, 0x65, 0x61, 0x6d, 0x69, - 0x6e, 0x67, 0x46, 0x65, 0x61, 0x74, 0x75, 0x72, 0x65, 0x73, 0x22, 0xf3, 0x01, 0x0a, 0x19, 0x53, - 0x74, 0x72, 0x65, 0x61, 0x6d, 0x69, 0x6e, 0x67, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, - 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x48, 0x0a, 0x0a, 0x72, 0x65, 0x63, 0x6f, - 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x42, 0x28, 0xe0, 0x41, - 0x02, 0xfa, 0x41, 0x22, 0x0a, 0x20, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x67, 0x6f, 0x6f, - 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x52, 0x65, 0x63, 0x6f, - 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x52, 0x0a, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, - 0x65, 0x72, 0x12, 0x5f, 0x0a, 0x10, 0x73, 0x74, 0x72, 0x65, 0x61, 0x6d, 0x69, 0x6e, 0x67, 0x5f, - 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x18, 0x06, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x32, 0x2e, 0x67, + 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x45, 0x78, 0x70, 0x6c, 0x69, 0x63, 0x69, 0x74, + 0x44, 0x65, 0x63, 0x6f, 0x64, 0x69, 0x6e, 0x67, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x48, 0x00, + 0x52, 0x16, 0x65, 0x78, 0x70, 0x6c, 0x69, 0x63, 0x69, 0x74, 0x44, 0x65, 0x63, 0x6f, 0x64, 0x69, + 0x6e, 0x67, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x19, 0x0a, 0x05, 0x6d, 0x6f, 0x64, 0x65, + 0x6c, 0x18, 0x09, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x05, 0x6d, 0x6f, + 0x64, 0x65, 0x6c, 0x12, 0x2a, 0x0a, 0x0e, 0x6c, 0x61, 0x6e, 0x67, 0x75, 0x61, 0x67, 0x65, 0x5f, + 0x63, 0x6f, 0x64, 0x65, 0x73, 0x18, 0x0a, 0x20, 0x03, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, + 0x52, 0x0d, 0x6c, 0x61, 0x6e, 0x67, 0x75, 0x61, 0x67, 0x65, 0x43, 0x6f, 0x64, 0x65, 0x73, 0x12, + 0x47, 0x0a, 0x08, 0x66, 0x65, 0x61, 0x74, 0x75, 0x72, 0x65, 0x73, 0x18, 0x02, 0x20, 0x01, 0x28, + 0x0b, 0x32, 0x2b, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, + 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x52, 0x65, 0x63, 0x6f, 0x67, + 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x46, 0x65, 0x61, 0x74, 0x75, 0x72, 0x65, 0x73, 0x52, 0x08, + 0x66, 0x65, 0x61, 0x74, 0x75, 0x72, 0x65, 0x73, 0x12, 0x48, 0x0a, 0x0a, 0x61, 0x64, 0x61, 0x70, + 0x74, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x18, 0x06, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x28, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, - 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x53, 0x74, 0x72, 0x65, 0x61, 0x6d, 0x69, 0x6e, 0x67, 0x52, - 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, - 0x48, 0x00, 0x52, 0x0f, 0x73, 0x74, 0x72, 0x65, 0x61, 0x6d, 0x69, 0x6e, 0x67, 0x43, 0x6f, 0x6e, - 0x66, 0x69, 0x67, 0x12, 0x16, 0x0a, 0x05, 0x61, 0x75, 0x64, 0x69, 0x6f, 0x18, 0x05, 0x20, 0x01, - 0x28, 0x0c, 0x48, 0x00, 0x52, 0x05, 0x61, 0x75, 0x64, 0x69, 0x6f, 0x42, 0x13, 0x0a, 0x11, 0x73, - 0x74, 0x72, 0x65, 0x61, 0x6d, 0x69, 0x6e, 0x67, 0x5f, 0x72, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, - 0x22, 0xdc, 0x04, 0x0a, 0x15, 0x42, 0x61, 0x74, 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, + 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x53, 0x70, 0x65, 0x65, 0x63, 0x68, 0x41, 0x64, 0x61, 0x70, + 0x74, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x0a, 0x61, 0x64, 0x61, 0x70, 0x74, 0x61, 0x74, 0x69, + 0x6f, 0x6e, 0x12, 0x6f, 0x0a, 0x18, 0x74, 0x72, 0x61, 0x6e, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, + 0x5f, 0x6e, 0x6f, 0x72, 0x6d, 0x61, 0x6c, 0x69, 0x7a, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x18, 0x0b, + 0x20, 0x01, 0x28, 0x0b, 0x32, 0x2f, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, + 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x54, 0x72, + 0x61, 0x6e, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x4e, 0x6f, 0x72, 0x6d, 0x61, 0x6c, 0x69, 0x7a, + 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x17, 0x74, 0x72, 0x61, 0x6e, + 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x4e, 0x6f, 0x72, 0x6d, 0x61, 0x6c, 0x69, 0x7a, 0x61, 0x74, + 0x69, 0x6f, 0x6e, 0x12, 0x5d, 0x0a, 0x12, 0x74, 0x72, 0x61, 0x6e, 0x73, 0x6c, 0x61, 0x74, 0x69, + 0x6f, 0x6e, 0x5f, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x18, 0x0f, 0x20, 0x01, 0x28, 0x0b, 0x32, + 0x29, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, + 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x54, 0x72, 0x61, 0x6e, 0x73, 0x6c, 0x61, + 0x74, 0x69, 0x6f, 0x6e, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, + 0x11, 0x74, 0x72, 0x61, 0x6e, 0x73, 0x6c, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x43, 0x6f, 0x6e, 0x66, + 0x69, 0x67, 0x42, 0x11, 0x0a, 0x0f, 0x64, 0x65, 0x63, 0x6f, 0x64, 0x69, 0x6e, 0x67, 0x5f, 0x63, + 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x22, 0x9c, 0x02, 0x0a, 0x10, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x48, 0x0a, 0x0a, 0x72, 0x65, - 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x28, + 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x42, 0x28, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x22, 0x0a, 0x20, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x52, 0x0a, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, - 0x69, 0x7a, 0x65, 0x72, 0x12, 0x41, 0x0a, 0x06, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x18, 0x04, + 0x69, 0x7a, 0x65, 0x72, 0x12, 0x41, 0x0a, 0x06, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x29, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x52, 0x06, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x3b, 0x0a, 0x0b, 0x63, 0x6f, 0x6e, 0x66, 0x69, - 0x67, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x18, 0x05, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, + 0x67, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x18, 0x08, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x46, 0x69, 0x65, 0x6c, 0x64, 0x4d, 0x61, 0x73, 0x6b, 0x52, 0x0a, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, - 0x4d, 0x61, 0x73, 0x6b, 0x12, 0x48, 0x0a, 0x05, 0x66, 0x69, 0x6c, 0x65, 0x73, 0x18, 0x03, 0x20, - 0x03, 0x28, 0x0b, 0x32, 0x32, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, - 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x42, 0x61, 0x74, - 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x46, 0x69, 0x6c, 0x65, 0x4d, - 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x52, 0x05, 0x66, 0x69, 0x6c, 0x65, 0x73, 0x12, 0x6b, - 0x0a, 0x19, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x5f, 0x6f, 0x75, - 0x74, 0x70, 0x75, 0x74, 0x5f, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x18, 0x06, 0x20, 0x01, 0x28, - 0x0b, 0x32, 0x2f, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, - 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x52, 0x65, 0x63, 0x6f, 0x67, - 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x4f, 0x75, 0x74, 0x70, 0x75, 0x74, 0x43, 0x6f, 0x6e, 0x66, - 0x69, 0x67, 0x52, 0x17, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x4f, - 0x75, 0x74, 0x70, 0x75, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x71, 0x0a, 0x13, 0x70, - 0x72, 0x6f, 0x63, 0x65, 0x73, 0x73, 0x69, 0x6e, 0x67, 0x5f, 0x73, 0x74, 0x72, 0x61, 0x74, 0x65, - 0x67, 0x79, 0x18, 0x07, 0x20, 0x01, 0x28, 0x0e, 0x32, 0x40, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, + 0x4d, 0x61, 0x73, 0x6b, 0x12, 0x1a, 0x0a, 0x07, 0x63, 0x6f, 0x6e, 0x74, 0x65, 0x6e, 0x74, 0x18, + 0x05, 0x20, 0x01, 0x28, 0x0c, 0x48, 0x00, 0x52, 0x07, 0x63, 0x6f, 0x6e, 0x74, 0x65, 0x6e, 0x74, + 0x12, 0x12, 0x0a, 0x03, 0x75, 0x72, 0x69, 0x18, 0x06, 0x20, 0x01, 0x28, 0x09, 0x48, 0x00, 0x52, + 0x03, 0x75, 0x72, 0x69, 0x42, 0x0e, 0x0a, 0x0c, 0x61, 0x75, 0x64, 0x69, 0x6f, 0x5f, 0x73, 0x6f, + 0x75, 0x72, 0x63, 0x65, 0x22, 0x95, 0x01, 0x0a, 0x1b, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, + 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x4d, 0x65, 0x74, 0x61, + 0x64, 0x61, 0x74, 0x61, 0x12, 0x27, 0x0a, 0x0a, 0x72, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x5f, + 0x69, 0x64, 0x18, 0x09, 0x20, 0x01, 0x28, 0x09, 0x42, 0x08, 0xe2, 0x8c, 0xcf, 0xd7, 0x08, 0x02, + 0x08, 0x01, 0x52, 0x09, 0x72, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x49, 0x64, 0x12, 0x4d, 0x0a, + 0x15, 0x74, 0x6f, 0x74, 0x61, 0x6c, 0x5f, 0x62, 0x69, 0x6c, 0x6c, 0x65, 0x64, 0x5f, 0x64, 0x75, + 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x18, 0x06, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x19, 0x2e, 0x67, + 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x44, + 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x13, 0x74, 0x6f, 0x74, 0x61, 0x6c, 0x42, 0x69, + 0x6c, 0x6c, 0x65, 0x64, 0x44, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x22, 0x96, 0x01, 0x0a, + 0x1c, 0x53, 0x70, 0x65, 0x65, 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, + 0x6f, 0x6e, 0x41, 0x6c, 0x74, 0x65, 0x72, 0x6e, 0x61, 0x74, 0x69, 0x76, 0x65, 0x12, 0x1e, 0x0a, + 0x0a, 0x74, 0x72, 0x61, 0x6e, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, + 0x09, 0x52, 0x0a, 0x74, 0x72, 0x61, 0x6e, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x12, 0x1e, 0x0a, + 0x0a, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x64, 0x65, 0x6e, 0x63, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, + 0x02, 0x52, 0x0a, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x64, 0x65, 0x6e, 0x63, 0x65, 0x12, 0x36, 0x0a, + 0x05, 0x77, 0x6f, 0x72, 0x64, 0x73, 0x18, 0x03, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x20, 0x2e, 0x67, + 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, + 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x57, 0x6f, 0x72, 0x64, 0x49, 0x6e, 0x66, 0x6f, 0x52, 0x05, + 0x77, 0x6f, 0x72, 0x64, 0x73, 0x22, 0xdb, 0x01, 0x0a, 0x08, 0x57, 0x6f, 0x72, 0x64, 0x49, 0x6e, + 0x66, 0x6f, 0x12, 0x3c, 0x0a, 0x0c, 0x73, 0x74, 0x61, 0x72, 0x74, 0x5f, 0x6f, 0x66, 0x66, 0x73, + 0x65, 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x19, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, + 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x44, 0x75, 0x72, 0x61, 0x74, + 0x69, 0x6f, 0x6e, 0x52, 0x0b, 0x73, 0x74, 0x61, 0x72, 0x74, 0x4f, 0x66, 0x66, 0x73, 0x65, 0x74, + 0x12, 0x38, 0x0a, 0x0a, 0x65, 0x6e, 0x64, 0x5f, 0x6f, 0x66, 0x66, 0x73, 0x65, 0x74, 0x18, 0x02, + 0x20, 0x01, 0x28, 0x0b, 0x32, 0x19, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, + 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x44, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, + 0x09, 0x65, 0x6e, 0x64, 0x4f, 0x66, 0x66, 0x73, 0x65, 0x74, 0x12, 0x12, 0x0a, 0x04, 0x77, 0x6f, + 0x72, 0x64, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x52, 0x04, 0x77, 0x6f, 0x72, 0x64, 0x12, 0x1e, + 0x0a, 0x0a, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x64, 0x65, 0x6e, 0x63, 0x65, 0x18, 0x04, 0x20, 0x01, + 0x28, 0x02, 0x52, 0x0a, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x64, 0x65, 0x6e, 0x63, 0x65, 0x12, 0x23, + 0x0a, 0x0d, 0x73, 0x70, 0x65, 0x61, 0x6b, 0x65, 0x72, 0x5f, 0x6c, 0x61, 0x62, 0x65, 0x6c, 0x18, + 0x06, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0c, 0x73, 0x70, 0x65, 0x61, 0x6b, 0x65, 0x72, 0x4c, 0x61, + 0x62, 0x65, 0x6c, 0x22, 0x85, 0x02, 0x0a, 0x17, 0x53, 0x70, 0x65, 0x65, 0x63, 0x68, 0x52, 0x65, + 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x12, + 0x58, 0x0a, 0x0c, 0x61, 0x6c, 0x74, 0x65, 0x72, 0x6e, 0x61, 0x74, 0x69, 0x76, 0x65, 0x73, 0x18, + 0x01, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x34, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, + 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x53, + 0x70, 0x65, 0x65, 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, + 0x41, 0x6c, 0x74, 0x65, 0x72, 0x6e, 0x61, 0x74, 0x69, 0x76, 0x65, 0x52, 0x0c, 0x61, 0x6c, 0x74, + 0x65, 0x72, 0x6e, 0x61, 0x74, 0x69, 0x76, 0x65, 0x73, 0x12, 0x1f, 0x0a, 0x0b, 0x63, 0x68, 0x61, + 0x6e, 0x6e, 0x65, 0x6c, 0x5f, 0x74, 0x61, 0x67, 0x18, 0x02, 0x20, 0x01, 0x28, 0x05, 0x52, 0x0a, + 0x63, 0x68, 0x61, 0x6e, 0x6e, 0x65, 0x6c, 0x54, 0x61, 0x67, 0x12, 0x45, 0x0a, 0x11, 0x72, 0x65, + 0x73, 0x75, 0x6c, 0x74, 0x5f, 0x65, 0x6e, 0x64, 0x5f, 0x6f, 0x66, 0x66, 0x73, 0x65, 0x74, 0x18, + 0x04, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x19, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, + 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x44, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, + 0x52, 0x0f, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x45, 0x6e, 0x64, 0x4f, 0x66, 0x66, 0x73, 0x65, + 0x74, 0x12, 0x28, 0x0a, 0x0d, 0x6c, 0x61, 0x6e, 0x67, 0x75, 0x61, 0x67, 0x65, 0x5f, 0x63, 0x6f, + 0x64, 0x65, 0x18, 0x05, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x0c, 0x6c, + 0x61, 0x6e, 0x67, 0x75, 0x61, 0x67, 0x65, 0x43, 0x6f, 0x64, 0x65, 0x22, 0xaf, 0x01, 0x0a, 0x11, + 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, + 0x65, 0x12, 0x49, 0x0a, 0x07, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x73, 0x18, 0x03, 0x20, 0x03, + 0x28, 0x0b, 0x32, 0x2f, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, + 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x53, 0x70, 0x65, 0x65, + 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x73, + 0x75, 0x6c, 0x74, 0x52, 0x07, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x73, 0x12, 0x4f, 0x0a, 0x08, + 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x33, + 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, + 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, + 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x4d, 0x65, 0x74, 0x61, 0x64, + 0x61, 0x74, 0x61, 0x52, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x22, 0xb8, 0x03, + 0x0a, 0x1c, 0x53, 0x74, 0x72, 0x65, 0x61, 0x6d, 0x69, 0x6e, 0x67, 0x52, 0x65, 0x63, 0x6f, 0x67, + 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x46, 0x65, 0x61, 0x74, 0x75, 0x72, 0x65, 0x73, 0x12, 0x3f, + 0x0a, 0x1c, 0x65, 0x6e, 0x61, 0x62, 0x6c, 0x65, 0x5f, 0x76, 0x6f, 0x69, 0x63, 0x65, 0x5f, 0x61, + 0x63, 0x74, 0x69, 0x76, 0x69, 0x74, 0x79, 0x5f, 0x65, 0x76, 0x65, 0x6e, 0x74, 0x73, 0x18, 0x01, + 0x20, 0x01, 0x28, 0x08, 0x52, 0x19, 0x65, 0x6e, 0x61, 0x62, 0x6c, 0x65, 0x56, 0x6f, 0x69, 0x63, + 0x65, 0x41, 0x63, 0x74, 0x69, 0x76, 0x69, 0x74, 0x79, 0x45, 0x76, 0x65, 0x6e, 0x74, 0x73, 0x12, + 0x27, 0x0a, 0x0f, 0x69, 0x6e, 0x74, 0x65, 0x72, 0x69, 0x6d, 0x5f, 0x72, 0x65, 0x73, 0x75, 0x6c, + 0x74, 0x73, 0x18, 0x02, 0x20, 0x01, 0x28, 0x08, 0x52, 0x0e, 0x69, 0x6e, 0x74, 0x65, 0x72, 0x69, + 0x6d, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x73, 0x12, 0x7f, 0x0a, 0x16, 0x76, 0x6f, 0x69, 0x63, + 0x65, 0x5f, 0x61, 0x63, 0x74, 0x69, 0x76, 0x69, 0x74, 0x79, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x6f, + 0x75, 0x74, 0x18, 0x03, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x49, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, - 0x32, 0x2e, 0x42, 0x61, 0x74, 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, - 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x2e, 0x50, 0x72, 0x6f, 0x63, 0x65, 0x73, 0x73, 0x69, - 0x6e, 0x67, 0x53, 0x74, 0x72, 0x61, 0x74, 0x65, 0x67, 0x79, 0x52, 0x12, 0x70, 0x72, 0x6f, 0x63, - 0x65, 0x73, 0x73, 0x69, 0x6e, 0x67, 0x53, 0x74, 0x72, 0x61, 0x74, 0x65, 0x67, 0x79, 0x22, 0x4f, - 0x0a, 0x12, 0x50, 0x72, 0x6f, 0x63, 0x65, 0x73, 0x73, 0x69, 0x6e, 0x67, 0x53, 0x74, 0x72, 0x61, - 0x74, 0x65, 0x67, 0x79, 0x12, 0x23, 0x0a, 0x1f, 0x50, 0x52, 0x4f, 0x43, 0x45, 0x53, 0x53, 0x49, - 0x4e, 0x47, 0x5f, 0x53, 0x54, 0x52, 0x41, 0x54, 0x45, 0x47, 0x59, 0x5f, 0x55, 0x4e, 0x53, 0x50, - 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x14, 0x0a, 0x10, 0x44, 0x59, 0x4e, - 0x41, 0x4d, 0x49, 0x43, 0x5f, 0x42, 0x41, 0x54, 0x43, 0x48, 0x49, 0x4e, 0x47, 0x10, 0x01, 0x22, - 0x23, 0x0a, 0x0f, 0x47, 0x63, 0x73, 0x4f, 0x75, 0x74, 0x70, 0x75, 0x74, 0x43, 0x6f, 0x6e, 0x66, - 0x69, 0x67, 0x12, 0x10, 0x0a, 0x03, 0x75, 0x72, 0x69, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, - 0x03, 0x75, 0x72, 0x69, 0x22, 0x14, 0x0a, 0x12, 0x49, 0x6e, 0x6c, 0x69, 0x6e, 0x65, 0x4f, 0x75, - 0x74, 0x70, 0x75, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x22, 0x1e, 0x0a, 0x1c, 0x4e, 0x61, - 0x74, 0x69, 0x76, 0x65, 0x4f, 0x75, 0x74, 0x70, 0x75, 0x74, 0x46, 0x69, 0x6c, 0x65, 0x46, 0x6f, - 0x72, 0x6d, 0x61, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x22, 0x1b, 0x0a, 0x19, 0x56, 0x74, - 0x74, 0x4f, 0x75, 0x74, 0x70, 0x75, 0x74, 0x46, 0x69, 0x6c, 0x65, 0x46, 0x6f, 0x72, 0x6d, 0x61, - 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x22, 0x1b, 0x0a, 0x19, 0x53, 0x72, 0x74, 0x4f, 0x75, - 0x74, 0x70, 0x75, 0x74, 0x46, 0x69, 0x6c, 0x65, 0x46, 0x6f, 0x72, 0x6d, 0x61, 0x74, 0x43, 0x6f, - 0x6e, 0x66, 0x69, 0x67, 0x22, 0xec, 0x01, 0x0a, 0x12, 0x4f, 0x75, 0x74, 0x70, 0x75, 0x74, 0x46, - 0x6f, 0x72, 0x6d, 0x61, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x4c, 0x0a, 0x06, 0x6e, - 0x61, 0x74, 0x69, 0x76, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x34, 0x2e, 0x67, 0x6f, - 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, - 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x4e, 0x61, 0x74, 0x69, 0x76, 0x65, 0x4f, 0x75, 0x74, 0x70, 0x75, - 0x74, 0x46, 0x69, 0x6c, 0x65, 0x46, 0x6f, 0x72, 0x6d, 0x61, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, - 0x67, 0x52, 0x06, 0x6e, 0x61, 0x74, 0x69, 0x76, 0x65, 0x12, 0x43, 0x0a, 0x03, 0x76, 0x74, 0x74, - 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x31, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, - 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, - 0x56, 0x74, 0x74, 0x4f, 0x75, 0x74, 0x70, 0x75, 0x74, 0x46, 0x69, 0x6c, 0x65, 0x46, 0x6f, 0x72, - 0x6d, 0x61, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x52, 0x03, 0x76, 0x74, 0x74, 0x12, 0x43, - 0x0a, 0x03, 0x73, 0x72, 0x74, 0x18, 0x03, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x31, 0x2e, 0x67, 0x6f, + 0x32, 0x2e, 0x53, 0x74, 0x72, 0x65, 0x61, 0x6d, 0x69, 0x6e, 0x67, 0x52, 0x65, 0x63, 0x6f, 0x67, + 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x46, 0x65, 0x61, 0x74, 0x75, 0x72, 0x65, 0x73, 0x2e, 0x56, + 0x6f, 0x69, 0x63, 0x65, 0x41, 0x63, 0x74, 0x69, 0x76, 0x69, 0x74, 0x79, 0x54, 0x69, 0x6d, 0x65, + 0x6f, 0x75, 0x74, 0x52, 0x14, 0x76, 0x6f, 0x69, 0x63, 0x65, 0x41, 0x63, 0x74, 0x69, 0x76, 0x69, + 0x74, 0x79, 0x54, 0x69, 0x6d, 0x65, 0x6f, 0x75, 0x74, 0x1a, 0xac, 0x01, 0x0a, 0x14, 0x56, 0x6f, + 0x69, 0x63, 0x65, 0x41, 0x63, 0x74, 0x69, 0x76, 0x69, 0x74, 0x79, 0x54, 0x69, 0x6d, 0x65, 0x6f, + 0x75, 0x74, 0x12, 0x4b, 0x0a, 0x14, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x5f, 0x73, 0x74, 0x61, + 0x72, 0x74, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x6f, 0x75, 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, + 0x32, 0x19, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, + 0x75, 0x66, 0x2e, 0x44, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x12, 0x73, 0x70, 0x65, + 0x65, 0x63, 0x68, 0x53, 0x74, 0x61, 0x72, 0x74, 0x54, 0x69, 0x6d, 0x65, 0x6f, 0x75, 0x74, 0x12, + 0x47, 0x0a, 0x12, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x5f, 0x65, 0x6e, 0x64, 0x5f, 0x74, 0x69, + 0x6d, 0x65, 0x6f, 0x75, 0x74, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x19, 0x2e, 0x67, 0x6f, + 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x44, 0x75, + 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x10, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x45, 0x6e, + 0x64, 0x54, 0x69, 0x6d, 0x65, 0x6f, 0x75, 0x74, 0x22, 0x86, 0x02, 0x0a, 0x1a, 0x53, 0x74, 0x72, + 0x65, 0x61, 0x6d, 0x69, 0x6e, 0x67, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, + 0x6e, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x46, 0x0a, 0x06, 0x63, 0x6f, 0x6e, 0x66, 0x69, + 0x67, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x29, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, + 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, + 0x2e, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x43, 0x6f, 0x6e, 0x66, + 0x69, 0x67, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x06, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, + 0x3b, 0x0a, 0x0b, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x18, 0x03, + 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, + 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x46, 0x69, 0x65, 0x6c, 0x64, 0x4d, 0x61, 0x73, 0x6b, + 0x52, 0x0a, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x4d, 0x61, 0x73, 0x6b, 0x12, 0x63, 0x0a, 0x12, + 0x73, 0x74, 0x72, 0x65, 0x61, 0x6d, 0x69, 0x6e, 0x67, 0x5f, 0x66, 0x65, 0x61, 0x74, 0x75, 0x72, + 0x65, 0x73, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x34, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, + 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, + 0x32, 0x2e, 0x53, 0x74, 0x72, 0x65, 0x61, 0x6d, 0x69, 0x6e, 0x67, 0x52, 0x65, 0x63, 0x6f, 0x67, + 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x46, 0x65, 0x61, 0x74, 0x75, 0x72, 0x65, 0x73, 0x52, 0x11, + 0x73, 0x74, 0x72, 0x65, 0x61, 0x6d, 0x69, 0x6e, 0x67, 0x46, 0x65, 0x61, 0x74, 0x75, 0x72, 0x65, + 0x73, 0x22, 0xf3, 0x01, 0x0a, 0x19, 0x53, 0x74, 0x72, 0x65, 0x61, 0x6d, 0x69, 0x6e, 0x67, 0x52, + 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, + 0x48, 0x0a, 0x0a, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x18, 0x03, 0x20, + 0x01, 0x28, 0x09, 0x42, 0x28, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x22, 0x0a, 0x20, 0x73, 0x70, 0x65, + 0x65, 0x63, 0x68, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, + 0x6f, 0x6d, 0x2f, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x52, 0x0a, 0x72, + 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x12, 0x5f, 0x0a, 0x10, 0x73, 0x74, 0x72, + 0x65, 0x61, 0x6d, 0x69, 0x6e, 0x67, 0x5f, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x18, 0x06, 0x20, + 0x01, 0x28, 0x0b, 0x32, 0x32, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, + 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x53, 0x74, 0x72, + 0x65, 0x61, 0x6d, 0x69, 0x6e, 0x67, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, + 0x6e, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x48, 0x00, 0x52, 0x0f, 0x73, 0x74, 0x72, 0x65, 0x61, + 0x6d, 0x69, 0x6e, 0x67, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x16, 0x0a, 0x05, 0x61, 0x75, + 0x64, 0x69, 0x6f, 0x18, 0x05, 0x20, 0x01, 0x28, 0x0c, 0x48, 0x00, 0x52, 0x05, 0x61, 0x75, 0x64, + 0x69, 0x6f, 0x42, 0x13, 0x0a, 0x11, 0x73, 0x74, 0x72, 0x65, 0x61, 0x6d, 0x69, 0x6e, 0x67, 0x5f, + 0x72, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x22, 0xdc, 0x04, 0x0a, 0x15, 0x42, 0x61, 0x74, 0x63, + 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, + 0x74, 0x12, 0x48, 0x0a, 0x0a, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x18, + 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x28, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x22, 0x0a, 0x20, 0x73, + 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, + 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x52, + 0x0a, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x12, 0x41, 0x0a, 0x06, 0x63, + 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x18, 0x04, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x29, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, - 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x53, 0x72, 0x74, 0x4f, 0x75, 0x74, 0x70, 0x75, 0x74, 0x46, 0x69, - 0x6c, 0x65, 0x46, 0x6f, 0x72, 0x6d, 0x61, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x52, 0x03, - 0x73, 0x72, 0x74, 0x22, 0xc1, 0x02, 0x0a, 0x17, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, - 0x69, 0x6f, 0x6e, 0x4f, 0x75, 0x74, 0x70, 0x75, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, - 0x55, 0x0a, 0x11, 0x67, 0x63, 0x73, 0x5f, 0x6f, 0x75, 0x74, 0x70, 0x75, 0x74, 0x5f, 0x63, 0x6f, - 0x6e, 0x66, 0x69, 0x67, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x27, 0x2e, 0x67, 0x6f, 0x6f, + 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, + 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x52, 0x06, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x3b, + 0x0a, 0x0b, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x18, 0x05, 0x20, + 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, + 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x46, 0x69, 0x65, 0x6c, 0x64, 0x4d, 0x61, 0x73, 0x6b, 0x52, + 0x0a, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x4d, 0x61, 0x73, 0x6b, 0x12, 0x48, 0x0a, 0x05, 0x66, + 0x69, 0x6c, 0x65, 0x73, 0x18, 0x03, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x32, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, - 0x2e, 0x76, 0x32, 0x2e, 0x47, 0x63, 0x73, 0x4f, 0x75, 0x74, 0x70, 0x75, 0x74, 0x43, 0x6f, 0x6e, - 0x66, 0x69, 0x67, 0x48, 0x00, 0x52, 0x0f, 0x67, 0x63, 0x73, 0x4f, 0x75, 0x74, 0x70, 0x75, 0x74, - 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x62, 0x0a, 0x16, 0x69, 0x6e, 0x6c, 0x69, 0x6e, 0x65, - 0x5f, 0x72, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x5f, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, - 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x2a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, - 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, - 0x49, 0x6e, 0x6c, 0x69, 0x6e, 0x65, 0x4f, 0x75, 0x74, 0x70, 0x75, 0x74, 0x43, 0x6f, 0x6e, 0x66, - 0x69, 0x67, 0x48, 0x00, 0x52, 0x14, 0x69, 0x6e, 0x6c, 0x69, 0x6e, 0x65, 0x52, 0x65, 0x73, 0x70, - 0x6f, 0x6e, 0x73, 0x65, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x61, 0x0a, 0x14, 0x6f, 0x75, - 0x74, 0x70, 0x75, 0x74, 0x5f, 0x66, 0x6f, 0x72, 0x6d, 0x61, 0x74, 0x5f, 0x63, 0x6f, 0x6e, 0x66, - 0x69, 0x67, 0x18, 0x03, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x2a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, + 0x2e, 0x76, 0x32, 0x2e, 0x42, 0x61, 0x74, 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, + 0x7a, 0x65, 0x46, 0x69, 0x6c, 0x65, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x52, 0x05, + 0x66, 0x69, 0x6c, 0x65, 0x73, 0x12, 0x6b, 0x0a, 0x19, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, + 0x74, 0x69, 0x6f, 0x6e, 0x5f, 0x6f, 0x75, 0x74, 0x70, 0x75, 0x74, 0x5f, 0x63, 0x6f, 0x6e, 0x66, + 0x69, 0x67, 0x18, 0x06, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x2f, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, - 0x32, 0x2e, 0x4f, 0x75, 0x74, 0x70, 0x75, 0x74, 0x46, 0x6f, 0x72, 0x6d, 0x61, 0x74, 0x43, 0x6f, - 0x6e, 0x66, 0x69, 0x67, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x12, 0x6f, 0x75, 0x74, 0x70, 0x75, - 0x74, 0x46, 0x6f, 0x72, 0x6d, 0x61, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x42, 0x08, 0x0a, - 0x06, 0x6f, 0x75, 0x74, 0x70, 0x75, 0x74, 0x22, 0xac, 0x02, 0x0a, 0x16, 0x42, 0x61, 0x74, 0x63, - 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, - 0x73, 0x65, 0x12, 0x55, 0x0a, 0x07, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x73, 0x18, 0x01, 0x20, - 0x03, 0x28, 0x0b, 0x32, 0x3b, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, - 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x42, 0x61, 0x74, - 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, - 0x6e, 0x73, 0x65, 0x2e, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x73, 0x45, 0x6e, 0x74, 0x72, 0x79, - 0x52, 0x07, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x73, 0x12, 0x4d, 0x0a, 0x15, 0x74, 0x6f, 0x74, - 0x61, 0x6c, 0x5f, 0x62, 0x69, 0x6c, 0x6c, 0x65, 0x64, 0x5f, 0x64, 0x75, 0x72, 0x61, 0x74, 0x69, - 0x6f, 0x6e, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x19, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, - 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x44, 0x75, 0x72, 0x61, 0x74, - 0x69, 0x6f, 0x6e, 0x52, 0x13, 0x74, 0x6f, 0x74, 0x61, 0x6c, 0x42, 0x69, 0x6c, 0x6c, 0x65, 0x64, - 0x44, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x1a, 0x6c, 0x0a, 0x0c, 0x52, 0x65, 0x73, 0x75, - 0x6c, 0x74, 0x73, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, 0x03, 0x6b, 0x65, 0x79, 0x18, - 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x46, 0x0a, 0x05, 0x76, 0x61, - 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x30, 0x2e, 0x67, 0x6f, 0x6f, 0x67, - 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, - 0x76, 0x32, 0x2e, 0x42, 0x61, 0x74, 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, - 0x65, 0x46, 0x69, 0x6c, 0x65, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x52, 0x05, 0x76, 0x61, 0x6c, - 0x75, 0x65, 0x3a, 0x02, 0x38, 0x01, 0x22, 0xb3, 0x01, 0x0a, 0x15, 0x42, 0x61, 0x74, 0x63, 0x68, - 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x73, - 0x12, 0x49, 0x0a, 0x07, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x73, 0x18, 0x01, 0x20, 0x03, 0x28, - 0x0b, 0x32, 0x2f, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, - 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x53, 0x70, 0x65, 0x65, 0x63, - 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x73, 0x75, - 0x6c, 0x74, 0x52, 0x07, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x73, 0x12, 0x4f, 0x0a, 0x08, 0x6d, - 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x33, 0x2e, + 0x32, 0x2e, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x4f, 0x75, 0x74, + 0x70, 0x75, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x52, 0x17, 0x72, 0x65, 0x63, 0x6f, 0x67, + 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x4f, 0x75, 0x74, 0x70, 0x75, 0x74, 0x43, 0x6f, 0x6e, 0x66, + 0x69, 0x67, 0x12, 0x71, 0x0a, 0x13, 0x70, 0x72, 0x6f, 0x63, 0x65, 0x73, 0x73, 0x69, 0x6e, 0x67, + 0x5f, 0x73, 0x74, 0x72, 0x61, 0x74, 0x65, 0x67, 0x79, 0x18, 0x07, 0x20, 0x01, 0x28, 0x0e, 0x32, + 0x40, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, + 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x42, 0x61, 0x74, 0x63, 0x68, 0x52, 0x65, + 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x2e, 0x50, + 0x72, 0x6f, 0x63, 0x65, 0x73, 0x73, 0x69, 0x6e, 0x67, 0x53, 0x74, 0x72, 0x61, 0x74, 0x65, 0x67, + 0x79, 0x52, 0x12, 0x70, 0x72, 0x6f, 0x63, 0x65, 0x73, 0x73, 0x69, 0x6e, 0x67, 0x53, 0x74, 0x72, + 0x61, 0x74, 0x65, 0x67, 0x79, 0x22, 0x4f, 0x0a, 0x12, 0x50, 0x72, 0x6f, 0x63, 0x65, 0x73, 0x73, + 0x69, 0x6e, 0x67, 0x53, 0x74, 0x72, 0x61, 0x74, 0x65, 0x67, 0x79, 0x12, 0x23, 0x0a, 0x1f, 0x50, + 0x52, 0x4f, 0x43, 0x45, 0x53, 0x53, 0x49, 0x4e, 0x47, 0x5f, 0x53, 0x54, 0x52, 0x41, 0x54, 0x45, + 0x47, 0x59, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, + 0x12, 0x14, 0x0a, 0x10, 0x44, 0x59, 0x4e, 0x41, 0x4d, 0x49, 0x43, 0x5f, 0x42, 0x41, 0x54, 0x43, + 0x48, 0x49, 0x4e, 0x47, 0x10, 0x01, 0x22, 0x23, 0x0a, 0x0f, 0x47, 0x63, 0x73, 0x4f, 0x75, 0x74, + 0x70, 0x75, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x10, 0x0a, 0x03, 0x75, 0x72, 0x69, + 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x75, 0x72, 0x69, 0x22, 0x14, 0x0a, 0x12, 0x49, + 0x6e, 0x6c, 0x69, 0x6e, 0x65, 0x4f, 0x75, 0x74, 0x70, 0x75, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, + 0x67, 0x22, 0x1e, 0x0a, 0x1c, 0x4e, 0x61, 0x74, 0x69, 0x76, 0x65, 0x4f, 0x75, 0x74, 0x70, 0x75, + 0x74, 0x46, 0x69, 0x6c, 0x65, 0x46, 0x6f, 0x72, 0x6d, 0x61, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, + 0x67, 0x22, 0x1b, 0x0a, 0x19, 0x56, 0x74, 0x74, 0x4f, 0x75, 0x74, 0x70, 0x75, 0x74, 0x46, 0x69, + 0x6c, 0x65, 0x46, 0x6f, 0x72, 0x6d, 0x61, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x22, 0x1b, + 0x0a, 0x19, 0x53, 0x72, 0x74, 0x4f, 0x75, 0x74, 0x70, 0x75, 0x74, 0x46, 0x69, 0x6c, 0x65, 0x46, + 0x6f, 0x72, 0x6d, 0x61, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x22, 0xec, 0x01, 0x0a, 0x12, + 0x4f, 0x75, 0x74, 0x70, 0x75, 0x74, 0x46, 0x6f, 0x72, 0x6d, 0x61, 0x74, 0x43, 0x6f, 0x6e, 0x66, + 0x69, 0x67, 0x12, 0x4c, 0x0a, 0x06, 0x6e, 0x61, 0x74, 0x69, 0x76, 0x65, 0x18, 0x01, 0x20, 0x01, + 0x28, 0x0b, 0x32, 0x34, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, + 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x4e, 0x61, 0x74, 0x69, + 0x76, 0x65, 0x4f, 0x75, 0x74, 0x70, 0x75, 0x74, 0x46, 0x69, 0x6c, 0x65, 0x46, 0x6f, 0x72, 0x6d, + 0x61, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x52, 0x06, 0x6e, 0x61, 0x74, 0x69, 0x76, 0x65, + 0x12, 0x43, 0x0a, 0x03, 0x76, 0x74, 0x74, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x31, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, - 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, - 0x6f, 0x6e, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, - 0x74, 0x61, 0x52, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x22, 0x72, 0x0a, 0x12, - 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x53, 0x74, 0x6f, 0x72, 0x61, 0x67, 0x65, 0x52, 0x65, 0x73, 0x75, - 0x6c, 0x74, 0x12, 0x10, 0x0a, 0x03, 0x75, 0x72, 0x69, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, - 0x03, 0x75, 0x72, 0x69, 0x12, 0x24, 0x0a, 0x0e, 0x76, 0x74, 0x74, 0x5f, 0x66, 0x6f, 0x72, 0x6d, - 0x61, 0x74, 0x5f, 0x75, 0x72, 0x69, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0c, 0x76, 0x74, - 0x74, 0x46, 0x6f, 0x72, 0x6d, 0x61, 0x74, 0x55, 0x72, 0x69, 0x12, 0x24, 0x0a, 0x0e, 0x73, 0x72, - 0x74, 0x5f, 0x66, 0x6f, 0x72, 0x6d, 0x61, 0x74, 0x5f, 0x75, 0x72, 0x69, 0x18, 0x03, 0x20, 0x01, - 0x28, 0x09, 0x52, 0x0c, 0x73, 0x72, 0x74, 0x46, 0x6f, 0x72, 0x6d, 0x61, 0x74, 0x55, 0x72, 0x69, - 0x22, 0xa3, 0x01, 0x0a, 0x0c, 0x49, 0x6e, 0x6c, 0x69, 0x6e, 0x65, 0x52, 0x65, 0x73, 0x75, 0x6c, - 0x74, 0x12, 0x4d, 0x0a, 0x0a, 0x74, 0x72, 0x61, 0x6e, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x18, - 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x2d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, - 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x42, - 0x61, 0x74, 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x52, 0x65, 0x73, - 0x75, 0x6c, 0x74, 0x73, 0x52, 0x0a, 0x74, 0x72, 0x61, 0x6e, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, - 0x12, 0x21, 0x0a, 0x0c, 0x76, 0x74, 0x74, 0x5f, 0x63, 0x61, 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x73, - 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0b, 0x76, 0x74, 0x74, 0x43, 0x61, 0x70, 0x74, 0x69, - 0x6f, 0x6e, 0x73, 0x12, 0x21, 0x0a, 0x0c, 0x73, 0x72, 0x74, 0x5f, 0x63, 0x61, 0x70, 0x74, 0x69, - 0x6f, 0x6e, 0x73, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0b, 0x73, 0x72, 0x74, 0x43, 0x61, - 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x22, 0xb5, 0x03, 0x0a, 0x18, 0x42, 0x61, 0x74, 0x63, 0x68, - 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x46, 0x69, 0x6c, 0x65, 0x52, 0x65, 0x73, - 0x75, 0x6c, 0x74, 0x12, 0x28, 0x0a, 0x05, 0x65, 0x72, 0x72, 0x6f, 0x72, 0x18, 0x02, 0x20, 0x01, - 0x28, 0x0b, 0x32, 0x12, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x72, 0x70, 0x63, 0x2e, - 0x53, 0x74, 0x61, 0x74, 0x75, 0x73, 0x52, 0x05, 0x65, 0x72, 0x72, 0x6f, 0x72, 0x12, 0x4f, 0x0a, - 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x18, 0x03, 0x20, 0x01, 0x28, 0x0b, 0x32, - 0x33, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, - 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, - 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x4d, 0x65, 0x74, 0x61, - 0x64, 0x61, 0x74, 0x61, 0x52, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x12, 0x5e, - 0x0a, 0x14, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x5f, 0x73, 0x74, 0x6f, 0x72, 0x61, 0x67, 0x65, 0x5f, - 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x18, 0x05, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x2a, 0x2e, 0x67, - 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, - 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x53, 0x74, 0x6f, 0x72, 0x61, - 0x67, 0x65, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x48, 0x00, 0x52, 0x12, 0x63, 0x6c, 0x6f, 0x75, - 0x64, 0x53, 0x74, 0x6f, 0x72, 0x61, 0x67, 0x65, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x12, 0x4b, - 0x0a, 0x0d, 0x69, 0x6e, 0x6c, 0x69, 0x6e, 0x65, 0x5f, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x18, - 0x06, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x24, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, - 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x49, - 0x6e, 0x6c, 0x69, 0x6e, 0x65, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x48, 0x00, 0x52, 0x0c, 0x69, - 0x6e, 0x6c, 0x69, 0x6e, 0x65, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x12, 0x14, 0x0a, 0x03, 0x75, - 0x72, 0x69, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x02, 0x18, 0x01, 0x52, 0x03, 0x75, 0x72, - 0x69, 0x12, 0x51, 0x0a, 0x0a, 0x74, 0x72, 0x61, 0x6e, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x18, - 0x04, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x2d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, - 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x42, - 0x61, 0x74, 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x52, 0x65, 0x73, - 0x75, 0x6c, 0x74, 0x73, 0x42, 0x02, 0x18, 0x01, 0x52, 0x0a, 0x74, 0x72, 0x61, 0x6e, 0x73, 0x63, - 0x72, 0x69, 0x70, 0x74, 0x42, 0x08, 0x0a, 0x06, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x22, 0x8c, - 0x01, 0x0a, 0x23, 0x42, 0x61, 0x74, 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, - 0x65, 0x54, 0x72, 0x61, 0x6e, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, - 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x12, 0x29, 0x0a, 0x10, 0x70, 0x72, 0x6f, 0x67, 0x72, 0x65, - 0x73, 0x73, 0x5f, 0x70, 0x65, 0x72, 0x63, 0x65, 0x6e, 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, 0x05, - 0x52, 0x0f, 0x70, 0x72, 0x6f, 0x67, 0x72, 0x65, 0x73, 0x73, 0x50, 0x65, 0x72, 0x63, 0x65, 0x6e, - 0x74, 0x12, 0x28, 0x0a, 0x05, 0x65, 0x72, 0x72, 0x6f, 0x72, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, - 0x32, 0x12, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x72, 0x70, 0x63, 0x2e, 0x53, 0x74, - 0x61, 0x74, 0x75, 0x73, 0x52, 0x05, 0x65, 0x72, 0x72, 0x6f, 0x72, 0x12, 0x10, 0x0a, 0x03, 0x75, - 0x72, 0x69, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x75, 0x72, 0x69, 0x22, 0xa3, 0x02, - 0x0a, 0x16, 0x42, 0x61, 0x74, 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, - 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x12, 0x80, 0x01, 0x0a, 0x16, 0x74, 0x72, 0x61, - 0x6e, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x5f, 0x6d, 0x65, 0x74, 0x61, 0x64, - 0x61, 0x74, 0x61, 0x18, 0x01, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x49, 0x2e, 0x67, 0x6f, 0x6f, 0x67, - 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, - 0x76, 0x32, 0x2e, 0x42, 0x61, 0x74, 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, - 0x65, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x2e, 0x54, 0x72, 0x61, 0x6e, 0x73, 0x63, - 0x72, 0x69, 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, - 0x6e, 0x74, 0x72, 0x79, 0x52, 0x15, 0x74, 0x72, 0x61, 0x6e, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, - 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x1a, 0x85, 0x01, 0x0a, 0x1a, - 0x54, 0x72, 0x61, 0x6e, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, - 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, 0x03, 0x6b, 0x65, - 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x51, 0x0a, 0x05, - 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x3b, 0x2e, 0x67, 0x6f, - 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, - 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x42, 0x61, 0x74, 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, - 0x69, 0x7a, 0x65, 0x54, 0x72, 0x61, 0x6e, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x69, 0x6f, 0x6e, - 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x52, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x3a, - 0x02, 0x38, 0x01, 0x22, 0xc0, 0x01, 0x0a, 0x1a, 0x42, 0x61, 0x74, 0x63, 0x68, 0x52, 0x65, 0x63, - 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x46, 0x69, 0x6c, 0x65, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, - 0x74, 0x61, 0x12, 0x12, 0x0a, 0x03, 0x75, 0x72, 0x69, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x48, - 0x00, 0x52, 0x03, 0x75, 0x72, 0x69, 0x12, 0x41, 0x0a, 0x06, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, - 0x18, 0x04, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x29, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, - 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, - 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x43, 0x6f, 0x6e, 0x66, 0x69, - 0x67, 0x52, 0x06, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x3b, 0x0a, 0x0b, 0x63, 0x6f, 0x6e, - 0x66, 0x69, 0x67, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x18, 0x05, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, - 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, - 0x2e, 0x46, 0x69, 0x65, 0x6c, 0x64, 0x4d, 0x61, 0x73, 0x6b, 0x52, 0x0a, 0x63, 0x6f, 0x6e, 0x66, - 0x69, 0x67, 0x4d, 0x61, 0x73, 0x6b, 0x42, 0x0e, 0x0a, 0x0c, 0x61, 0x75, 0x64, 0x69, 0x6f, 0x5f, - 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, 0x22, 0xc1, 0x02, 0x0a, 0x1a, 0x53, 0x74, 0x72, 0x65, 0x61, - 0x6d, 0x69, 0x6e, 0x67, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x52, - 0x65, 0x73, 0x75, 0x6c, 0x74, 0x12, 0x58, 0x0a, 0x0c, 0x61, 0x6c, 0x74, 0x65, 0x72, 0x6e, 0x61, - 0x74, 0x69, 0x76, 0x65, 0x73, 0x18, 0x01, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x34, 0x2e, 0x67, 0x6f, - 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, - 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x53, 0x70, 0x65, 0x65, 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, - 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x41, 0x6c, 0x74, 0x65, 0x72, 0x6e, 0x61, 0x74, 0x69, 0x76, - 0x65, 0x52, 0x0c, 0x61, 0x6c, 0x74, 0x65, 0x72, 0x6e, 0x61, 0x74, 0x69, 0x76, 0x65, 0x73, 0x12, - 0x19, 0x0a, 0x08, 0x69, 0x73, 0x5f, 0x66, 0x69, 0x6e, 0x61, 0x6c, 0x18, 0x02, 0x20, 0x01, 0x28, - 0x08, 0x52, 0x07, 0x69, 0x73, 0x46, 0x69, 0x6e, 0x61, 0x6c, 0x12, 0x1c, 0x0a, 0x09, 0x73, 0x74, - 0x61, 0x62, 0x69, 0x6c, 0x69, 0x74, 0x79, 0x18, 0x03, 0x20, 0x01, 0x28, 0x02, 0x52, 0x09, 0x73, - 0x74, 0x61, 0x62, 0x69, 0x6c, 0x69, 0x74, 0x79, 0x12, 0x45, 0x0a, 0x11, 0x72, 0x65, 0x73, 0x75, - 0x6c, 0x74, 0x5f, 0x65, 0x6e, 0x64, 0x5f, 0x6f, 0x66, 0x66, 0x73, 0x65, 0x74, 0x18, 0x04, 0x20, - 0x01, 0x28, 0x0b, 0x32, 0x19, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, - 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x44, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x0f, - 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x45, 0x6e, 0x64, 0x4f, 0x66, 0x66, 0x73, 0x65, 0x74, 0x12, - 0x1f, 0x0a, 0x0b, 0x63, 0x68, 0x61, 0x6e, 0x6e, 0x65, 0x6c, 0x5f, 0x74, 0x61, 0x67, 0x18, 0x05, - 0x20, 0x01, 0x28, 0x05, 0x52, 0x0a, 0x63, 0x68, 0x61, 0x6e, 0x6e, 0x65, 0x6c, 0x54, 0x61, 0x67, - 0x12, 0x28, 0x0a, 0x0d, 0x6c, 0x61, 0x6e, 0x67, 0x75, 0x61, 0x67, 0x65, 0x5f, 0x63, 0x6f, 0x64, - 0x65, 0x18, 0x06, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x0c, 0x6c, 0x61, - 0x6e, 0x67, 0x75, 0x61, 0x67, 0x65, 0x43, 0x6f, 0x64, 0x65, 0x22, 0xfe, 0x03, 0x0a, 0x1a, 0x53, - 0x74, 0x72, 0x65, 0x61, 0x6d, 0x69, 0x6e, 0x67, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, - 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x4c, 0x0a, 0x07, 0x72, 0x65, 0x73, - 0x75, 0x6c, 0x74, 0x73, 0x18, 0x06, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x32, 0x2e, 0x67, 0x6f, 0x6f, + 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x56, 0x74, 0x74, 0x4f, 0x75, 0x74, 0x70, 0x75, 0x74, + 0x46, 0x69, 0x6c, 0x65, 0x46, 0x6f, 0x72, 0x6d, 0x61, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, + 0x52, 0x03, 0x76, 0x74, 0x74, 0x12, 0x43, 0x0a, 0x03, 0x73, 0x72, 0x74, 0x18, 0x03, 0x20, 0x01, + 0x28, 0x0b, 0x32, 0x31, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, + 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x53, 0x72, 0x74, 0x4f, + 0x75, 0x74, 0x70, 0x75, 0x74, 0x46, 0x69, 0x6c, 0x65, 0x46, 0x6f, 0x72, 0x6d, 0x61, 0x74, 0x43, + 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x52, 0x03, 0x73, 0x72, 0x74, 0x22, 0xc1, 0x02, 0x0a, 0x17, 0x52, + 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x4f, 0x75, 0x74, 0x70, 0x75, 0x74, + 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x55, 0x0a, 0x11, 0x67, 0x63, 0x73, 0x5f, 0x6f, 0x75, + 0x74, 0x70, 0x75, 0x74, 0x5f, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x18, 0x01, 0x20, 0x01, 0x28, + 0x0b, 0x32, 0x27, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, + 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x47, 0x63, 0x73, 0x4f, 0x75, + 0x74, 0x70, 0x75, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x48, 0x00, 0x52, 0x0f, 0x67, 0x63, + 0x73, 0x4f, 0x75, 0x74, 0x70, 0x75, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x62, 0x0a, + 0x16, 0x69, 0x6e, 0x6c, 0x69, 0x6e, 0x65, 0x5f, 0x72, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, + 0x5f, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x2a, 0x2e, + 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, + 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x49, 0x6e, 0x6c, 0x69, 0x6e, 0x65, 0x4f, 0x75, 0x74, + 0x70, 0x75, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x48, 0x00, 0x52, 0x14, 0x69, 0x6e, 0x6c, + 0x69, 0x6e, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x43, 0x6f, 0x6e, 0x66, 0x69, + 0x67, 0x12, 0x61, 0x0a, 0x14, 0x6f, 0x75, 0x74, 0x70, 0x75, 0x74, 0x5f, 0x66, 0x6f, 0x72, 0x6d, + 0x61, 0x74, 0x5f, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x18, 0x03, 0x20, 0x01, 0x28, 0x0b, 0x32, + 0x2a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, + 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x4f, 0x75, 0x74, 0x70, 0x75, 0x74, 0x46, + 0x6f, 0x72, 0x6d, 0x61, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x42, 0x03, 0xe0, 0x41, 0x01, + 0x52, 0x12, 0x6f, 0x75, 0x74, 0x70, 0x75, 0x74, 0x46, 0x6f, 0x72, 0x6d, 0x61, 0x74, 0x43, 0x6f, + 0x6e, 0x66, 0x69, 0x67, 0x42, 0x08, 0x0a, 0x06, 0x6f, 0x75, 0x74, 0x70, 0x75, 0x74, 0x22, 0xac, + 0x02, 0x0a, 0x16, 0x42, 0x61, 0x74, 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, + 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x55, 0x0a, 0x07, 0x72, 0x65, 0x73, + 0x75, 0x6c, 0x74, 0x73, 0x18, 0x01, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x3b, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, - 0x2e, 0x76, 0x32, 0x2e, 0x53, 0x74, 0x72, 0x65, 0x61, 0x6d, 0x69, 0x6e, 0x67, 0x52, 0x65, 0x63, - 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x52, 0x07, - 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x73, 0x12, 0x6e, 0x0a, 0x11, 0x73, 0x70, 0x65, 0x65, 0x63, - 0x68, 0x5f, 0x65, 0x76, 0x65, 0x6e, 0x74, 0x5f, 0x74, 0x79, 0x70, 0x65, 0x18, 0x03, 0x20, 0x01, - 0x28, 0x0e, 0x32, 0x42, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, - 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x53, 0x74, 0x72, 0x65, - 0x61, 0x6d, 0x69, 0x6e, 0x67, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x52, 0x65, - 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x2e, 0x53, 0x70, 0x65, 0x65, 0x63, 0x68, 0x45, 0x76, 0x65, - 0x6e, 0x74, 0x54, 0x79, 0x70, 0x65, 0x52, 0x0f, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x45, 0x76, - 0x65, 0x6e, 0x74, 0x54, 0x79, 0x70, 0x65, 0x12, 0x49, 0x0a, 0x13, 0x73, 0x70, 0x65, 0x65, 0x63, - 0x68, 0x5f, 0x65, 0x76, 0x65, 0x6e, 0x74, 0x5f, 0x6f, 0x66, 0x66, 0x73, 0x65, 0x74, 0x18, 0x07, - 0x20, 0x01, 0x28, 0x0b, 0x32, 0x19, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, - 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x44, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, - 0x11, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x45, 0x76, 0x65, 0x6e, 0x74, 0x4f, 0x66, 0x66, 0x73, - 0x65, 0x74, 0x12, 0x4f, 0x0a, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x18, 0x05, + 0x2e, 0x76, 0x32, 0x2e, 0x42, 0x61, 0x74, 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, + 0x7a, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x2e, 0x52, 0x65, 0x73, 0x75, 0x6c, + 0x74, 0x73, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x52, 0x07, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x73, + 0x12, 0x4d, 0x0a, 0x15, 0x74, 0x6f, 0x74, 0x61, 0x6c, 0x5f, 0x62, 0x69, 0x6c, 0x6c, 0x65, 0x64, + 0x5f, 0x64, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, + 0x19, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, + 0x66, 0x2e, 0x44, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x13, 0x74, 0x6f, 0x74, 0x61, + 0x6c, 0x42, 0x69, 0x6c, 0x6c, 0x65, 0x64, 0x44, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x1a, + 0x6c, 0x0a, 0x0c, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x73, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, + 0x10, 0x0a, 0x03, 0x6b, 0x65, 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, + 0x79, 0x12, 0x46, 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, + 0x32, 0x30, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, + 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x42, 0x61, 0x74, 0x63, 0x68, 0x52, + 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x46, 0x69, 0x6c, 0x65, 0x52, 0x65, 0x73, 0x75, + 0x6c, 0x74, 0x52, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x3a, 0x02, 0x38, 0x01, 0x22, 0xb3, 0x01, + 0x0a, 0x15, 0x42, 0x61, 0x74, 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, + 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x73, 0x12, 0x49, 0x0a, 0x07, 0x72, 0x65, 0x73, 0x75, 0x6c, + 0x74, 0x73, 0x18, 0x01, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x2f, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, + 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, + 0x32, 0x2e, 0x53, 0x70, 0x65, 0x65, 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, + 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x52, 0x07, 0x72, 0x65, 0x73, 0x75, 0x6c, + 0x74, 0x73, 0x12, 0x4f, 0x0a, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x33, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x52, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, - 0x61, 0x74, 0x61, 0x22, 0x85, 0x01, 0x0a, 0x0f, 0x53, 0x70, 0x65, 0x65, 0x63, 0x68, 0x45, 0x76, - 0x65, 0x6e, 0x74, 0x54, 0x79, 0x70, 0x65, 0x12, 0x21, 0x0a, 0x1d, 0x53, 0x50, 0x45, 0x45, 0x43, - 0x48, 0x5f, 0x45, 0x56, 0x45, 0x4e, 0x54, 0x5f, 0x54, 0x59, 0x50, 0x45, 0x5f, 0x55, 0x4e, 0x53, - 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x1b, 0x0a, 0x17, 0x45, 0x4e, - 0x44, 0x5f, 0x4f, 0x46, 0x5f, 0x53, 0x49, 0x4e, 0x47, 0x4c, 0x45, 0x5f, 0x55, 0x54, 0x54, 0x45, - 0x52, 0x41, 0x4e, 0x43, 0x45, 0x10, 0x01, 0x12, 0x19, 0x0a, 0x15, 0x53, 0x50, 0x45, 0x45, 0x43, - 0x48, 0x5f, 0x41, 0x43, 0x54, 0x49, 0x56, 0x49, 0x54, 0x59, 0x5f, 0x42, 0x45, 0x47, 0x49, 0x4e, - 0x10, 0x02, 0x12, 0x17, 0x0a, 0x13, 0x53, 0x50, 0x45, 0x45, 0x43, 0x48, 0x5f, 0x41, 0x43, 0x54, - 0x49, 0x56, 0x49, 0x54, 0x59, 0x5f, 0x45, 0x4e, 0x44, 0x10, 0x03, 0x22, 0x86, 0x02, 0x0a, 0x06, - 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x1a, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, - 0x20, 0x01, 0x28, 0x09, 0x42, 0x06, 0xe0, 0x41, 0x03, 0xe0, 0x41, 0x08, 0x52, 0x04, 0x6e, 0x61, - 0x6d, 0x65, 0x12, 0x4b, 0x0a, 0x0c, 0x6b, 0x6d, 0x73, 0x5f, 0x6b, 0x65, 0x79, 0x5f, 0x6e, 0x61, - 0x6d, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x42, 0x29, 0xe0, 0x41, 0x01, 0xfa, 0x41, 0x23, - 0x0a, 0x21, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x6b, 0x6d, 0x73, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, - 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x43, 0x72, 0x79, 0x70, 0x74, 0x6f, - 0x4b, 0x65, 0x79, 0x52, 0x0a, 0x6b, 0x6d, 0x73, 0x4b, 0x65, 0x79, 0x4e, 0x61, 0x6d, 0x65, 0x12, - 0x40, 0x0a, 0x0b, 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x18, 0x03, - 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, - 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, - 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x0a, 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, 0x54, 0x69, 0x6d, - 0x65, 0x3a, 0x51, 0xea, 0x41, 0x4e, 0x0a, 0x1c, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x67, - 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x43, 0x6f, - 0x6e, 0x66, 0x69, 0x67, 0x12, 0x2e, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x7b, - 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x7d, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, - 0x6e, 0x73, 0x2f, 0x7b, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x7d, 0x2f, 0x63, 0x6f, - 0x6e, 0x66, 0x69, 0x67, 0x22, 0x4c, 0x0a, 0x10, 0x47, 0x65, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, - 0x67, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x38, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, - 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x24, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x1e, 0x0a, 0x1c, - 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, - 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x52, 0x04, 0x6e, 0x61, - 0x6d, 0x65, 0x22, 0x8f, 0x01, 0x0a, 0x13, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x43, 0x6f, 0x6e, - 0x66, 0x69, 0x67, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x3b, 0x0a, 0x06, 0x63, 0x6f, - 0x6e, 0x66, 0x69, 0x67, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1e, 0x2e, 0x67, 0x6f, 0x6f, + 0x61, 0x74, 0x61, 0x22, 0x72, 0x0a, 0x12, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x53, 0x74, 0x6f, 0x72, + 0x61, 0x67, 0x65, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x12, 0x10, 0x0a, 0x03, 0x75, 0x72, 0x69, + 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x75, 0x72, 0x69, 0x12, 0x24, 0x0a, 0x0e, 0x76, + 0x74, 0x74, 0x5f, 0x66, 0x6f, 0x72, 0x6d, 0x61, 0x74, 0x5f, 0x75, 0x72, 0x69, 0x18, 0x02, 0x20, + 0x01, 0x28, 0x09, 0x52, 0x0c, 0x76, 0x74, 0x74, 0x46, 0x6f, 0x72, 0x6d, 0x61, 0x74, 0x55, 0x72, + 0x69, 0x12, 0x24, 0x0a, 0x0e, 0x73, 0x72, 0x74, 0x5f, 0x66, 0x6f, 0x72, 0x6d, 0x61, 0x74, 0x5f, + 0x75, 0x72, 0x69, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0c, 0x73, 0x72, 0x74, 0x46, 0x6f, + 0x72, 0x6d, 0x61, 0x74, 0x55, 0x72, 0x69, 0x22, 0xa3, 0x01, 0x0a, 0x0c, 0x49, 0x6e, 0x6c, 0x69, + 0x6e, 0x65, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x12, 0x4d, 0x0a, 0x0a, 0x74, 0x72, 0x61, 0x6e, + 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x2d, 0x2e, 0x67, + 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, + 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x42, 0x61, 0x74, 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, + 0x6e, 0x69, 0x7a, 0x65, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x73, 0x52, 0x0a, 0x74, 0x72, 0x61, + 0x6e, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x12, 0x21, 0x0a, 0x0c, 0x76, 0x74, 0x74, 0x5f, 0x63, + 0x61, 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0b, 0x76, + 0x74, 0x74, 0x43, 0x61, 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x12, 0x21, 0x0a, 0x0c, 0x73, 0x72, + 0x74, 0x5f, 0x63, 0x61, 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, + 0x52, 0x0b, 0x73, 0x72, 0x74, 0x43, 0x61, 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x22, 0xb5, 0x03, + 0x0a, 0x18, 0x42, 0x61, 0x74, 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, + 0x46, 0x69, 0x6c, 0x65, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x12, 0x28, 0x0a, 0x05, 0x65, 0x72, + 0x72, 0x6f, 0x72, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x12, 0x2e, 0x67, 0x6f, 0x6f, 0x67, + 0x6c, 0x65, 0x2e, 0x72, 0x70, 0x63, 0x2e, 0x53, 0x74, 0x61, 0x74, 0x75, 0x73, 0x52, 0x05, 0x65, + 0x72, 0x72, 0x6f, 0x72, 0x12, 0x4f, 0x0a, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, + 0x18, 0x03, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x33, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, + 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, + 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x73, 0x70, 0x6f, + 0x6e, 0x73, 0x65, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x52, 0x08, 0x6d, 0x65, 0x74, + 0x61, 0x64, 0x61, 0x74, 0x61, 0x12, 0x5e, 0x0a, 0x14, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x5f, 0x73, + 0x74, 0x6f, 0x72, 0x61, 0x67, 0x65, 0x5f, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x18, 0x05, 0x20, + 0x01, 0x28, 0x0b, 0x32, 0x2a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, + 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x43, 0x6c, 0x6f, + 0x75, 0x64, 0x53, 0x74, 0x6f, 0x72, 0x61, 0x67, 0x65, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x48, + 0x00, 0x52, 0x12, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x53, 0x74, 0x6f, 0x72, 0x61, 0x67, 0x65, 0x52, + 0x65, 0x73, 0x75, 0x6c, 0x74, 0x12, 0x4b, 0x0a, 0x0d, 0x69, 0x6e, 0x6c, 0x69, 0x6e, 0x65, 0x5f, + 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x18, 0x06, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x24, 0x2e, 0x67, + 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, + 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x49, 0x6e, 0x6c, 0x69, 0x6e, 0x65, 0x52, 0x65, 0x73, 0x75, + 0x6c, 0x74, 0x48, 0x00, 0x52, 0x0c, 0x69, 0x6e, 0x6c, 0x69, 0x6e, 0x65, 0x52, 0x65, 0x73, 0x75, + 0x6c, 0x74, 0x12, 0x14, 0x0a, 0x03, 0x75, 0x72, 0x69, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, + 0x02, 0x18, 0x01, 0x52, 0x03, 0x75, 0x72, 0x69, 0x12, 0x51, 0x0a, 0x0a, 0x74, 0x72, 0x61, 0x6e, + 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x18, 0x04, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x2d, 0x2e, 0x67, + 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, + 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x42, 0x61, 0x74, 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, + 0x6e, 0x69, 0x7a, 0x65, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x73, 0x42, 0x02, 0x18, 0x01, 0x52, + 0x0a, 0x74, 0x72, 0x61, 0x6e, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x42, 0x08, 0x0a, 0x06, 0x72, + 0x65, 0x73, 0x75, 0x6c, 0x74, 0x22, 0x8c, 0x01, 0x0a, 0x23, 0x42, 0x61, 0x74, 0x63, 0x68, 0x52, + 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x54, 0x72, 0x61, 0x6e, 0x73, 0x63, 0x72, 0x69, + 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x12, 0x29, 0x0a, + 0x10, 0x70, 0x72, 0x6f, 0x67, 0x72, 0x65, 0x73, 0x73, 0x5f, 0x70, 0x65, 0x72, 0x63, 0x65, 0x6e, + 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, 0x05, 0x52, 0x0f, 0x70, 0x72, 0x6f, 0x67, 0x72, 0x65, 0x73, + 0x73, 0x50, 0x65, 0x72, 0x63, 0x65, 0x6e, 0x74, 0x12, 0x28, 0x0a, 0x05, 0x65, 0x72, 0x72, 0x6f, + 0x72, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x12, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, + 0x2e, 0x72, 0x70, 0x63, 0x2e, 0x53, 0x74, 0x61, 0x74, 0x75, 0x73, 0x52, 0x05, 0x65, 0x72, 0x72, + 0x6f, 0x72, 0x12, 0x10, 0x0a, 0x03, 0x75, 0x72, 0x69, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x52, + 0x03, 0x75, 0x72, 0x69, 0x22, 0xa3, 0x02, 0x0a, 0x16, 0x42, 0x61, 0x74, 0x63, 0x68, 0x52, 0x65, + 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x12, + 0x80, 0x01, 0x0a, 0x16, 0x74, 0x72, 0x61, 0x6e, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x69, 0x6f, + 0x6e, 0x5f, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x18, 0x01, 0x20, 0x03, 0x28, 0x0b, + 0x32, 0x49, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, + 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x42, 0x61, 0x74, 0x63, 0x68, 0x52, + 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, + 0x2e, 0x54, 0x72, 0x61, 0x6e, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, + 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x52, 0x15, 0x74, 0x72, 0x61, + 0x6e, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, + 0x74, 0x61, 0x1a, 0x85, 0x01, 0x0a, 0x1a, 0x54, 0x72, 0x61, 0x6e, 0x73, 0x63, 0x72, 0x69, 0x70, + 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, + 0x79, 0x12, 0x10, 0x0a, 0x03, 0x6b, 0x65, 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, + 0x6b, 0x65, 0x79, 0x12, 0x51, 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, + 0x28, 0x0b, 0x32, 0x3b, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, + 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x42, 0x61, 0x74, 0x63, + 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x54, 0x72, 0x61, 0x6e, 0x73, 0x63, + 0x72, 0x69, 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x52, + 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x3a, 0x02, 0x38, 0x01, 0x22, 0xc0, 0x01, 0x0a, 0x1a, 0x42, + 0x61, 0x74, 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x46, 0x69, 0x6c, + 0x65, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x12, 0x12, 0x0a, 0x03, 0x75, 0x72, 0x69, + 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x48, 0x00, 0x52, 0x03, 0x75, 0x72, 0x69, 0x12, 0x41, 0x0a, + 0x06, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x18, 0x04, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x29, 0x2e, + 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, + 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, + 0x6f, 0x6e, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x52, 0x06, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, + 0x12, 0x3b, 0x0a, 0x0b, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x18, + 0x05, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, + 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x46, 0x69, 0x65, 0x6c, 0x64, 0x4d, 0x61, 0x73, + 0x6b, 0x52, 0x0a, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x4d, 0x61, 0x73, 0x6b, 0x42, 0x0e, 0x0a, + 0x0c, 0x61, 0x75, 0x64, 0x69, 0x6f, 0x5f, 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, 0x22, 0xc1, 0x02, + 0x0a, 0x1a, 0x53, 0x74, 0x72, 0x65, 0x61, 0x6d, 0x69, 0x6e, 0x67, 0x52, 0x65, 0x63, 0x6f, 0x67, + 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x12, 0x58, 0x0a, 0x0c, + 0x61, 0x6c, 0x74, 0x65, 0x72, 0x6e, 0x61, 0x74, 0x69, 0x76, 0x65, 0x73, 0x18, 0x01, 0x20, 0x03, + 0x28, 0x0b, 0x32, 0x34, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, + 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x53, 0x70, 0x65, 0x65, + 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x41, 0x6c, 0x74, + 0x65, 0x72, 0x6e, 0x61, 0x74, 0x69, 0x76, 0x65, 0x52, 0x0c, 0x61, 0x6c, 0x74, 0x65, 0x72, 0x6e, + 0x61, 0x74, 0x69, 0x76, 0x65, 0x73, 0x12, 0x19, 0x0a, 0x08, 0x69, 0x73, 0x5f, 0x66, 0x69, 0x6e, + 0x61, 0x6c, 0x18, 0x02, 0x20, 0x01, 0x28, 0x08, 0x52, 0x07, 0x69, 0x73, 0x46, 0x69, 0x6e, 0x61, + 0x6c, 0x12, 0x1c, 0x0a, 0x09, 0x73, 0x74, 0x61, 0x62, 0x69, 0x6c, 0x69, 0x74, 0x79, 0x18, 0x03, + 0x20, 0x01, 0x28, 0x02, 0x52, 0x09, 0x73, 0x74, 0x61, 0x62, 0x69, 0x6c, 0x69, 0x74, 0x79, 0x12, + 0x45, 0x0a, 0x11, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x5f, 0x65, 0x6e, 0x64, 0x5f, 0x6f, 0x66, + 0x66, 0x73, 0x65, 0x74, 0x18, 0x04, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x19, 0x2e, 0x67, 0x6f, 0x6f, + 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x44, 0x75, 0x72, + 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x0f, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x45, 0x6e, 0x64, + 0x4f, 0x66, 0x66, 0x73, 0x65, 0x74, 0x12, 0x1f, 0x0a, 0x0b, 0x63, 0x68, 0x61, 0x6e, 0x6e, 0x65, + 0x6c, 0x5f, 0x74, 0x61, 0x67, 0x18, 0x05, 0x20, 0x01, 0x28, 0x05, 0x52, 0x0a, 0x63, 0x68, 0x61, + 0x6e, 0x6e, 0x65, 0x6c, 0x54, 0x61, 0x67, 0x12, 0x28, 0x0a, 0x0d, 0x6c, 0x61, 0x6e, 0x67, 0x75, + 0x61, 0x67, 0x65, 0x5f, 0x63, 0x6f, 0x64, 0x65, 0x18, 0x06, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, + 0xe0, 0x41, 0x03, 0x52, 0x0c, 0x6c, 0x61, 0x6e, 0x67, 0x75, 0x61, 0x67, 0x65, 0x43, 0x6f, 0x64, + 0x65, 0x22, 0xfe, 0x03, 0x0a, 0x1a, 0x53, 0x74, 0x72, 0x65, 0x61, 0x6d, 0x69, 0x6e, 0x67, 0x52, + 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, + 0x12, 0x4c, 0x0a, 0x07, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x73, 0x18, 0x06, 0x20, 0x03, 0x28, + 0x0b, 0x32, 0x32, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, + 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x53, 0x74, 0x72, 0x65, 0x61, + 0x6d, 0x69, 0x6e, 0x67, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, 0x52, + 0x65, 0x73, 0x75, 0x6c, 0x74, 0x52, 0x07, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x73, 0x12, 0x6e, + 0x0a, 0x11, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x5f, 0x65, 0x76, 0x65, 0x6e, 0x74, 0x5f, 0x74, + 0x79, 0x70, 0x65, 0x18, 0x03, 0x20, 0x01, 0x28, 0x0e, 0x32, 0x42, 0x2e, 0x67, 0x6f, 0x6f, 0x67, + 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, + 0x76, 0x32, 0x2e, 0x53, 0x74, 0x72, 0x65, 0x61, 0x6d, 0x69, 0x6e, 0x67, 0x52, 0x65, 0x63, 0x6f, + 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x2e, 0x53, 0x70, + 0x65, 0x65, 0x63, 0x68, 0x45, 0x76, 0x65, 0x6e, 0x74, 0x54, 0x79, 0x70, 0x65, 0x52, 0x0f, 0x73, + 0x70, 0x65, 0x65, 0x63, 0x68, 0x45, 0x76, 0x65, 0x6e, 0x74, 0x54, 0x79, 0x70, 0x65, 0x12, 0x49, + 0x0a, 0x13, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x5f, 0x65, 0x76, 0x65, 0x6e, 0x74, 0x5f, 0x6f, + 0x66, 0x66, 0x73, 0x65, 0x74, 0x18, 0x07, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x19, 0x2e, 0x67, 0x6f, + 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x44, 0x75, + 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x11, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x45, 0x76, + 0x65, 0x6e, 0x74, 0x4f, 0x66, 0x66, 0x73, 0x65, 0x74, 0x12, 0x4f, 0x0a, 0x08, 0x6d, 0x65, 0x74, + 0x61, 0x64, 0x61, 0x74, 0x61, 0x18, 0x05, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x33, 0x2e, 0x67, 0x6f, + 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, + 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x74, 0x69, 0x6f, 0x6e, + 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, + 0x52, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x22, 0x85, 0x01, 0x0a, 0x0f, 0x53, + 0x70, 0x65, 0x65, 0x63, 0x68, 0x45, 0x76, 0x65, 0x6e, 0x74, 0x54, 0x79, 0x70, 0x65, 0x12, 0x21, + 0x0a, 0x1d, 0x53, 0x50, 0x45, 0x45, 0x43, 0x48, 0x5f, 0x45, 0x56, 0x45, 0x4e, 0x54, 0x5f, 0x54, + 0x59, 0x50, 0x45, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, + 0x00, 0x12, 0x1b, 0x0a, 0x17, 0x45, 0x4e, 0x44, 0x5f, 0x4f, 0x46, 0x5f, 0x53, 0x49, 0x4e, 0x47, + 0x4c, 0x45, 0x5f, 0x55, 0x54, 0x54, 0x45, 0x52, 0x41, 0x4e, 0x43, 0x45, 0x10, 0x01, 0x12, 0x19, + 0x0a, 0x15, 0x53, 0x50, 0x45, 0x45, 0x43, 0x48, 0x5f, 0x41, 0x43, 0x54, 0x49, 0x56, 0x49, 0x54, + 0x59, 0x5f, 0x42, 0x45, 0x47, 0x49, 0x4e, 0x10, 0x02, 0x12, 0x17, 0x0a, 0x13, 0x53, 0x50, 0x45, + 0x45, 0x43, 0x48, 0x5f, 0x41, 0x43, 0x54, 0x49, 0x56, 0x49, 0x54, 0x59, 0x5f, 0x45, 0x4e, 0x44, + 0x10, 0x03, 0x22, 0x86, 0x02, 0x0a, 0x06, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x1a, 0x0a, + 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x06, 0xe0, 0x41, 0x03, + 0xe0, 0x41, 0x08, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x4b, 0x0a, 0x0c, 0x6b, 0x6d, 0x73, + 0x5f, 0x6b, 0x65, 0x79, 0x5f, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x42, + 0x29, 0xe0, 0x41, 0x01, 0xfa, 0x41, 0x23, 0x0a, 0x21, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x6b, 0x6d, + 0x73, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, + 0x2f, 0x43, 0x72, 0x79, 0x70, 0x74, 0x6f, 0x4b, 0x65, 0x79, 0x52, 0x0a, 0x6b, 0x6d, 0x73, 0x4b, + 0x65, 0x79, 0x4e, 0x61, 0x6d, 0x65, 0x12, 0x40, 0x0a, 0x0b, 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, + 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x18, 0x03, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, + 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x54, 0x69, + 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x0a, 0x75, 0x70, + 0x64, 0x61, 0x74, 0x65, 0x54, 0x69, 0x6d, 0x65, 0x3a, 0x51, 0xea, 0x41, 0x4e, 0x0a, 0x1c, 0x73, + 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, + 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x2e, 0x70, 0x72, 0x6f, + 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x7b, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x7d, 0x2f, + 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x7b, 0x6c, 0x6f, 0x63, 0x61, 0x74, + 0x69, 0x6f, 0x6e, 0x7d, 0x2f, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x22, 0x4c, 0x0a, 0x10, 0x47, + 0x65, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, + 0x38, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x24, 0xe0, + 0x41, 0x02, 0xfa, 0x41, 0x1e, 0x0a, 0x1c, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x67, 0x6f, + 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x43, 0x6f, 0x6e, + 0x66, 0x69, 0x67, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x22, 0x8f, 0x01, 0x0a, 0x13, 0x55, 0x70, + 0x64, 0x61, 0x74, 0x65, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, + 0x74, 0x12, 0x3b, 0x0a, 0x06, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x18, 0x01, 0x20, 0x01, 0x28, + 0x0b, 0x32, 0x1e, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, + 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x43, 0x6f, 0x6e, 0x66, 0x69, + 0x67, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x06, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x3b, + 0x0a, 0x0b, 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x18, 0x02, 0x20, + 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, + 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x46, 0x69, 0x65, 0x6c, 0x64, 0x4d, 0x61, 0x73, 0x6b, 0x52, + 0x0a, 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, 0x4d, 0x61, 0x73, 0x6b, 0x22, 0xd5, 0x08, 0x0a, 0x0b, + 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x12, 0x1a, 0x0a, 0x04, 0x6e, + 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x06, 0xe0, 0x41, 0x03, 0xe0, 0x41, + 0x08, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x15, 0x0a, 0x03, 0x75, 0x69, 0x64, 0x18, 0x02, + 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x03, 0x75, 0x69, 0x64, 0x12, 0x26, + 0x0a, 0x0c, 0x64, 0x69, 0x73, 0x70, 0x6c, 0x61, 0x79, 0x5f, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x04, + 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0b, 0x64, 0x69, 0x73, 0x70, 0x6c, + 0x61, 0x79, 0x4e, 0x61, 0x6d, 0x65, 0x12, 0x43, 0x0a, 0x05, 0x69, 0x74, 0x65, 0x6d, 0x73, 0x18, + 0x05, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x2d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, + 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x43, + 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x2e, 0x43, 0x6c, 0x61, 0x73, 0x73, + 0x49, 0x74, 0x65, 0x6d, 0x52, 0x05, 0x69, 0x74, 0x65, 0x6d, 0x73, 0x12, 0x44, 0x0a, 0x05, 0x73, + 0x74, 0x61, 0x74, 0x65, 0x18, 0x0f, 0x20, 0x01, 0x28, 0x0e, 0x32, 0x29, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, - 0x2e, 0x76, 0x32, 0x2e, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, - 0x06, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x3b, 0x0a, 0x0b, 0x75, 0x70, 0x64, 0x61, 0x74, - 0x65, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, - 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x46, - 0x69, 0x65, 0x6c, 0x64, 0x4d, 0x61, 0x73, 0x6b, 0x52, 0x0a, 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, - 0x4d, 0x61, 0x73, 0x6b, 0x22, 0xd5, 0x08, 0x0a, 0x0b, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, - 0x6c, 0x61, 0x73, 0x73, 0x12, 0x1a, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, - 0x28, 0x09, 0x42, 0x06, 0xe0, 0x41, 0x03, 0xe0, 0x41, 0x08, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, - 0x12, 0x15, 0x0a, 0x03, 0x75, 0x69, 0x64, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, - 0x41, 0x03, 0x52, 0x03, 0x75, 0x69, 0x64, 0x12, 0x26, 0x0a, 0x0c, 0x64, 0x69, 0x73, 0x70, 0x6c, - 0x61, 0x79, 0x5f, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x04, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, - 0x41, 0x01, 0x52, 0x0b, 0x64, 0x69, 0x73, 0x70, 0x6c, 0x61, 0x79, 0x4e, 0x61, 0x6d, 0x65, 0x12, - 0x43, 0x0a, 0x05, 0x69, 0x74, 0x65, 0x6d, 0x73, 0x18, 0x05, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x2d, + 0x2e, 0x76, 0x32, 0x2e, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x2e, + 0x53, 0x74, 0x61, 0x74, 0x65, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x05, 0x73, 0x74, 0x61, 0x74, + 0x65, 0x12, 0x40, 0x0a, 0x0b, 0x63, 0x72, 0x65, 0x61, 0x74, 0x65, 0x5f, 0x74, 0x69, 0x6d, 0x65, + 0x18, 0x06, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, + 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, + 0x6d, 0x70, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x0a, 0x63, 0x72, 0x65, 0x61, 0x74, 0x65, 0x54, + 0x69, 0x6d, 0x65, 0x12, 0x40, 0x0a, 0x0b, 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, 0x5f, 0x74, 0x69, + 0x6d, 0x65, 0x18, 0x07, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, + 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x73, + 0x74, 0x61, 0x6d, 0x70, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x0a, 0x75, 0x70, 0x64, 0x61, 0x74, + 0x65, 0x54, 0x69, 0x6d, 0x65, 0x12, 0x40, 0x0a, 0x0b, 0x64, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x5f, + 0x74, 0x69, 0x6d, 0x65, 0x18, 0x08, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, + 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x54, 0x69, 0x6d, + 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x0a, 0x64, 0x65, 0x6c, + 0x65, 0x74, 0x65, 0x54, 0x69, 0x6d, 0x65, 0x12, 0x40, 0x0a, 0x0b, 0x65, 0x78, 0x70, 0x69, 0x72, + 0x65, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x18, 0x09, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, + 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x54, + 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x0a, 0x65, + 0x78, 0x70, 0x69, 0x72, 0x65, 0x54, 0x69, 0x6d, 0x65, 0x12, 0x5b, 0x0a, 0x0b, 0x61, 0x6e, 0x6e, + 0x6f, 0x74, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x18, 0x0a, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x34, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, - 0x61, 0x73, 0x73, 0x2e, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x49, 0x74, 0x65, 0x6d, 0x52, 0x05, 0x69, - 0x74, 0x65, 0x6d, 0x73, 0x12, 0x44, 0x0a, 0x05, 0x73, 0x74, 0x61, 0x74, 0x65, 0x18, 0x0f, 0x20, - 0x01, 0x28, 0x0e, 0x32, 0x29, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, - 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x43, 0x75, 0x73, - 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x2e, 0x53, 0x74, 0x61, 0x74, 0x65, 0x42, 0x03, - 0xe0, 0x41, 0x03, 0x52, 0x05, 0x73, 0x74, 0x61, 0x74, 0x65, 0x12, 0x40, 0x0a, 0x0b, 0x63, 0x72, - 0x65, 0x61, 0x74, 0x65, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x18, 0x06, 0x20, 0x01, 0x28, 0x0b, 0x32, - 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, - 0x66, 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x42, 0x03, 0xe0, 0x41, 0x03, - 0x52, 0x0a, 0x63, 0x72, 0x65, 0x61, 0x74, 0x65, 0x54, 0x69, 0x6d, 0x65, 0x12, 0x40, 0x0a, 0x0b, - 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x18, 0x07, 0x20, 0x01, 0x28, - 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, - 0x62, 0x75, 0x66, 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x42, 0x03, 0xe0, - 0x41, 0x03, 0x52, 0x0a, 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, 0x54, 0x69, 0x6d, 0x65, 0x12, 0x40, - 0x0a, 0x0b, 0x64, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x18, 0x08, 0x20, - 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, - 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x42, - 0x03, 0xe0, 0x41, 0x03, 0x52, 0x0a, 0x64, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x54, 0x69, 0x6d, 0x65, - 0x12, 0x40, 0x0a, 0x0b, 0x65, 0x78, 0x70, 0x69, 0x72, 0x65, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x18, - 0x09, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, - 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, - 0x70, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x0a, 0x65, 0x78, 0x70, 0x69, 0x72, 0x65, 0x54, 0x69, - 0x6d, 0x65, 0x12, 0x5b, 0x0a, 0x0b, 0x61, 0x6e, 0x6e, 0x6f, 0x74, 0x61, 0x74, 0x69, 0x6f, 0x6e, - 0x73, 0x18, 0x0a, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x34, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, - 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, - 0x2e, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x2e, 0x41, 0x6e, 0x6e, - 0x6f, 0x74, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x42, 0x03, 0xe0, - 0x41, 0x01, 0x52, 0x0b, 0x61, 0x6e, 0x6e, 0x6f, 0x74, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x12, - 0x17, 0x0a, 0x04, 0x65, 0x74, 0x61, 0x67, 0x18, 0x0b, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, - 0x41, 0x03, 0x52, 0x04, 0x65, 0x74, 0x61, 0x67, 0x12, 0x25, 0x0a, 0x0b, 0x72, 0x65, 0x63, 0x6f, - 0x6e, 0x63, 0x69, 0x6c, 0x69, 0x6e, 0x67, 0x18, 0x0c, 0x20, 0x01, 0x28, 0x08, 0x42, 0x03, 0xe0, - 0x41, 0x03, 0x52, 0x0b, 0x72, 0x65, 0x63, 0x6f, 0x6e, 0x63, 0x69, 0x6c, 0x69, 0x6e, 0x67, 0x12, - 0x4b, 0x0a, 0x0c, 0x6b, 0x6d, 0x73, 0x5f, 0x6b, 0x65, 0x79, 0x5f, 0x6e, 0x61, 0x6d, 0x65, 0x18, - 0x0d, 0x20, 0x01, 0x28, 0x09, 0x42, 0x29, 0xe0, 0x41, 0x03, 0xfa, 0x41, 0x23, 0x0a, 0x21, 0x63, - 0x6c, 0x6f, 0x75, 0x64, 0x6b, 0x6d, 0x73, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, - 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x43, 0x72, 0x79, 0x70, 0x74, 0x6f, 0x4b, 0x65, 0x79, - 0x52, 0x0a, 0x6b, 0x6d, 0x73, 0x4b, 0x65, 0x79, 0x4e, 0x61, 0x6d, 0x65, 0x12, 0x61, 0x0a, 0x14, - 0x6b, 0x6d, 0x73, 0x5f, 0x6b, 0x65, 0x79, 0x5f, 0x76, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x5f, - 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x0e, 0x20, 0x01, 0x28, 0x09, 0x42, 0x30, 0xe0, 0x41, 0x03, 0xfa, - 0x41, 0x2a, 0x0a, 0x28, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x6b, 0x6d, 0x73, 0x2e, 0x67, 0x6f, 0x6f, - 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x43, 0x72, 0x79, 0x70, - 0x74, 0x6f, 0x4b, 0x65, 0x79, 0x56, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x52, 0x11, 0x6b, 0x6d, - 0x73, 0x4b, 0x65, 0x79, 0x56, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x4e, 0x61, 0x6d, 0x65, 0x1a, - 0x21, 0x0a, 0x09, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x49, 0x74, 0x65, 0x6d, 0x12, 0x14, 0x0a, 0x05, - 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, 0x61, 0x6c, - 0x75, 0x65, 0x1a, 0x3e, 0x0a, 0x10, 0x41, 0x6e, 0x6e, 0x6f, 0x74, 0x61, 0x74, 0x69, 0x6f, 0x6e, - 0x73, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, 0x03, 0x6b, 0x65, 0x79, 0x18, 0x01, 0x20, - 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x14, 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, - 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x3a, 0x02, - 0x38, 0x01, 0x22, 0x37, 0x0a, 0x05, 0x53, 0x74, 0x61, 0x74, 0x65, 0x12, 0x15, 0x0a, 0x11, 0x53, - 0x54, 0x41, 0x54, 0x45, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, - 0x10, 0x00, 0x12, 0x0a, 0x0a, 0x06, 0x41, 0x43, 0x54, 0x49, 0x56, 0x45, 0x10, 0x02, 0x12, 0x0b, - 0x0a, 0x07, 0x44, 0x45, 0x4c, 0x45, 0x54, 0x45, 0x44, 0x10, 0x04, 0x3a, 0x6f, 0xea, 0x41, 0x6c, - 0x0a, 0x21, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, - 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, - 0x61, 0x73, 0x73, 0x12, 0x44, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x7b, 0x70, - 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x7d, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, - 0x73, 0x2f, 0x7b, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x7d, 0x2f, 0x63, 0x75, 0x73, - 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x65, 0x73, 0x2f, 0x7b, 0x63, 0x75, 0x73, 0x74, - 0x6f, 0x6d, 0x5f, 0x63, 0x6c, 0x61, 0x73, 0x73, 0x7d, 0x52, 0x01, 0x01, 0x22, 0xe6, 0x08, 0x0a, - 0x09, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x12, 0x1a, 0x0a, 0x04, 0x6e, 0x61, - 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x06, 0xe0, 0x41, 0x03, 0xe0, 0x41, 0x08, - 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x15, 0x0a, 0x03, 0x75, 0x69, 0x64, 0x18, 0x02, 0x20, - 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x03, 0x75, 0x69, 0x64, 0x12, 0x42, 0x0a, - 0x07, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x73, 0x18, 0x03, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x28, - 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, - 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, - 0x74, 0x2e, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x52, 0x07, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, - 0x73, 0x12, 0x14, 0x0a, 0x05, 0x62, 0x6f, 0x6f, 0x73, 0x74, 0x18, 0x04, 0x20, 0x01, 0x28, 0x02, - 0x52, 0x05, 0x62, 0x6f, 0x6f, 0x73, 0x74, 0x12, 0x21, 0x0a, 0x0c, 0x64, 0x69, 0x73, 0x70, 0x6c, - 0x61, 0x79, 0x5f, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x05, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0b, 0x64, - 0x69, 0x73, 0x70, 0x6c, 0x61, 0x79, 0x4e, 0x61, 0x6d, 0x65, 0x12, 0x42, 0x0a, 0x05, 0x73, 0x74, - 0x61, 0x74, 0x65, 0x18, 0x0f, 0x20, 0x01, 0x28, 0x0e, 0x32, 0x27, 0x2e, 0x67, 0x6f, 0x6f, 0x67, - 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, - 0x76, 0x32, 0x2e, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x2e, 0x53, 0x74, 0x61, - 0x74, 0x65, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x05, 0x73, 0x74, 0x61, 0x74, 0x65, 0x12, 0x40, - 0x0a, 0x0b, 0x63, 0x72, 0x65, 0x61, 0x74, 0x65, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x18, 0x06, 0x20, - 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, - 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x42, - 0x03, 0xe0, 0x41, 0x03, 0x52, 0x0a, 0x63, 0x72, 0x65, 0x61, 0x74, 0x65, 0x54, 0x69, 0x6d, 0x65, - 0x12, 0x40, 0x0a, 0x0b, 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x18, - 0x07, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, - 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, - 0x70, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x0a, 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, 0x54, 0x69, - 0x6d, 0x65, 0x12, 0x40, 0x0a, 0x0b, 0x64, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x5f, 0x74, 0x69, 0x6d, - 0x65, 0x18, 0x08, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, - 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x73, 0x74, - 0x61, 0x6d, 0x70, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x0a, 0x64, 0x65, 0x6c, 0x65, 0x74, 0x65, - 0x54, 0x69, 0x6d, 0x65, 0x12, 0x40, 0x0a, 0x0b, 0x65, 0x78, 0x70, 0x69, 0x72, 0x65, 0x5f, 0x74, - 0x69, 0x6d, 0x65, 0x18, 0x09, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, - 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x54, 0x69, 0x6d, 0x65, - 0x73, 0x74, 0x61, 0x6d, 0x70, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x0a, 0x65, 0x78, 0x70, 0x69, - 0x72, 0x65, 0x54, 0x69, 0x6d, 0x65, 0x12, 0x54, 0x0a, 0x0b, 0x61, 0x6e, 0x6e, 0x6f, 0x74, 0x61, - 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x18, 0x0a, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x32, 0x2e, 0x67, 0x6f, - 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, - 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x2e, 0x41, - 0x6e, 0x6e, 0x6f, 0x74, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x52, - 0x0b, 0x61, 0x6e, 0x6e, 0x6f, 0x74, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x12, 0x17, 0x0a, 0x04, - 0x65, 0x74, 0x61, 0x67, 0x18, 0x0b, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, - 0x04, 0x65, 0x74, 0x61, 0x67, 0x12, 0x25, 0x0a, 0x0b, 0x72, 0x65, 0x63, 0x6f, 0x6e, 0x63, 0x69, - 0x6c, 0x69, 0x6e, 0x67, 0x18, 0x0c, 0x20, 0x01, 0x28, 0x08, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, - 0x0b, 0x72, 0x65, 0x63, 0x6f, 0x6e, 0x63, 0x69, 0x6c, 0x69, 0x6e, 0x67, 0x12, 0x4b, 0x0a, 0x0c, - 0x6b, 0x6d, 0x73, 0x5f, 0x6b, 0x65, 0x79, 0x5f, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x0d, 0x20, 0x01, - 0x28, 0x09, 0x42, 0x29, 0xe0, 0x41, 0x03, 0xfa, 0x41, 0x23, 0x0a, 0x21, 0x63, 0x6c, 0x6f, 0x75, - 0x64, 0x6b, 0x6d, 0x73, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, - 0x63, 0x6f, 0x6d, 0x2f, 0x43, 0x72, 0x79, 0x70, 0x74, 0x6f, 0x4b, 0x65, 0x79, 0x52, 0x0a, 0x6b, - 0x6d, 0x73, 0x4b, 0x65, 0x79, 0x4e, 0x61, 0x6d, 0x65, 0x12, 0x61, 0x0a, 0x14, 0x6b, 0x6d, 0x73, - 0x5f, 0x6b, 0x65, 0x79, 0x5f, 0x76, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x5f, 0x6e, 0x61, 0x6d, - 0x65, 0x18, 0x0e, 0x20, 0x01, 0x28, 0x09, 0x42, 0x30, 0xe0, 0x41, 0x03, 0xfa, 0x41, 0x2a, 0x0a, - 0x28, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x6b, 0x6d, 0x73, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, - 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x43, 0x72, 0x79, 0x70, 0x74, 0x6f, 0x4b, - 0x65, 0x79, 0x56, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x52, 0x11, 0x6b, 0x6d, 0x73, 0x4b, 0x65, - 0x79, 0x56, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x4e, 0x61, 0x6d, 0x65, 0x1a, 0x34, 0x0a, 0x06, - 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x12, 0x14, 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, - 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x12, 0x14, 0x0a, 0x05, - 0x62, 0x6f, 0x6f, 0x73, 0x74, 0x18, 0x02, 0x20, 0x01, 0x28, 0x02, 0x52, 0x05, 0x62, 0x6f, 0x6f, - 0x73, 0x74, 0x1a, 0x3e, 0x0a, 0x10, 0x41, 0x6e, 0x6e, 0x6f, 0x74, 0x61, 0x74, 0x69, 0x6f, 0x6e, - 0x73, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, 0x03, 0x6b, 0x65, 0x79, 0x18, 0x01, 0x20, - 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x14, 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, - 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x3a, 0x02, - 0x38, 0x01, 0x22, 0x37, 0x0a, 0x05, 0x53, 0x74, 0x61, 0x74, 0x65, 0x12, 0x15, 0x0a, 0x11, 0x53, - 0x54, 0x41, 0x54, 0x45, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, - 0x10, 0x00, 0x12, 0x0a, 0x0a, 0x06, 0x41, 0x43, 0x54, 0x49, 0x56, 0x45, 0x10, 0x02, 0x12, 0x0b, - 0x0a, 0x07, 0x44, 0x45, 0x4c, 0x45, 0x54, 0x45, 0x44, 0x10, 0x04, 0x3a, 0x68, 0xea, 0x41, 0x65, - 0x0a, 0x1f, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, - 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, - 0x74, 0x12, 0x3f, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x7b, 0x70, 0x72, 0x6f, - 0x6a, 0x65, 0x63, 0x74, 0x7d, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, - 0x7b, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x7d, 0x2f, 0x70, 0x68, 0x72, 0x61, 0x73, - 0x65, 0x53, 0x65, 0x74, 0x73, 0x2f, 0x7b, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x5f, 0x73, 0x65, - 0x74, 0x7d, 0x52, 0x01, 0x01, 0x22, 0xf7, 0x01, 0x0a, 0x18, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, - 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, - 0x73, 0x74, 0x12, 0x4b, 0x0a, 0x0c, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x5f, 0x63, 0x6c, 0x61, - 0x73, 0x73, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x23, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, - 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, - 0x32, 0x2e, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x42, 0x03, 0xe0, - 0x41, 0x02, 0x52, 0x0b, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x12, - 0x23, 0x0a, 0x0d, 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, 0x65, 0x5f, 0x6f, 0x6e, 0x6c, 0x79, - 0x18, 0x02, 0x20, 0x01, 0x28, 0x08, 0x52, 0x0c, 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, 0x65, - 0x4f, 0x6e, 0x6c, 0x79, 0x12, 0x26, 0x0a, 0x0f, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x5f, 0x63, - 0x6c, 0x61, 0x73, 0x73, 0x5f, 0x69, 0x64, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0d, 0x63, - 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x49, 0x64, 0x12, 0x41, 0x0a, 0x06, - 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x18, 0x04, 0x20, 0x01, 0x28, 0x09, 0x42, 0x29, 0xe0, 0x41, - 0x02, 0xfa, 0x41, 0x23, 0x12, 0x21, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x67, 0x6f, 0x6f, - 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x43, 0x75, 0x73, 0x74, - 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x52, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x22, - 0xbc, 0x01, 0x0a, 0x18, 0x4c, 0x69, 0x73, 0x74, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, - 0x61, 0x73, 0x73, 0x65, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x41, 0x0a, 0x06, - 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x29, 0xe0, 0x41, - 0x02, 0xfa, 0x41, 0x23, 0x0a, 0x21, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2e, - 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x4c, - 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x12, - 0x1b, 0x0a, 0x09, 0x70, 0x61, 0x67, 0x65, 0x5f, 0x73, 0x69, 0x7a, 0x65, 0x18, 0x02, 0x20, 0x01, - 0x28, 0x05, 0x52, 0x08, 0x70, 0x61, 0x67, 0x65, 0x53, 0x69, 0x7a, 0x65, 0x12, 0x1d, 0x0a, 0x0a, - 0x70, 0x61, 0x67, 0x65, 0x5f, 0x74, 0x6f, 0x6b, 0x65, 0x6e, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, - 0x52, 0x09, 0x70, 0x61, 0x67, 0x65, 0x54, 0x6f, 0x6b, 0x65, 0x6e, 0x12, 0x21, 0x0a, 0x0c, 0x73, - 0x68, 0x6f, 0x77, 0x5f, 0x64, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x64, 0x18, 0x04, 0x20, 0x01, 0x28, - 0x08, 0x52, 0x0b, 0x73, 0x68, 0x6f, 0x77, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x64, 0x22, 0x8f, - 0x01, 0x0a, 0x19, 0x4c, 0x69, 0x73, 0x74, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, - 0x73, 0x73, 0x65, 0x73, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x4a, 0x0a, 0x0e, - 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x5f, 0x63, 0x6c, 0x61, 0x73, 0x73, 0x65, 0x73, 0x18, 0x01, - 0x20, 0x03, 0x28, 0x0b, 0x32, 0x23, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, - 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x43, 0x75, - 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x52, 0x0d, 0x63, 0x75, 0x73, 0x74, 0x6f, - 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x65, 0x73, 0x12, 0x26, 0x0a, 0x0f, 0x6e, 0x65, 0x78, 0x74, - 0x5f, 0x70, 0x61, 0x67, 0x65, 0x5f, 0x74, 0x6f, 0x6b, 0x65, 0x6e, 0x18, 0x02, 0x20, 0x01, 0x28, - 0x09, 0x52, 0x0d, 0x6e, 0x65, 0x78, 0x74, 0x50, 0x61, 0x67, 0x65, 0x54, 0x6f, 0x6b, 0x65, 0x6e, - 0x22, 0x56, 0x0a, 0x15, 0x47, 0x65, 0x74, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, - 0x73, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x3d, 0x0a, 0x04, 0x6e, 0x61, 0x6d, - 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x29, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x23, 0x0a, - 0x21, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, - 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, - 0x73, 0x73, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x22, 0xc9, 0x01, 0x0a, 0x18, 0x55, 0x70, 0x64, - 0x61, 0x74, 0x65, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x52, 0x65, - 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x4b, 0x0a, 0x0c, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x5f, - 0x63, 0x6c, 0x61, 0x73, 0x73, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x23, 0x2e, 0x67, 0x6f, + 0x61, 0x73, 0x73, 0x2e, 0x41, 0x6e, 0x6e, 0x6f, 0x74, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x45, + 0x6e, 0x74, 0x72, 0x79, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0b, 0x61, 0x6e, 0x6e, 0x6f, 0x74, + 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x12, 0x17, 0x0a, 0x04, 0x65, 0x74, 0x61, 0x67, 0x18, 0x0b, + 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x04, 0x65, 0x74, 0x61, 0x67, 0x12, + 0x25, 0x0a, 0x0b, 0x72, 0x65, 0x63, 0x6f, 0x6e, 0x63, 0x69, 0x6c, 0x69, 0x6e, 0x67, 0x18, 0x0c, + 0x20, 0x01, 0x28, 0x08, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x0b, 0x72, 0x65, 0x63, 0x6f, 0x6e, + 0x63, 0x69, 0x6c, 0x69, 0x6e, 0x67, 0x12, 0x4b, 0x0a, 0x0c, 0x6b, 0x6d, 0x73, 0x5f, 0x6b, 0x65, + 0x79, 0x5f, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x0d, 0x20, 0x01, 0x28, 0x09, 0x42, 0x29, 0xe0, 0x41, + 0x03, 0xfa, 0x41, 0x23, 0x0a, 0x21, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x6b, 0x6d, 0x73, 0x2e, 0x67, + 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x43, 0x72, + 0x79, 0x70, 0x74, 0x6f, 0x4b, 0x65, 0x79, 0x52, 0x0a, 0x6b, 0x6d, 0x73, 0x4b, 0x65, 0x79, 0x4e, + 0x61, 0x6d, 0x65, 0x12, 0x61, 0x0a, 0x14, 0x6b, 0x6d, 0x73, 0x5f, 0x6b, 0x65, 0x79, 0x5f, 0x76, + 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x5f, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x0e, 0x20, 0x01, 0x28, + 0x09, 0x42, 0x30, 0xe0, 0x41, 0x03, 0xfa, 0x41, 0x2a, 0x0a, 0x28, 0x63, 0x6c, 0x6f, 0x75, 0x64, + 0x6b, 0x6d, 0x73, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, + 0x6f, 0x6d, 0x2f, 0x43, 0x72, 0x79, 0x70, 0x74, 0x6f, 0x4b, 0x65, 0x79, 0x56, 0x65, 0x72, 0x73, + 0x69, 0x6f, 0x6e, 0x52, 0x11, 0x6b, 0x6d, 0x73, 0x4b, 0x65, 0x79, 0x56, 0x65, 0x72, 0x73, 0x69, + 0x6f, 0x6e, 0x4e, 0x61, 0x6d, 0x65, 0x1a, 0x21, 0x0a, 0x09, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x49, + 0x74, 0x65, 0x6d, 0x12, 0x14, 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x01, 0x20, 0x01, + 0x28, 0x09, 0x52, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x1a, 0x3e, 0x0a, 0x10, 0x41, 0x6e, 0x6e, + 0x6f, 0x74, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, + 0x03, 0x6b, 0x65, 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, + 0x14, 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, + 0x76, 0x61, 0x6c, 0x75, 0x65, 0x3a, 0x02, 0x38, 0x01, 0x22, 0x37, 0x0a, 0x05, 0x53, 0x74, 0x61, + 0x74, 0x65, 0x12, 0x15, 0x0a, 0x11, 0x53, 0x54, 0x41, 0x54, 0x45, 0x5f, 0x55, 0x4e, 0x53, 0x50, + 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x0a, 0x0a, 0x06, 0x41, 0x43, 0x54, + 0x49, 0x56, 0x45, 0x10, 0x02, 0x12, 0x0b, 0x0a, 0x07, 0x44, 0x45, 0x4c, 0x45, 0x54, 0x45, 0x44, + 0x10, 0x04, 0x3a, 0x6f, 0xea, 0x41, 0x6c, 0x0a, 0x21, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, + 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x43, + 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x12, 0x44, 0x70, 0x72, 0x6f, 0x6a, + 0x65, 0x63, 0x74, 0x73, 0x2f, 0x7b, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x7d, 0x2f, 0x6c, + 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x7b, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, + 0x6f, 0x6e, 0x7d, 0x2f, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x65, + 0x73, 0x2f, 0x7b, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x5f, 0x63, 0x6c, 0x61, 0x73, 0x73, 0x7d, + 0x52, 0x01, 0x01, 0x22, 0xe6, 0x08, 0x0a, 0x09, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, + 0x74, 0x12, 0x1a, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, + 0x06, 0xe0, 0x41, 0x03, 0xe0, 0x41, 0x08, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x15, 0x0a, + 0x03, 0x75, 0x69, 0x64, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, + 0x03, 0x75, 0x69, 0x64, 0x12, 0x42, 0x0a, 0x07, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x73, 0x18, + 0x03, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x28, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, + 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x50, + 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x2e, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x52, + 0x07, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x73, 0x12, 0x14, 0x0a, 0x05, 0x62, 0x6f, 0x6f, 0x73, + 0x74, 0x18, 0x04, 0x20, 0x01, 0x28, 0x02, 0x52, 0x05, 0x62, 0x6f, 0x6f, 0x73, 0x74, 0x12, 0x21, + 0x0a, 0x0c, 0x64, 0x69, 0x73, 0x70, 0x6c, 0x61, 0x79, 0x5f, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x05, + 0x20, 0x01, 0x28, 0x09, 0x52, 0x0b, 0x64, 0x69, 0x73, 0x70, 0x6c, 0x61, 0x79, 0x4e, 0x61, 0x6d, + 0x65, 0x12, 0x42, 0x0a, 0x05, 0x73, 0x74, 0x61, 0x74, 0x65, 0x18, 0x0f, 0x20, 0x01, 0x28, 0x0e, + 0x32, 0x27, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, + 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, + 0x53, 0x65, 0x74, 0x2e, 0x53, 0x74, 0x61, 0x74, 0x65, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x05, + 0x73, 0x74, 0x61, 0x74, 0x65, 0x12, 0x40, 0x0a, 0x0b, 0x63, 0x72, 0x65, 0x61, 0x74, 0x65, 0x5f, + 0x74, 0x69, 0x6d, 0x65, 0x18, 0x06, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, + 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x54, 0x69, 0x6d, + 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x0a, 0x63, 0x72, 0x65, + 0x61, 0x74, 0x65, 0x54, 0x69, 0x6d, 0x65, 0x12, 0x40, 0x0a, 0x0b, 0x75, 0x70, 0x64, 0x61, 0x74, + 0x65, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x18, 0x07, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, + 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x54, + 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x0a, 0x75, + 0x70, 0x64, 0x61, 0x74, 0x65, 0x54, 0x69, 0x6d, 0x65, 0x12, 0x40, 0x0a, 0x0b, 0x64, 0x65, 0x6c, + 0x65, 0x74, 0x65, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x18, 0x08, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, + 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, + 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, + 0x0a, 0x64, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x54, 0x69, 0x6d, 0x65, 0x12, 0x40, 0x0a, 0x0b, 0x65, + 0x78, 0x70, 0x69, 0x72, 0x65, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x18, 0x09, 0x20, 0x01, 0x28, 0x0b, + 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, + 0x75, 0x66, 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x42, 0x03, 0xe0, 0x41, + 0x03, 0x52, 0x0a, 0x65, 0x78, 0x70, 0x69, 0x72, 0x65, 0x54, 0x69, 0x6d, 0x65, 0x12, 0x54, 0x0a, + 0x0b, 0x61, 0x6e, 0x6e, 0x6f, 0x74, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x18, 0x0a, 0x20, 0x03, + 0x28, 0x0b, 0x32, 0x32, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, + 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x50, 0x68, 0x72, 0x61, + 0x73, 0x65, 0x53, 0x65, 0x74, 0x2e, 0x41, 0x6e, 0x6e, 0x6f, 0x74, 0x61, 0x74, 0x69, 0x6f, 0x6e, + 0x73, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x52, 0x0b, 0x61, 0x6e, 0x6e, 0x6f, 0x74, 0x61, 0x74, 0x69, + 0x6f, 0x6e, 0x73, 0x12, 0x17, 0x0a, 0x04, 0x65, 0x74, 0x61, 0x67, 0x18, 0x0b, 0x20, 0x01, 0x28, + 0x09, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x04, 0x65, 0x74, 0x61, 0x67, 0x12, 0x25, 0x0a, 0x0b, + 0x72, 0x65, 0x63, 0x6f, 0x6e, 0x63, 0x69, 0x6c, 0x69, 0x6e, 0x67, 0x18, 0x0c, 0x20, 0x01, 0x28, + 0x08, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x0b, 0x72, 0x65, 0x63, 0x6f, 0x6e, 0x63, 0x69, 0x6c, + 0x69, 0x6e, 0x67, 0x12, 0x4b, 0x0a, 0x0c, 0x6b, 0x6d, 0x73, 0x5f, 0x6b, 0x65, 0x79, 0x5f, 0x6e, + 0x61, 0x6d, 0x65, 0x18, 0x0d, 0x20, 0x01, 0x28, 0x09, 0x42, 0x29, 0xe0, 0x41, 0x03, 0xfa, 0x41, + 0x23, 0x0a, 0x21, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x6b, 0x6d, 0x73, 0x2e, 0x67, 0x6f, 0x6f, 0x67, + 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x43, 0x72, 0x79, 0x70, 0x74, + 0x6f, 0x4b, 0x65, 0x79, 0x52, 0x0a, 0x6b, 0x6d, 0x73, 0x4b, 0x65, 0x79, 0x4e, 0x61, 0x6d, 0x65, + 0x12, 0x61, 0x0a, 0x14, 0x6b, 0x6d, 0x73, 0x5f, 0x6b, 0x65, 0x79, 0x5f, 0x76, 0x65, 0x72, 0x73, + 0x69, 0x6f, 0x6e, 0x5f, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x0e, 0x20, 0x01, 0x28, 0x09, 0x42, 0x30, + 0xe0, 0x41, 0x03, 0xfa, 0x41, 0x2a, 0x0a, 0x28, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x6b, 0x6d, 0x73, + 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, + 0x43, 0x72, 0x79, 0x70, 0x74, 0x6f, 0x4b, 0x65, 0x79, 0x56, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, + 0x52, 0x11, 0x6b, 0x6d, 0x73, 0x4b, 0x65, 0x79, 0x56, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x4e, + 0x61, 0x6d, 0x65, 0x1a, 0x34, 0x0a, 0x06, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x12, 0x14, 0x0a, + 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, 0x61, + 0x6c, 0x75, 0x65, 0x12, 0x14, 0x0a, 0x05, 0x62, 0x6f, 0x6f, 0x73, 0x74, 0x18, 0x02, 0x20, 0x01, + 0x28, 0x02, 0x52, 0x05, 0x62, 0x6f, 0x6f, 0x73, 0x74, 0x1a, 0x3e, 0x0a, 0x10, 0x41, 0x6e, 0x6e, + 0x6f, 0x74, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, + 0x03, 0x6b, 0x65, 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, + 0x14, 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, + 0x76, 0x61, 0x6c, 0x75, 0x65, 0x3a, 0x02, 0x38, 0x01, 0x22, 0x37, 0x0a, 0x05, 0x53, 0x74, 0x61, + 0x74, 0x65, 0x12, 0x15, 0x0a, 0x11, 0x53, 0x54, 0x41, 0x54, 0x45, 0x5f, 0x55, 0x4e, 0x53, 0x50, + 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x0a, 0x0a, 0x06, 0x41, 0x43, 0x54, + 0x49, 0x56, 0x45, 0x10, 0x02, 0x12, 0x0b, 0x0a, 0x07, 0x44, 0x45, 0x4c, 0x45, 0x54, 0x45, 0x44, + 0x10, 0x04, 0x3a, 0x68, 0xea, 0x41, 0x65, 0x0a, 0x1f, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, + 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x50, + 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x12, 0x3f, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, + 0x74, 0x73, 0x2f, 0x7b, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x7d, 0x2f, 0x6c, 0x6f, 0x63, + 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x7b, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, + 0x7d, 0x2f, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x73, 0x2f, 0x7b, 0x70, 0x68, + 0x72, 0x61, 0x73, 0x65, 0x5f, 0x73, 0x65, 0x74, 0x7d, 0x52, 0x01, 0x01, 0x22, 0xf7, 0x01, 0x0a, + 0x18, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, + 0x73, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x4b, 0x0a, 0x0c, 0x63, 0x75, 0x73, + 0x74, 0x6f, 0x6d, 0x5f, 0x63, 0x6c, 0x61, 0x73, 0x73, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, + 0x23, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, + 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, + 0x6c, 0x61, 0x73, 0x73, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x0b, 0x63, 0x75, 0x73, 0x74, 0x6f, + 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x12, 0x23, 0x0a, 0x0d, 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, + 0x74, 0x65, 0x5f, 0x6f, 0x6e, 0x6c, 0x79, 0x18, 0x02, 0x20, 0x01, 0x28, 0x08, 0x52, 0x0c, 0x76, + 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, 0x65, 0x4f, 0x6e, 0x6c, 0x79, 0x12, 0x26, 0x0a, 0x0f, 0x63, + 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x5f, 0x63, 0x6c, 0x61, 0x73, 0x73, 0x5f, 0x69, 0x64, 0x18, 0x03, + 0x20, 0x01, 0x28, 0x09, 0x52, 0x0d, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, + 0x73, 0x49, 0x64, 0x12, 0x41, 0x0a, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x18, 0x04, 0x20, + 0x01, 0x28, 0x09, 0x42, 0x29, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x23, 0x12, 0x21, 0x73, 0x70, 0x65, + 0x65, 0x63, 0x68, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, + 0x6f, 0x6d, 0x2f, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x52, 0x06, + 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x22, 0xbc, 0x01, 0x0a, 0x18, 0x4c, 0x69, 0x73, 0x74, 0x43, + 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x65, 0x73, 0x52, 0x65, 0x71, 0x75, + 0x65, 0x73, 0x74, 0x12, 0x41, 0x0a, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x18, 0x01, 0x20, + 0x01, 0x28, 0x09, 0x42, 0x29, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x23, 0x0a, 0x21, 0x6c, 0x6f, 0x63, + 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, + 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x4c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x06, + 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x12, 0x1b, 0x0a, 0x09, 0x70, 0x61, 0x67, 0x65, 0x5f, 0x73, + 0x69, 0x7a, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x05, 0x52, 0x08, 0x70, 0x61, 0x67, 0x65, 0x53, + 0x69, 0x7a, 0x65, 0x12, 0x1d, 0x0a, 0x0a, 0x70, 0x61, 0x67, 0x65, 0x5f, 0x74, 0x6f, 0x6b, 0x65, + 0x6e, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x52, 0x09, 0x70, 0x61, 0x67, 0x65, 0x54, 0x6f, 0x6b, + 0x65, 0x6e, 0x12, 0x21, 0x0a, 0x0c, 0x73, 0x68, 0x6f, 0x77, 0x5f, 0x64, 0x65, 0x6c, 0x65, 0x74, + 0x65, 0x64, 0x18, 0x04, 0x20, 0x01, 0x28, 0x08, 0x52, 0x0b, 0x73, 0x68, 0x6f, 0x77, 0x44, 0x65, + 0x6c, 0x65, 0x74, 0x65, 0x64, 0x22, 0x8f, 0x01, 0x0a, 0x19, 0x4c, 0x69, 0x73, 0x74, 0x43, 0x75, + 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x65, 0x73, 0x52, 0x65, 0x73, 0x70, 0x6f, + 0x6e, 0x73, 0x65, 0x12, 0x4a, 0x0a, 0x0e, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x5f, 0x63, 0x6c, + 0x61, 0x73, 0x73, 0x65, 0x73, 0x18, 0x01, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x23, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, - 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x0b, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, - 0x73, 0x73, 0x12, 0x3b, 0x0a, 0x0b, 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, 0x5f, 0x6d, 0x61, 0x73, - 0x6b, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, - 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x46, 0x69, 0x65, 0x6c, 0x64, 0x4d, - 0x61, 0x73, 0x6b, 0x52, 0x0a, 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, 0x4d, 0x61, 0x73, 0x6b, 0x12, - 0x23, 0x0a, 0x0d, 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, 0x65, 0x5f, 0x6f, 0x6e, 0x6c, 0x79, - 0x18, 0x04, 0x20, 0x01, 0x28, 0x08, 0x52, 0x0c, 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, 0x65, - 0x4f, 0x6e, 0x6c, 0x79, 0x22, 0xb7, 0x01, 0x0a, 0x18, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x43, - 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, - 0x74, 0x12, 0x3d, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, - 0x29, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x23, 0x0a, 0x21, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, - 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x43, - 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, - 0x12, 0x23, 0x0a, 0x0d, 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, 0x65, 0x5f, 0x6f, 0x6e, 0x6c, - 0x79, 0x18, 0x02, 0x20, 0x01, 0x28, 0x08, 0x52, 0x0c, 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, - 0x65, 0x4f, 0x6e, 0x6c, 0x79, 0x12, 0x23, 0x0a, 0x0d, 0x61, 0x6c, 0x6c, 0x6f, 0x77, 0x5f, 0x6d, - 0x69, 0x73, 0x73, 0x69, 0x6e, 0x67, 0x18, 0x04, 0x20, 0x01, 0x28, 0x08, 0x52, 0x0c, 0x61, 0x6c, - 0x6c, 0x6f, 0x77, 0x4d, 0x69, 0x73, 0x73, 0x69, 0x6e, 0x67, 0x12, 0x12, 0x0a, 0x04, 0x65, 0x74, - 0x61, 0x67, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x52, 0x04, 0x65, 0x74, 0x61, 0x67, 0x22, 0x94, - 0x01, 0x0a, 0x1a, 0x55, 0x6e, 0x64, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x43, 0x75, 0x73, 0x74, 0x6f, - 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x3d, 0x0a, - 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x29, 0xe0, 0x41, 0x02, - 0xfa, 0x41, 0x23, 0x0a, 0x21, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x67, 0x6f, 0x6f, 0x67, - 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x43, 0x75, 0x73, 0x74, 0x6f, - 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x23, 0x0a, 0x0d, - 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, 0x65, 0x5f, 0x6f, 0x6e, 0x6c, 0x79, 0x18, 0x03, 0x20, - 0x01, 0x28, 0x08, 0x52, 0x0c, 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, 0x65, 0x4f, 0x6e, 0x6c, - 0x79, 0x12, 0x12, 0x0a, 0x04, 0x65, 0x74, 0x61, 0x67, 0x18, 0x04, 0x20, 0x01, 0x28, 0x09, 0x52, - 0x04, 0x65, 0x74, 0x61, 0x67, 0x22, 0xe9, 0x01, 0x0a, 0x16, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, - 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, - 0x12, 0x45, 0x0a, 0x0a, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x5f, 0x73, 0x65, 0x74, 0x18, 0x01, - 0x20, 0x01, 0x28, 0x0b, 0x32, 0x21, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, - 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x50, 0x68, - 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x09, 0x70, 0x68, - 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x12, 0x23, 0x0a, 0x0d, 0x76, 0x61, 0x6c, 0x69, 0x64, + 0x52, 0x0d, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x65, 0x73, 0x12, + 0x26, 0x0a, 0x0f, 0x6e, 0x65, 0x78, 0x74, 0x5f, 0x70, 0x61, 0x67, 0x65, 0x5f, 0x74, 0x6f, 0x6b, + 0x65, 0x6e, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0d, 0x6e, 0x65, 0x78, 0x74, 0x50, 0x61, + 0x67, 0x65, 0x54, 0x6f, 0x6b, 0x65, 0x6e, 0x22, 0x56, 0x0a, 0x15, 0x47, 0x65, 0x74, 0x43, 0x75, + 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, + 0x12, 0x3d, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x29, + 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x23, 0x0a, 0x21, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x67, + 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x43, 0x75, + 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x22, + 0xc9, 0x01, 0x0a, 0x18, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, + 0x43, 0x6c, 0x61, 0x73, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x4b, 0x0a, 0x0c, + 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x5f, 0x63, 0x6c, 0x61, 0x73, 0x73, 0x18, 0x01, 0x20, 0x01, + 0x28, 0x0b, 0x32, 0x23, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, + 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x43, 0x75, 0x73, 0x74, + 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x0b, 0x63, 0x75, + 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x12, 0x3b, 0x0a, 0x0b, 0x75, 0x70, 0x64, + 0x61, 0x74, 0x65, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, + 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, + 0x2e, 0x46, 0x69, 0x65, 0x6c, 0x64, 0x4d, 0x61, 0x73, 0x6b, 0x52, 0x0a, 0x75, 0x70, 0x64, 0x61, + 0x74, 0x65, 0x4d, 0x61, 0x73, 0x6b, 0x12, 0x23, 0x0a, 0x0d, 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, + 0x74, 0x65, 0x5f, 0x6f, 0x6e, 0x6c, 0x79, 0x18, 0x04, 0x20, 0x01, 0x28, 0x08, 0x52, 0x0c, 0x76, + 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, 0x65, 0x4f, 0x6e, 0x6c, 0x79, 0x22, 0xb7, 0x01, 0x0a, 0x18, + 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, + 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x3d, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, + 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x29, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x23, 0x0a, 0x21, + 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, + 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, + 0x73, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x23, 0x0a, 0x0d, 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, 0x65, 0x5f, 0x6f, 0x6e, 0x6c, 0x79, 0x18, 0x02, 0x20, 0x01, 0x28, 0x08, 0x52, 0x0c, - 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, 0x65, 0x4f, 0x6e, 0x6c, 0x79, 0x12, 0x22, 0x0a, 0x0d, - 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x5f, 0x73, 0x65, 0x74, 0x5f, 0x69, 0x64, 0x18, 0x03, 0x20, - 0x01, 0x28, 0x09, 0x52, 0x0b, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x49, 0x64, - 0x12, 0x3f, 0x0a, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x18, 0x04, 0x20, 0x01, 0x28, 0x09, - 0x42, 0x27, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x21, 0x12, 0x1f, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, + 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, 0x65, 0x4f, 0x6e, 0x6c, 0x79, 0x12, 0x23, 0x0a, 0x0d, + 0x61, 0x6c, 0x6c, 0x6f, 0x77, 0x5f, 0x6d, 0x69, 0x73, 0x73, 0x69, 0x6e, 0x67, 0x18, 0x04, 0x20, + 0x01, 0x28, 0x08, 0x52, 0x0c, 0x61, 0x6c, 0x6c, 0x6f, 0x77, 0x4d, 0x69, 0x73, 0x73, 0x69, 0x6e, + 0x67, 0x12, 0x12, 0x0a, 0x04, 0x65, 0x74, 0x61, 0x67, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x52, + 0x04, 0x65, 0x74, 0x61, 0x67, 0x22, 0x94, 0x01, 0x0a, 0x1a, 0x55, 0x6e, 0x64, 0x65, 0x6c, 0x65, + 0x74, 0x65, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x52, 0x65, 0x71, + 0x75, 0x65, 0x73, 0x74, 0x12, 0x3d, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, + 0x28, 0x09, 0x42, 0x29, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x23, 0x0a, 0x21, 0x73, 0x70, 0x65, 0x65, + 0x63, 0x68, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, + 0x6d, 0x2f, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x52, 0x04, 0x6e, + 0x61, 0x6d, 0x65, 0x12, 0x23, 0x0a, 0x0d, 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, 0x65, 0x5f, + 0x6f, 0x6e, 0x6c, 0x79, 0x18, 0x03, 0x20, 0x01, 0x28, 0x08, 0x52, 0x0c, 0x76, 0x61, 0x6c, 0x69, + 0x64, 0x61, 0x74, 0x65, 0x4f, 0x6e, 0x6c, 0x79, 0x12, 0x12, 0x0a, 0x04, 0x65, 0x74, 0x61, 0x67, + 0x18, 0x04, 0x20, 0x01, 0x28, 0x09, 0x52, 0x04, 0x65, 0x74, 0x61, 0x67, 0x22, 0xe9, 0x01, 0x0a, + 0x16, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, + 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x45, 0x0a, 0x0a, 0x70, 0x68, 0x72, 0x61, 0x73, + 0x65, 0x5f, 0x73, 0x65, 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x21, 0x2e, 0x67, 0x6f, + 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, + 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x42, 0x03, + 0xe0, 0x41, 0x02, 0x52, 0x09, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x12, 0x23, + 0x0a, 0x0d, 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, 0x65, 0x5f, 0x6f, 0x6e, 0x6c, 0x79, 0x18, + 0x02, 0x20, 0x01, 0x28, 0x08, 0x52, 0x0c, 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, 0x65, 0x4f, + 0x6e, 0x6c, 0x79, 0x12, 0x22, 0x0a, 0x0d, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x5f, 0x73, 0x65, + 0x74, 0x5f, 0x69, 0x64, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0b, 0x70, 0x68, 0x72, 0x61, + 0x73, 0x65, 0x53, 0x65, 0x74, 0x49, 0x64, 0x12, 0x3f, 0x0a, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, + 0x74, 0x18, 0x04, 0x20, 0x01, 0x28, 0x09, 0x42, 0x27, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x21, 0x12, + 0x1f, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, + 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, + 0x52, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x22, 0xb9, 0x01, 0x0a, 0x15, 0x4c, 0x69, 0x73, + 0x74, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, + 0x73, 0x74, 0x12, 0x41, 0x0a, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x18, 0x01, 0x20, 0x01, + 0x28, 0x09, 0x42, 0x29, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x23, 0x0a, 0x21, 0x6c, 0x6f, 0x63, 0x61, + 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, + 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x4c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x06, 0x70, + 0x61, 0x72, 0x65, 0x6e, 0x74, 0x12, 0x1b, 0x0a, 0x09, 0x70, 0x61, 0x67, 0x65, 0x5f, 0x73, 0x69, + 0x7a, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x05, 0x52, 0x08, 0x70, 0x61, 0x67, 0x65, 0x53, 0x69, + 0x7a, 0x65, 0x12, 0x1d, 0x0a, 0x0a, 0x70, 0x61, 0x67, 0x65, 0x5f, 0x74, 0x6f, 0x6b, 0x65, 0x6e, + 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x52, 0x09, 0x70, 0x61, 0x67, 0x65, 0x54, 0x6f, 0x6b, 0x65, + 0x6e, 0x12, 0x21, 0x0a, 0x0c, 0x73, 0x68, 0x6f, 0x77, 0x5f, 0x64, 0x65, 0x6c, 0x65, 0x74, 0x65, + 0x64, 0x18, 0x04, 0x20, 0x01, 0x28, 0x08, 0x52, 0x0b, 0x73, 0x68, 0x6f, 0x77, 0x44, 0x65, 0x6c, + 0x65, 0x74, 0x65, 0x64, 0x22, 0x84, 0x01, 0x0a, 0x16, 0x4c, 0x69, 0x73, 0x74, 0x50, 0x68, 0x72, + 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x73, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, + 0x42, 0x0a, 0x0b, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x5f, 0x73, 0x65, 0x74, 0x73, 0x18, 0x01, + 0x20, 0x03, 0x28, 0x0b, 0x32, 0x21, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, + 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x50, 0x68, + 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x52, 0x0a, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, + 0x65, 0x74, 0x73, 0x12, 0x26, 0x0a, 0x0f, 0x6e, 0x65, 0x78, 0x74, 0x5f, 0x70, 0x61, 0x67, 0x65, + 0x5f, 0x74, 0x6f, 0x6b, 0x65, 0x6e, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0d, 0x6e, 0x65, + 0x78, 0x74, 0x50, 0x61, 0x67, 0x65, 0x54, 0x6f, 0x6b, 0x65, 0x6e, 0x22, 0x52, 0x0a, 0x13, 0x47, + 0x65, 0x74, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x52, 0x65, 0x71, 0x75, 0x65, + 0x73, 0x74, 0x12, 0x3b, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, + 0x42, 0x27, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x21, 0x0a, 0x1f, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, - 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x52, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, - 0x74, 0x22, 0xb9, 0x01, 0x0a, 0x15, 0x4c, 0x69, 0x73, 0x74, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, - 0x53, 0x65, 0x74, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x41, 0x0a, 0x06, 0x70, - 0x61, 0x72, 0x65, 0x6e, 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x29, 0xe0, 0x41, 0x02, - 0xfa, 0x41, 0x23, 0x0a, 0x21, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2e, 0x67, - 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x4c, 0x6f, - 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x12, 0x1b, - 0x0a, 0x09, 0x70, 0x61, 0x67, 0x65, 0x5f, 0x73, 0x69, 0x7a, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, - 0x05, 0x52, 0x08, 0x70, 0x61, 0x67, 0x65, 0x53, 0x69, 0x7a, 0x65, 0x12, 0x1d, 0x0a, 0x0a, 0x70, - 0x61, 0x67, 0x65, 0x5f, 0x74, 0x6f, 0x6b, 0x65, 0x6e, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x52, - 0x09, 0x70, 0x61, 0x67, 0x65, 0x54, 0x6f, 0x6b, 0x65, 0x6e, 0x12, 0x21, 0x0a, 0x0c, 0x73, 0x68, - 0x6f, 0x77, 0x5f, 0x64, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x64, 0x18, 0x04, 0x20, 0x01, 0x28, 0x08, - 0x52, 0x0b, 0x73, 0x68, 0x6f, 0x77, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x64, 0x22, 0x84, 0x01, - 0x0a, 0x16, 0x4c, 0x69, 0x73, 0x74, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x73, - 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x42, 0x0a, 0x0b, 0x70, 0x68, 0x72, 0x61, - 0x73, 0x65, 0x5f, 0x73, 0x65, 0x74, 0x73, 0x18, 0x01, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x21, 0x2e, - 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, - 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, - 0x52, 0x0a, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x73, 0x12, 0x26, 0x0a, 0x0f, - 0x6e, 0x65, 0x78, 0x74, 0x5f, 0x70, 0x61, 0x67, 0x65, 0x5f, 0x74, 0x6f, 0x6b, 0x65, 0x6e, 0x18, - 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0d, 0x6e, 0x65, 0x78, 0x74, 0x50, 0x61, 0x67, 0x65, 0x54, - 0x6f, 0x6b, 0x65, 0x6e, 0x22, 0x52, 0x0a, 0x13, 0x47, 0x65, 0x74, 0x50, 0x68, 0x72, 0x61, 0x73, - 0x65, 0x53, 0x65, 0x74, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x3b, 0x0a, 0x04, 0x6e, - 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x27, 0xe0, 0x41, 0x02, 0xfa, 0x41, - 0x21, 0x0a, 0x1f, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, - 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, - 0x65, 0x74, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x22, 0xc1, 0x01, 0x0a, 0x16, 0x55, 0x70, 0x64, - 0x61, 0x74, 0x65, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x52, 0x65, 0x71, 0x75, - 0x65, 0x73, 0x74, 0x12, 0x45, 0x0a, 0x0a, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x5f, 0x73, 0x65, - 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x21, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, - 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, - 0x2e, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, - 0x09, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x12, 0x3b, 0x0a, 0x0b, 0x75, 0x70, - 0x64, 0x61, 0x74, 0x65, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, - 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, - 0x66, 0x2e, 0x46, 0x69, 0x65, 0x6c, 0x64, 0x4d, 0x61, 0x73, 0x6b, 0x52, 0x0a, 0x75, 0x70, 0x64, - 0x61, 0x74, 0x65, 0x4d, 0x61, 0x73, 0x6b, 0x12, 0x23, 0x0a, 0x0d, 0x76, 0x61, 0x6c, 0x69, 0x64, - 0x61, 0x74, 0x65, 0x5f, 0x6f, 0x6e, 0x6c, 0x79, 0x18, 0x04, 0x20, 0x01, 0x28, 0x08, 0x52, 0x0c, - 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, 0x65, 0x4f, 0x6e, 0x6c, 0x79, 0x22, 0xb3, 0x01, 0x0a, - 0x16, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, - 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x3b, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, - 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x27, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x21, 0x0a, 0x1f, 0x73, - 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, - 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x52, 0x04, - 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x23, 0x0a, 0x0d, 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, 0x65, - 0x5f, 0x6f, 0x6e, 0x6c, 0x79, 0x18, 0x02, 0x20, 0x01, 0x28, 0x08, 0x52, 0x0c, 0x76, 0x61, 0x6c, - 0x69, 0x64, 0x61, 0x74, 0x65, 0x4f, 0x6e, 0x6c, 0x79, 0x12, 0x23, 0x0a, 0x0d, 0x61, 0x6c, 0x6c, - 0x6f, 0x77, 0x5f, 0x6d, 0x69, 0x73, 0x73, 0x69, 0x6e, 0x67, 0x18, 0x04, 0x20, 0x01, 0x28, 0x08, - 0x52, 0x0c, 0x61, 0x6c, 0x6c, 0x6f, 0x77, 0x4d, 0x69, 0x73, 0x73, 0x69, 0x6e, 0x67, 0x12, 0x12, - 0x0a, 0x04, 0x65, 0x74, 0x61, 0x67, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x52, 0x04, 0x65, 0x74, - 0x61, 0x67, 0x22, 0x90, 0x01, 0x0a, 0x18, 0x55, 0x6e, 0x64, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x50, - 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, - 0x3b, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x27, 0xe0, - 0x41, 0x02, 0xfa, 0x41, 0x21, 0x0a, 0x1f, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x67, 0x6f, - 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x50, 0x68, 0x72, - 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x23, 0x0a, 0x0d, - 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, 0x65, 0x5f, 0x6f, 0x6e, 0x6c, 0x79, 0x18, 0x03, 0x20, - 0x01, 0x28, 0x08, 0x52, 0x0c, 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, 0x65, 0x4f, 0x6e, 0x6c, - 0x79, 0x12, 0x12, 0x0a, 0x04, 0x65, 0x74, 0x61, 0x67, 0x18, 0x04, 0x20, 0x01, 0x28, 0x09, 0x52, - 0x04, 0x65, 0x74, 0x61, 0x67, 0x32, 0xbf, 0x25, 0x0a, 0x06, 0x53, 0x70, 0x65, 0x65, 0x63, 0x68, - 0x12, 0xec, 0x01, 0x0a, 0x10, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x52, 0x65, 0x63, 0x6f, 0x67, - 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x12, 0x2f, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, - 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x43, - 0x72, 0x65, 0x61, 0x74, 0x65, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x52, - 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, - 0x6c, 0x6f, 0x6e, 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, 0x67, 0x2e, 0x4f, 0x70, 0x65, 0x72, - 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x22, 0x87, 0x01, 0xca, 0x41, 0x1f, 0x0a, 0x0a, 0x52, 0x65, 0x63, - 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x12, 0x11, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, - 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0xda, 0x41, 0x1f, 0x70, 0x61, 0x72, - 0x65, 0x6e, 0x74, 0x2c, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x2c, 0x72, - 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x5f, 0x69, 0x64, 0x82, 0xd3, 0xe4, 0x93, - 0x02, 0x3d, 0x3a, 0x0a, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x22, 0x2f, - 0x2f, 0x76, 0x32, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, - 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, - 0x2f, 0x2a, 0x7d, 0x2f, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x73, 0x12, - 0xb4, 0x01, 0x0a, 0x0f, 0x4c, 0x69, 0x73, 0x74, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, - 0x65, 0x72, 0x73, 0x12, 0x2e, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, - 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x4c, 0x69, 0x73, - 0x74, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x73, 0x52, 0x65, 0x71, 0x75, - 0x65, 0x73, 0x74, 0x1a, 0x2f, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, - 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x4c, 0x69, 0x73, - 0x74, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x73, 0x52, 0x65, 0x73, 0x70, - 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x40, 0xda, 0x41, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x82, - 0xd3, 0xe4, 0x93, 0x02, 0x31, 0x12, 0x2f, 0x2f, 0x76, 0x32, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, + 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x22, + 0xc1, 0x01, 0x0a, 0x16, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, + 0x53, 0x65, 0x74, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x45, 0x0a, 0x0a, 0x70, 0x68, + 0x72, 0x61, 0x73, 0x65, 0x5f, 0x73, 0x65, 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x21, + 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, + 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, + 0x74, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x09, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, + 0x74, 0x12, 0x3b, 0x0a, 0x0b, 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, 0x5f, 0x6d, 0x61, 0x73, 0x6b, + 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, + 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x46, 0x69, 0x65, 0x6c, 0x64, 0x4d, 0x61, + 0x73, 0x6b, 0x52, 0x0a, 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, 0x4d, 0x61, 0x73, 0x6b, 0x12, 0x23, + 0x0a, 0x0d, 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, 0x65, 0x5f, 0x6f, 0x6e, 0x6c, 0x79, 0x18, + 0x04, 0x20, 0x01, 0x28, 0x08, 0x52, 0x0c, 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, 0x65, 0x4f, + 0x6e, 0x6c, 0x79, 0x22, 0xb3, 0x01, 0x0a, 0x16, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x50, 0x68, + 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x3b, + 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x27, 0xe0, 0x41, + 0x02, 0xfa, 0x41, 0x21, 0x0a, 0x1f, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x67, 0x6f, 0x6f, + 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x50, 0x68, 0x72, 0x61, + 0x73, 0x65, 0x53, 0x65, 0x74, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x23, 0x0a, 0x0d, 0x76, + 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, 0x65, 0x5f, 0x6f, 0x6e, 0x6c, 0x79, 0x18, 0x02, 0x20, 0x01, + 0x28, 0x08, 0x52, 0x0c, 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, 0x65, 0x4f, 0x6e, 0x6c, 0x79, + 0x12, 0x23, 0x0a, 0x0d, 0x61, 0x6c, 0x6c, 0x6f, 0x77, 0x5f, 0x6d, 0x69, 0x73, 0x73, 0x69, 0x6e, + 0x67, 0x18, 0x04, 0x20, 0x01, 0x28, 0x08, 0x52, 0x0c, 0x61, 0x6c, 0x6c, 0x6f, 0x77, 0x4d, 0x69, + 0x73, 0x73, 0x69, 0x6e, 0x67, 0x12, 0x12, 0x0a, 0x04, 0x65, 0x74, 0x61, 0x67, 0x18, 0x03, 0x20, + 0x01, 0x28, 0x09, 0x52, 0x04, 0x65, 0x74, 0x61, 0x67, 0x22, 0x90, 0x01, 0x0a, 0x18, 0x55, 0x6e, + 0x64, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x52, + 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x3b, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, + 0x20, 0x01, 0x28, 0x09, 0x42, 0x27, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x21, 0x0a, 0x1f, 0x73, 0x70, + 0x65, 0x65, 0x63, 0x68, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, + 0x63, 0x6f, 0x6d, 0x2f, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x52, 0x04, 0x6e, + 0x61, 0x6d, 0x65, 0x12, 0x23, 0x0a, 0x0d, 0x76, 0x61, 0x6c, 0x69, 0x64, 0x61, 0x74, 0x65, 0x5f, + 0x6f, 0x6e, 0x6c, 0x79, 0x18, 0x03, 0x20, 0x01, 0x28, 0x08, 0x52, 0x0c, 0x76, 0x61, 0x6c, 0x69, + 0x64, 0x61, 0x74, 0x65, 0x4f, 0x6e, 0x6c, 0x79, 0x12, 0x12, 0x0a, 0x04, 0x65, 0x74, 0x61, 0x67, + 0x18, 0x04, 0x20, 0x01, 0x28, 0x09, 0x52, 0x04, 0x65, 0x74, 0x61, 0x67, 0x32, 0xbf, 0x25, 0x0a, + 0x06, 0x53, 0x70, 0x65, 0x65, 0x63, 0x68, 0x12, 0xec, 0x01, 0x0a, 0x10, 0x43, 0x72, 0x65, 0x61, + 0x74, 0x65, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x12, 0x2f, 0x2e, 0x67, + 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, + 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x52, 0x65, 0x63, 0x6f, + 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, + 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x6c, 0x6f, 0x6e, 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, + 0x6e, 0x67, 0x2e, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x22, 0x87, 0x01, 0xca, + 0x41, 0x1f, 0x0a, 0x0a, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x12, 0x11, + 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, + 0x61, 0xda, 0x41, 0x1f, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x2c, 0x72, 0x65, 0x63, 0x6f, 0x67, + 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x2c, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, + 0x5f, 0x69, 0x64, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x3d, 0x3a, 0x0a, 0x72, 0x65, 0x63, 0x6f, 0x67, + 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x22, 0x2f, 0x2f, 0x76, 0x32, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x72, 0x65, 0x63, 0x6f, 0x67, - 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x73, 0x12, 0xa1, 0x01, 0x0a, 0x0d, 0x47, 0x65, 0x74, 0x52, 0x65, - 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x12, 0x2c, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, - 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, - 0x32, 0x2e, 0x47, 0x65, 0x74, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x52, - 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x22, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, + 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x73, 0x12, 0xb4, 0x01, 0x0a, 0x0f, 0x4c, 0x69, 0x73, 0x74, 0x52, + 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x73, 0x12, 0x2e, 0x2e, 0x67, 0x6f, 0x6f, + 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, + 0x2e, 0x76, 0x32, 0x2e, 0x4c, 0x69, 0x73, 0x74, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, + 0x65, 0x72, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x2f, 0x2e, 0x67, 0x6f, 0x6f, + 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, + 0x2e, 0x76, 0x32, 0x2e, 0x4c, 0x69, 0x73, 0x74, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, + 0x65, 0x72, 0x73, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x40, 0xda, 0x41, 0x06, + 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x31, 0x12, 0x2f, 0x2f, 0x76, + 0x32, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, + 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, + 0x7d, 0x2f, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x73, 0x12, 0xa1, 0x01, + 0x0a, 0x0d, 0x47, 0x65, 0x74, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x12, + 0x2c, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, + 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x47, 0x65, 0x74, 0x52, 0x65, 0x63, 0x6f, + 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x22, 0x2e, + 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, + 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, + 0x72, 0x22, 0x3e, 0xda, 0x41, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x31, + 0x12, 0x2f, 0x2f, 0x76, 0x32, 0x2f, 0x7b, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, + 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, + 0x2f, 0x2a, 0x2f, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x73, 0x2f, 0x2a, + 0x7d, 0x12, 0xee, 0x01, 0x0a, 0x10, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x52, 0x65, 0x63, 0x6f, + 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x12, 0x2f, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, - 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x22, 0x3e, 0xda, 0x41, 0x04, 0x6e, - 0x61, 0x6d, 0x65, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x31, 0x12, 0x2f, 0x2f, 0x76, 0x32, 0x2f, 0x7b, - 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, - 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x72, 0x65, 0x63, 0x6f, - 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x73, 0x2f, 0x2a, 0x7d, 0x12, 0xee, 0x01, 0x0a, 0x10, 0x55, - 0x70, 0x64, 0x61, 0x74, 0x65, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x12, - 0x2f, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, - 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x52, - 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, - 0x1a, 0x1d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x6c, 0x6f, 0x6e, 0x67, 0x72, 0x75, - 0x6e, 0x6e, 0x69, 0x6e, 0x67, 0x2e, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x22, - 0x89, 0x01, 0xca, 0x41, 0x1f, 0x0a, 0x0a, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, - 0x72, 0x12, 0x11, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, - 0x64, 0x61, 0x74, 0x61, 0xda, 0x41, 0x16, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, - 0x72, 0x2c, 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x82, 0xd3, 0xe4, - 0x93, 0x02, 0x48, 0x3a, 0x0a, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x32, - 0x3a, 0x2f, 0x76, 0x32, 0x2f, 0x7b, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, - 0x2e, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, - 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x72, 0x65, 0x63, - 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x73, 0x2f, 0x2a, 0x7d, 0x12, 0xc4, 0x01, 0x0a, 0x10, - 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, - 0x12, 0x2f, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, - 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, - 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, - 0x74, 0x1a, 0x1d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x6c, 0x6f, 0x6e, 0x67, 0x72, - 0x75, 0x6e, 0x6e, 0x69, 0x6e, 0x67, 0x2e, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, - 0x22, 0x60, 0xca, 0x41, 0x1f, 0x0a, 0x0a, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, - 0x72, 0x12, 0x11, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, - 0x64, 0x61, 0x74, 0x61, 0xda, 0x41, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x82, 0xd3, 0xe4, 0x93, 0x02, - 0x31, 0x2a, 0x2f, 0x2f, 0x76, 0x32, 0x2f, 0x7b, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, + 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, + 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, + 0x2e, 0x6c, 0x6f, 0x6e, 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, 0x67, 0x2e, 0x4f, 0x70, 0x65, + 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x22, 0x89, 0x01, 0xca, 0x41, 0x1f, 0x0a, 0x0a, 0x52, 0x65, + 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x12, 0x11, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, + 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0xda, 0x41, 0x16, 0x72, 0x65, + 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x2c, 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, 0x5f, + 0x6d, 0x61, 0x73, 0x6b, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x48, 0x3a, 0x0a, 0x72, 0x65, 0x63, 0x6f, + 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x32, 0x3a, 0x2f, 0x76, 0x32, 0x2f, 0x7b, 0x72, 0x65, 0x63, + 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x2e, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x73, 0x2f, - 0x2a, 0x7d, 0x12, 0xd4, 0x01, 0x0a, 0x12, 0x55, 0x6e, 0x64, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x52, - 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x12, 0x31, 0x2e, 0x67, 0x6f, 0x6f, 0x67, - 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, - 0x76, 0x32, 0x2e, 0x55, 0x6e, 0x64, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x52, 0x65, 0x63, 0x6f, 0x67, - 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x67, - 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x6c, 0x6f, 0x6e, 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, - 0x67, 0x2e, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x22, 0x6c, 0xca, 0x41, 0x1f, - 0x0a, 0x0a, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x12, 0x11, 0x4f, 0x70, - 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0xda, - 0x41, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x3d, 0x3a, 0x01, 0x2a, 0x22, - 0x38, 0x2f, 0x76, 0x32, 0x2f, 0x7b, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, - 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, - 0x2a, 0x2f, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x73, 0x2f, 0x2a, 0x7d, - 0x3a, 0x75, 0x6e, 0x64, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x12, 0xf9, 0x01, 0x0a, 0x09, 0x52, 0x65, - 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x12, 0x28, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, + 0x2a, 0x7d, 0x12, 0xc4, 0x01, 0x0a, 0x10, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x52, 0x65, 0x63, + 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x12, 0x2f, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, - 0x2e, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, - 0x74, 0x1a, 0x29, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, - 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x52, 0x65, 0x63, 0x6f, 0x67, - 0x6e, 0x69, 0x7a, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x96, 0x01, 0xda, - 0x41, 0x25, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x2c, 0x63, 0x6f, 0x6e, - 0x66, 0x69, 0x67, 0x2c, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x2c, - 0x63, 0x6f, 0x6e, 0x74, 0x65, 0x6e, 0x74, 0xda, 0x41, 0x21, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, - 0x69, 0x7a, 0x65, 0x72, 0x2c, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x2c, 0x63, 0x6f, 0x6e, 0x66, - 0x69, 0x67, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x2c, 0x75, 0x72, 0x69, 0x82, 0xd3, 0xe4, 0x93, 0x02, - 0x44, 0x3a, 0x01, 0x2a, 0x22, 0x3f, 0x2f, 0x76, 0x32, 0x2f, 0x7b, 0x72, 0x65, 0x63, 0x6f, 0x67, - 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, - 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x72, 0x65, 0x63, - 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x73, 0x2f, 0x2a, 0x7d, 0x3a, 0x72, 0x65, 0x63, 0x6f, - 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x12, 0x81, 0x01, 0x0a, 0x12, 0x53, 0x74, 0x72, 0x65, 0x61, 0x6d, - 0x69, 0x6e, 0x67, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x12, 0x31, 0x2e, 0x67, - 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, - 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x53, 0x74, 0x72, 0x65, 0x61, 0x6d, 0x69, 0x6e, 0x67, 0x52, - 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, - 0x32, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, - 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x53, 0x74, 0x72, 0x65, 0x61, 0x6d, 0x69, - 0x6e, 0x67, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, - 0x6e, 0x73, 0x65, 0x22, 0x00, 0x28, 0x01, 0x30, 0x01, 0x12, 0x84, 0x02, 0x0a, 0x0e, 0x42, 0x61, - 0x74, 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x12, 0x2d, 0x2e, 0x67, - 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, - 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x42, 0x61, 0x74, 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, - 0x6e, 0x69, 0x7a, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x67, 0x6f, - 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x6c, 0x6f, 0x6e, 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, 0x67, - 0x2e, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x22, 0xa3, 0x01, 0xca, 0x41, 0x2b, - 0x0a, 0x16, 0x42, 0x61, 0x74, 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, - 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x11, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, - 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0xda, 0x41, 0x23, 0x72, 0x65, - 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x2c, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x2c, - 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x2c, 0x66, 0x69, 0x6c, 0x65, - 0x73, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x49, 0x3a, 0x01, 0x2a, 0x22, 0x44, 0x2f, 0x76, 0x32, 0x2f, - 0x7b, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x3d, 0x70, 0x72, 0x6f, 0x6a, - 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, - 0x2f, 0x2a, 0x2f, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x73, 0x2f, 0x2a, - 0x7d, 0x3a, 0x62, 0x61, 0x74, 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, - 0x12, 0x8e, 0x01, 0x0a, 0x09, 0x47, 0x65, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x28, + 0x2e, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, + 0x72, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, + 0x65, 0x2e, 0x6c, 0x6f, 0x6e, 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, 0x67, 0x2e, 0x4f, 0x70, + 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x22, 0x60, 0xca, 0x41, 0x1f, 0x0a, 0x0a, 0x52, 0x65, + 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x12, 0x11, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, + 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0xda, 0x41, 0x04, 0x6e, 0x61, + 0x6d, 0x65, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x31, 0x2a, 0x2f, 0x2f, 0x76, 0x32, 0x2f, 0x7b, 0x6e, + 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, + 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x72, 0x65, 0x63, 0x6f, 0x67, + 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x73, 0x2f, 0x2a, 0x7d, 0x12, 0xd4, 0x01, 0x0a, 0x12, 0x55, 0x6e, + 0x64, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, + 0x12, 0x31, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, + 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x55, 0x6e, 0x64, 0x65, 0x6c, 0x65, + 0x74, 0x65, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x52, 0x65, 0x71, 0x75, + 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x6c, 0x6f, 0x6e, + 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, 0x67, 0x2e, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, + 0x6f, 0x6e, 0x22, 0x6c, 0xca, 0x41, 0x1f, 0x0a, 0x0a, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, + 0x7a, 0x65, 0x72, 0x12, 0x11, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, + 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0xda, 0x41, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x82, 0xd3, 0xe4, + 0x93, 0x02, 0x3d, 0x3a, 0x01, 0x2a, 0x22, 0x38, 0x2f, 0x76, 0x32, 0x2f, 0x7b, 0x6e, 0x61, 0x6d, + 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, + 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, + 0x7a, 0x65, 0x72, 0x73, 0x2f, 0x2a, 0x7d, 0x3a, 0x75, 0x6e, 0x64, 0x65, 0x6c, 0x65, 0x74, 0x65, + 0x12, 0xf9, 0x01, 0x0a, 0x09, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x12, 0x28, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, - 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x47, 0x65, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, - 0x67, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1e, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, + 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, + 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x29, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, - 0x32, 0x2e, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x22, 0x37, 0xda, 0x41, 0x04, 0x6e, 0x61, 0x6d, - 0x65, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x2a, 0x12, 0x28, 0x2f, 0x76, 0x32, 0x2f, 0x7b, 0x6e, 0x61, - 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, - 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, - 0x7d, 0x12, 0xb1, 0x01, 0x0a, 0x0c, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x43, 0x6f, 0x6e, 0x66, - 0x69, 0x67, 0x12, 0x2b, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, - 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x55, 0x70, 0x64, 0x61, - 0x74, 0x65, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, + 0x32, 0x2e, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, + 0x6e, 0x73, 0x65, 0x22, 0x96, 0x01, 0xda, 0x41, 0x25, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, + 0x7a, 0x65, 0x72, 0x2c, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x2c, 0x63, 0x6f, 0x6e, 0x66, 0x69, + 0x67, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x2c, 0x63, 0x6f, 0x6e, 0x74, 0x65, 0x6e, 0x74, 0xda, 0x41, + 0x21, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x2c, 0x63, 0x6f, 0x6e, 0x66, + 0x69, 0x67, 0x2c, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x2c, 0x75, + 0x72, 0x69, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x44, 0x3a, 0x01, 0x2a, 0x22, 0x3f, 0x2f, 0x76, 0x32, + 0x2f, 0x7b, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x3d, 0x70, 0x72, 0x6f, + 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, + 0x73, 0x2f, 0x2a, 0x2f, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x73, 0x2f, + 0x2a, 0x7d, 0x3a, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x12, 0x81, 0x01, 0x0a, + 0x12, 0x53, 0x74, 0x72, 0x65, 0x61, 0x6d, 0x69, 0x6e, 0x67, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, + 0x69, 0x7a, 0x65, 0x12, 0x31, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, + 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x53, 0x74, 0x72, + 0x65, 0x61, 0x6d, 0x69, 0x6e, 0x67, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x52, + 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x32, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, + 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, + 0x53, 0x74, 0x72, 0x65, 0x61, 0x6d, 0x69, 0x6e, 0x67, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, + 0x7a, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, 0x28, 0x01, 0x30, 0x01, + 0x12, 0x84, 0x02, 0x0a, 0x0e, 0x42, 0x61, 0x74, 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, + 0x69, 0x7a, 0x65, 0x12, 0x2d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, + 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x42, 0x61, 0x74, + 0x63, 0x68, 0x52, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, + 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x6c, 0x6f, 0x6e, 0x67, + 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, 0x67, 0x2e, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, + 0x6e, 0x22, 0xa3, 0x01, 0xca, 0x41, 0x2b, 0x0a, 0x16, 0x42, 0x61, 0x74, 0x63, 0x68, 0x52, 0x65, + 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, + 0x11, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, + 0x74, 0x61, 0xda, 0x41, 0x23, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x72, 0x2c, + 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x2c, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x5f, 0x6d, 0x61, + 0x73, 0x6b, 0x2c, 0x66, 0x69, 0x6c, 0x65, 0x73, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x49, 0x3a, 0x01, + 0x2a, 0x22, 0x44, 0x2f, 0x76, 0x32, 0x2f, 0x7b, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, + 0x65, 0x72, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, + 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x72, 0x65, 0x63, 0x6f, 0x67, 0x6e, + 0x69, 0x7a, 0x65, 0x72, 0x73, 0x2f, 0x2a, 0x7d, 0x3a, 0x62, 0x61, 0x74, 0x63, 0x68, 0x52, 0x65, + 0x63, 0x6f, 0x67, 0x6e, 0x69, 0x7a, 0x65, 0x12, 0x8e, 0x01, 0x0a, 0x09, 0x47, 0x65, 0x74, 0x43, + 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x28, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, + 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x47, + 0x65, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1e, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x22, - 0x54, 0xda, 0x41, 0x12, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x2c, 0x75, 0x70, 0x64, 0x61, 0x74, - 0x65, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x39, 0x3a, 0x06, 0x63, 0x6f, - 0x6e, 0x66, 0x69, 0x67, 0x32, 0x2f, 0x2f, 0x76, 0x32, 0x2f, 0x7b, 0x63, 0x6f, 0x6e, 0x66, 0x69, - 0x67, 0x2e, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, - 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x63, 0x6f, - 0x6e, 0x66, 0x69, 0x67, 0x7d, 0x12, 0xf7, 0x01, 0x0a, 0x11, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, - 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x12, 0x30, 0x2e, 0x67, 0x6f, - 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, - 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x43, 0x75, 0x73, 0x74, 0x6f, - 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, - 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x6c, 0x6f, 0x6e, 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, - 0x6e, 0x67, 0x2e, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x22, 0x90, 0x01, 0xca, - 0x41, 0x20, 0x0a, 0x0b, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x12, - 0x11, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, - 0x74, 0x61, 0xda, 0x41, 0x23, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x2c, 0x63, 0x75, 0x73, 0x74, - 0x6f, 0x6d, 0x5f, 0x63, 0x6c, 0x61, 0x73, 0x73, 0x2c, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x5f, - 0x63, 0x6c, 0x61, 0x73, 0x73, 0x5f, 0x69, 0x64, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x41, 0x3a, 0x0c, - 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x5f, 0x63, 0x6c, 0x61, 0x73, 0x73, 0x22, 0x31, 0x2f, 0x76, - 0x32, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, + 0x37, 0xda, 0x41, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x2a, 0x12, 0x28, + 0x2f, 0x76, 0x32, 0x2f, 0x7b, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, - 0x7d, 0x2f, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x65, 0x73, 0x12, - 0xbc, 0x01, 0x0a, 0x11, 0x4c, 0x69, 0x73, 0x74, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, - 0x61, 0x73, 0x73, 0x65, 0x73, 0x12, 0x30, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, - 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x4c, - 0x69, 0x73, 0x74, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x65, 0x73, - 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x31, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, - 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, - 0x2e, 0x4c, 0x69, 0x73, 0x74, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, - 0x65, 0x73, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x42, 0xda, 0x41, 0x06, 0x70, - 0x61, 0x72, 0x65, 0x6e, 0x74, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x33, 0x12, 0x31, 0x2f, 0x76, 0x32, - 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, - 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x7d, - 0x2f, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x65, 0x73, 0x12, 0xa6, - 0x01, 0x0a, 0x0e, 0x47, 0x65, 0x74, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, - 0x73, 0x12, 0x2d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, - 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x47, 0x65, 0x74, 0x43, 0x75, - 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, - 0x1a, 0x23, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, - 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, - 0x43, 0x6c, 0x61, 0x73, 0x73, 0x22, 0x40, 0xda, 0x41, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x82, 0xd3, - 0xe4, 0x93, 0x02, 0x33, 0x12, 0x31, 0x2f, 0x76, 0x32, 0x2f, 0x7b, 0x6e, 0x61, 0x6d, 0x65, 0x3d, - 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, - 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, - 0x73, 0x73, 0x65, 0x73, 0x2f, 0x2a, 0x7d, 0x12, 0xf9, 0x01, 0x0a, 0x11, 0x55, 0x70, 0x64, 0x61, - 0x74, 0x65, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x12, 0x30, 0x2e, - 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, - 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x43, 0x75, 0x73, - 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, - 0x1d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x6c, 0x6f, 0x6e, 0x67, 0x72, 0x75, 0x6e, - 0x6e, 0x69, 0x6e, 0x67, 0x2e, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x22, 0x92, - 0x01, 0xca, 0x41, 0x20, 0x0a, 0x0b, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, - 0x73, 0x12, 0x11, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, - 0x64, 0x61, 0x74, 0x61, 0xda, 0x41, 0x18, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x5f, 0x63, 0x6c, - 0x61, 0x73, 0x73, 0x2c, 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x82, - 0xd3, 0xe4, 0x93, 0x02, 0x4e, 0x3a, 0x0c, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x5f, 0x63, 0x6c, - 0x61, 0x73, 0x73, 0x32, 0x3e, 0x2f, 0x76, 0x32, 0x2f, 0x7b, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, - 0x5f, 0x63, 0x6c, 0x61, 0x73, 0x73, 0x2e, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, - 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, - 0x2f, 0x2a, 0x2f, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x65, 0x73, - 0x2f, 0x2a, 0x7d, 0x12, 0xc9, 0x01, 0x0a, 0x11, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x43, 0x75, - 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x12, 0x30, 0x2e, 0x67, 0x6f, 0x6f, 0x67, - 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, - 0x76, 0x32, 0x2e, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, - 0x6c, 0x61, 0x73, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x67, 0x6f, - 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x6c, 0x6f, 0x6e, 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, 0x67, - 0x2e, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x22, 0x63, 0xca, 0x41, 0x20, 0x0a, - 0x0b, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x12, 0x11, 0x4f, 0x70, - 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0xda, - 0x41, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x33, 0x2a, 0x31, 0x2f, 0x76, - 0x32, 0x2f, 0x7b, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, - 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x63, - 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x65, 0x73, 0x2f, 0x2a, 0x7d, 0x12, - 0xd9, 0x01, 0x0a, 0x13, 0x55, 0x6e, 0x64, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x43, 0x75, 0x73, 0x74, - 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x12, 0x32, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, - 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, - 0x2e, 0x55, 0x6e, 0x64, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, - 0x6c, 0x61, 0x73, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x67, 0x6f, - 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x6c, 0x6f, 0x6e, 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, 0x67, - 0x2e, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x22, 0x6f, 0xca, 0x41, 0x20, 0x0a, - 0x0b, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x12, 0x11, 0x4f, 0x70, - 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0xda, - 0x41, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x3f, 0x3a, 0x01, 0x2a, 0x22, - 0x3a, 0x2f, 0x76, 0x32, 0x2f, 0x7b, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, - 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, - 0x2a, 0x2f, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x65, 0x73, 0x2f, - 0x2a, 0x7d, 0x3a, 0x75, 0x6e, 0x64, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x12, 0xe8, 0x01, 0x0a, 0x0f, - 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x12, - 0x2e, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, - 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x50, - 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, - 0x1d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x6c, 0x6f, 0x6e, 0x67, 0x72, 0x75, 0x6e, - 0x6e, 0x69, 0x6e, 0x67, 0x2e, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x22, 0x85, - 0x01, 0xca, 0x41, 0x1e, 0x0a, 0x09, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x12, - 0x11, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, - 0x74, 0x61, 0xda, 0x41, 0x1f, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x2c, 0x70, 0x68, 0x72, 0x61, - 0x73, 0x65, 0x5f, 0x73, 0x65, 0x74, 0x2c, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x5f, 0x73, 0x65, - 0x74, 0x5f, 0x69, 0x64, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x3c, 0x3a, 0x0a, 0x70, 0x68, 0x72, 0x61, - 0x73, 0x65, 0x5f, 0x73, 0x65, 0x74, 0x22, 0x2e, 0x2f, 0x76, 0x32, 0x2f, 0x7b, 0x70, 0x61, 0x72, - 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, - 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x70, 0x68, 0x72, 0x61, - 0x73, 0x65, 0x53, 0x65, 0x74, 0x73, 0x12, 0xb0, 0x01, 0x0a, 0x0e, 0x4c, 0x69, 0x73, 0x74, 0x50, - 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x73, 0x12, 0x2d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, + 0x2f, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x7d, 0x12, 0xb1, 0x01, 0x0a, 0x0c, 0x55, 0x70, 0x64, + 0x61, 0x74, 0x65, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x2b, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, - 0x76, 0x32, 0x2e, 0x4c, 0x69, 0x73, 0x74, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, - 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x2e, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, + 0x76, 0x32, 0x2e, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x52, + 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1e, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, + 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, + 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x22, 0x54, 0xda, 0x41, 0x12, 0x63, 0x6f, 0x6e, 0x66, 0x69, + 0x67, 0x2c, 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x82, 0xd3, 0xe4, + 0x93, 0x02, 0x39, 0x3a, 0x06, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x32, 0x2f, 0x2f, 0x76, 0x32, + 0x2f, 0x7b, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x2e, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, + 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, + 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x7d, 0x12, 0xf7, 0x01, 0x0a, + 0x11, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, + 0x73, 0x73, 0x12, 0x30, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, + 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x43, 0x72, 0x65, 0x61, + 0x74, 0x65, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x52, 0x65, 0x71, + 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x6c, 0x6f, + 0x6e, 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, 0x67, 0x2e, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, + 0x69, 0x6f, 0x6e, 0x22, 0x90, 0x01, 0xca, 0x41, 0x20, 0x0a, 0x0b, 0x43, 0x75, 0x73, 0x74, 0x6f, + 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x12, 0x11, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, + 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0xda, 0x41, 0x23, 0x70, 0x61, 0x72, 0x65, + 0x6e, 0x74, 0x2c, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x5f, 0x63, 0x6c, 0x61, 0x73, 0x73, 0x2c, + 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x5f, 0x63, 0x6c, 0x61, 0x73, 0x73, 0x5f, 0x69, 0x64, 0x82, + 0xd3, 0xe4, 0x93, 0x02, 0x41, 0x3a, 0x0c, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x5f, 0x63, 0x6c, + 0x61, 0x73, 0x73, 0x22, 0x31, 0x2f, 0x76, 0x32, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, + 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, + 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, + 0x6c, 0x61, 0x73, 0x73, 0x65, 0x73, 0x12, 0xbc, 0x01, 0x0a, 0x11, 0x4c, 0x69, 0x73, 0x74, 0x43, + 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x65, 0x73, 0x12, 0x30, 0x2e, 0x67, + 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, + 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x4c, 0x69, 0x73, 0x74, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, + 0x43, 0x6c, 0x61, 0x73, 0x73, 0x65, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x31, + 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, + 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x4c, 0x69, 0x73, 0x74, 0x43, 0x75, 0x73, 0x74, + 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x65, 0x73, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, + 0x65, 0x22, 0x42, 0xda, 0x41, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x82, 0xd3, 0xe4, 0x93, + 0x02, 0x33, 0x12, 0x31, 0x2f, 0x76, 0x32, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, + 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, + 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, + 0x61, 0x73, 0x73, 0x65, 0x73, 0x12, 0xa6, 0x01, 0x0a, 0x0e, 0x47, 0x65, 0x74, 0x43, 0x75, 0x73, + 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x12, 0x2d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, - 0x32, 0x2e, 0x4c, 0x69, 0x73, 0x74, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x73, - 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x3f, 0xda, 0x41, 0x06, 0x70, 0x61, 0x72, - 0x65, 0x6e, 0x74, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x30, 0x12, 0x2e, 0x2f, 0x76, 0x32, 0x2f, 0x7b, - 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, - 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x70, - 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x73, 0x12, 0x9d, 0x01, 0x0a, 0x0c, 0x47, 0x65, - 0x74, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x12, 0x2b, 0x2e, 0x67, 0x6f, 0x6f, - 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, - 0x2e, 0x76, 0x32, 0x2e, 0x47, 0x65, 0x74, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, - 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x21, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, + 0x32, 0x2e, 0x47, 0x65, 0x74, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, + 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x23, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, - 0x2e, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x22, 0x3d, 0xda, 0x41, 0x04, 0x6e, - 0x61, 0x6d, 0x65, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x30, 0x12, 0x2e, 0x2f, 0x76, 0x32, 0x2f, 0x7b, - 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, - 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x70, 0x68, 0x72, 0x61, - 0x73, 0x65, 0x53, 0x65, 0x74, 0x73, 0x2f, 0x2a, 0x7d, 0x12, 0xea, 0x01, 0x0a, 0x0f, 0x55, 0x70, - 0x64, 0x61, 0x74, 0x65, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x12, 0x2e, 0x2e, - 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, - 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x50, 0x68, 0x72, - 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, - 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x6c, 0x6f, 0x6e, 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, - 0x6e, 0x67, 0x2e, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x22, 0x87, 0x01, 0xca, - 0x41, 0x1e, 0x0a, 0x09, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x12, 0x11, 0x4f, - 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, - 0xda, 0x41, 0x16, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x5f, 0x73, 0x65, 0x74, 0x2c, 0x75, 0x70, - 0x64, 0x61, 0x74, 0x65, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x47, 0x3a, - 0x0a, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x5f, 0x73, 0x65, 0x74, 0x32, 0x39, 0x2f, 0x76, 0x32, - 0x2f, 0x7b, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x5f, 0x73, 0x65, 0x74, 0x2e, 0x6e, 0x61, 0x6d, + 0x2e, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x22, 0x40, 0xda, 0x41, + 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x33, 0x12, 0x31, 0x2f, 0x76, 0x32, + 0x2f, 0x7b, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, + 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x63, 0x75, + 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x65, 0x73, 0x2f, 0x2a, 0x7d, 0x12, 0xf9, + 0x01, 0x0a, 0x11, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, + 0x6c, 0x61, 0x73, 0x73, 0x12, 0x30, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, + 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x55, 0x70, + 0x64, 0x61, 0x74, 0x65, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x52, + 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, + 0x6c, 0x6f, 0x6e, 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, 0x67, 0x2e, 0x4f, 0x70, 0x65, 0x72, + 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x22, 0x92, 0x01, 0xca, 0x41, 0x20, 0x0a, 0x0b, 0x43, 0x75, 0x73, + 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x12, 0x11, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, + 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0xda, 0x41, 0x18, 0x63, 0x75, + 0x73, 0x74, 0x6f, 0x6d, 0x5f, 0x63, 0x6c, 0x61, 0x73, 0x73, 0x2c, 0x75, 0x70, 0x64, 0x61, 0x74, + 0x65, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x4e, 0x3a, 0x0c, 0x63, 0x75, + 0x73, 0x74, 0x6f, 0x6d, 0x5f, 0x63, 0x6c, 0x61, 0x73, 0x73, 0x32, 0x3e, 0x2f, 0x76, 0x32, 0x2f, + 0x7b, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x5f, 0x63, 0x6c, 0x61, 0x73, 0x73, 0x2e, 0x6e, 0x61, + 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, + 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, + 0x43, 0x6c, 0x61, 0x73, 0x73, 0x65, 0x73, 0x2f, 0x2a, 0x7d, 0x12, 0xc9, 0x01, 0x0a, 0x11, 0x44, + 0x65, 0x6c, 0x65, 0x74, 0x65, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, + 0x12, 0x30, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, + 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, + 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, + 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x6c, 0x6f, 0x6e, 0x67, + 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, 0x67, 0x2e, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, + 0x6e, 0x22, 0x63, 0xca, 0x41, 0x20, 0x0a, 0x0b, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, + 0x61, 0x73, 0x73, 0x12, 0x11, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, + 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0xda, 0x41, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x82, 0xd3, 0xe4, + 0x93, 0x02, 0x33, 0x2a, 0x31, 0x2f, 0x76, 0x32, 0x2f, 0x7b, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, + 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, + 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, + 0x73, 0x65, 0x73, 0x2f, 0x2a, 0x7d, 0x12, 0xd9, 0x01, 0x0a, 0x13, 0x55, 0x6e, 0x64, 0x65, 0x6c, + 0x65, 0x74, 0x65, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x12, 0x32, + 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, + 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x55, 0x6e, 0x64, 0x65, 0x6c, 0x65, 0x74, 0x65, + 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, 0x61, 0x73, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, + 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x6c, 0x6f, 0x6e, 0x67, + 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, 0x67, 0x2e, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, + 0x6e, 0x22, 0x6f, 0xca, 0x41, 0x20, 0x0a, 0x0b, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, 0x6c, + 0x61, 0x73, 0x73, 0x12, 0x11, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, + 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0xda, 0x41, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x82, 0xd3, 0xe4, + 0x93, 0x02, 0x3f, 0x3a, 0x01, 0x2a, 0x22, 0x3a, 0x2f, 0x76, 0x32, 0x2f, 0x7b, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, - 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, - 0x65, 0x74, 0x73, 0x2f, 0x2a, 0x7d, 0x12, 0xc0, 0x01, 0x0a, 0x0f, 0x44, 0x65, 0x6c, 0x65, 0x74, - 0x65, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x12, 0x2e, 0x2e, 0x67, 0x6f, 0x6f, - 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, - 0x2e, 0x76, 0x32, 0x2e, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, - 0x53, 0x65, 0x74, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x67, 0x6f, 0x6f, - 0x67, 0x6c, 0x65, 0x2e, 0x6c, 0x6f, 0x6e, 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, 0x67, 0x2e, - 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x22, 0x5e, 0xca, 0x41, 0x1e, 0x0a, 0x09, - 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x12, 0x11, 0x4f, 0x70, 0x65, 0x72, 0x61, - 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0xda, 0x41, 0x04, 0x6e, - 0x61, 0x6d, 0x65, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x30, 0x2a, 0x2e, 0x2f, 0x76, 0x32, 0x2f, 0x7b, - 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, - 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x70, 0x68, 0x72, 0x61, - 0x73, 0x65, 0x53, 0x65, 0x74, 0x73, 0x2f, 0x2a, 0x7d, 0x12, 0xd0, 0x01, 0x0a, 0x11, 0x55, 0x6e, - 0x64, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x12, - 0x30, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, - 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x55, 0x6e, 0x64, 0x65, 0x6c, 0x65, 0x74, + 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x63, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x43, + 0x6c, 0x61, 0x73, 0x73, 0x65, 0x73, 0x2f, 0x2a, 0x7d, 0x3a, 0x75, 0x6e, 0x64, 0x65, 0x6c, 0x65, + 0x74, 0x65, 0x12, 0xe8, 0x01, 0x0a, 0x0f, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x50, 0x68, 0x72, + 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x12, 0x2e, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, + 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, + 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x52, + 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, + 0x6c, 0x6f, 0x6e, 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, 0x67, 0x2e, 0x4f, 0x70, 0x65, 0x72, + 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x22, 0x85, 0x01, 0xca, 0x41, 0x1e, 0x0a, 0x09, 0x50, 0x68, 0x72, + 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x12, 0x11, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, + 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0xda, 0x41, 0x1f, 0x70, 0x61, 0x72, 0x65, + 0x6e, 0x74, 0x2c, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x5f, 0x73, 0x65, 0x74, 0x2c, 0x70, 0x68, + 0x72, 0x61, 0x73, 0x65, 0x5f, 0x73, 0x65, 0x74, 0x5f, 0x69, 0x64, 0x82, 0xd3, 0xe4, 0x93, 0x02, + 0x3c, 0x3a, 0x0a, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x5f, 0x73, 0x65, 0x74, 0x22, 0x2e, 0x2f, + 0x76, 0x32, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, + 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, + 0x2a, 0x7d, 0x2f, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x73, 0x12, 0xb0, 0x01, + 0x0a, 0x0e, 0x4c, 0x69, 0x73, 0x74, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x73, + 0x12, 0x2d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, + 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x4c, 0x69, 0x73, 0x74, 0x50, 0x68, + 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, + 0x2e, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, + 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x4c, 0x69, 0x73, 0x74, 0x50, 0x68, 0x72, + 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x73, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, + 0x3f, 0xda, 0x41, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x30, + 0x12, 0x2e, 0x2f, 0x76, 0x32, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, + 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, + 0x6e, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x73, + 0x12, 0x9d, 0x01, 0x0a, 0x0c, 0x47, 0x65, 0x74, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, + 0x74, 0x12, 0x2b, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, + 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x47, 0x65, 0x74, 0x50, 0x68, + 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x21, + 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, + 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, + 0x74, 0x22, 0x3d, 0xda, 0x41, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x30, + 0x12, 0x2e, 0x2f, 0x76, 0x32, 0x2f, 0x7b, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, + 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, + 0x2f, 0x2a, 0x2f, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x73, 0x2f, 0x2a, 0x7d, + 0x12, 0xea, 0x01, 0x0a, 0x0f, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x50, 0x68, 0x72, 0x61, 0x73, + 0x65, 0x53, 0x65, 0x74, 0x12, 0x2e, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, + 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x55, 0x70, + 0x64, 0x61, 0x74, 0x65, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x52, 0x65, 0x71, + 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x6c, 0x6f, + 0x6e, 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, 0x67, 0x2e, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, + 0x69, 0x6f, 0x6e, 0x22, 0x87, 0x01, 0xca, 0x41, 0x1e, 0x0a, 0x09, 0x50, 0x68, 0x72, 0x61, 0x73, + 0x65, 0x53, 0x65, 0x74, 0x12, 0x11, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, + 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0xda, 0x41, 0x16, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, + 0x5f, 0x73, 0x65, 0x74, 0x2c, 0x75, 0x70, 0x64, 0x61, 0x74, 0x65, 0x5f, 0x6d, 0x61, 0x73, 0x6b, + 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x47, 0x3a, 0x0a, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x5f, 0x73, + 0x65, 0x74, 0x32, 0x39, 0x2f, 0x76, 0x32, 0x2f, 0x7b, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x5f, + 0x73, 0x65, 0x74, 0x2e, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, + 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, + 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x73, 0x2f, 0x2a, 0x7d, 0x12, 0xc0, 0x01, + 0x0a, 0x0f, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, + 0x74, 0x12, 0x2e, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, + 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x6c, 0x6f, 0x6e, 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, 0x67, 0x2e, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, - 0x22, 0x6a, 0xca, 0x41, 0x1e, 0x0a, 0x09, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, + 0x22, 0x5e, 0xca, 0x41, 0x1e, 0x0a, 0x09, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x12, 0x11, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, - 0x61, 0x74, 0x61, 0xda, 0x41, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x3c, - 0x3a, 0x01, 0x2a, 0x22, 0x37, 0x2f, 0x76, 0x32, 0x2f, 0x7b, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, - 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, - 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x73, - 0x2f, 0x2a, 0x7d, 0x3a, 0x75, 0x6e, 0x64, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x1a, 0x49, 0xca, 0x41, - 0x15, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, - 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0xd2, 0x41, 0x2e, 0x68, 0x74, 0x74, 0x70, 0x73, 0x3a, 0x2f, - 0x2f, 0x77, 0x77, 0x77, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, - 0x63, 0x6f, 0x6d, 0x2f, 0x61, 0x75, 0x74, 0x68, 0x2f, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2d, 0x70, - 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x42, 0x89, 0x03, 0xea, 0x41, 0x78, 0x0a, 0x21, 0x63, - 0x6c, 0x6f, 0x75, 0x64, 0x6b, 0x6d, 0x73, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, - 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x43, 0x72, 0x79, 0x70, 0x74, 0x6f, 0x4b, 0x65, 0x79, - 0x12, 0x53, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x7b, 0x70, 0x72, 0x6f, 0x6a, - 0x65, 0x63, 0x74, 0x7d, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x7b, - 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x7d, 0x2f, 0x6b, 0x65, 0x79, 0x52, 0x69, 0x6e, - 0x67, 0x73, 0x2f, 0x7b, 0x6b, 0x65, 0x79, 0x5f, 0x72, 0x69, 0x6e, 0x67, 0x7d, 0x2f, 0x63, 0x72, - 0x79, 0x70, 0x74, 0x6f, 0x4b, 0x65, 0x79, 0x73, 0x2f, 0x7b, 0x63, 0x72, 0x79, 0x70, 0x74, 0x6f, - 0x5f, 0x6b, 0x65, 0x79, 0x7d, 0xea, 0x41, 0xa6, 0x01, 0x0a, 0x28, 0x63, 0x6c, 0x6f, 0x75, 0x64, - 0x6b, 0x6d, 0x73, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, - 0x6f, 0x6d, 0x2f, 0x43, 0x72, 0x79, 0x70, 0x74, 0x6f, 0x4b, 0x65, 0x79, 0x56, 0x65, 0x72, 0x73, - 0x69, 0x6f, 0x6e, 0x12, 0x7a, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x7b, 0x70, - 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x7d, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, - 0x73, 0x2f, 0x7b, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x7d, 0x2f, 0x6b, 0x65, 0x79, - 0x52, 0x69, 0x6e, 0x67, 0x73, 0x2f, 0x7b, 0x6b, 0x65, 0x79, 0x5f, 0x72, 0x69, 0x6e, 0x67, 0x7d, - 0x2f, 0x63, 0x72, 0x79, 0x70, 0x74, 0x6f, 0x4b, 0x65, 0x79, 0x73, 0x2f, 0x7b, 0x63, 0x72, 0x79, - 0x70, 0x74, 0x6f, 0x5f, 0x6b, 0x65, 0x79, 0x7d, 0x2f, 0x63, 0x72, 0x79, 0x70, 0x74, 0x6f, 0x4b, - 0x65, 0x79, 0x56, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x7b, 0x63, 0x72, 0x79, 0x70, - 0x74, 0x6f, 0x5f, 0x6b, 0x65, 0x79, 0x5f, 0x76, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x7d, 0x0a, - 0x1a, 0x63, 0x6f, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, - 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x42, 0x10, 0x43, 0x6c, 0x6f, - 0x75, 0x64, 0x53, 0x70, 0x65, 0x65, 0x63, 0x68, 0x50, 0x72, 0x6f, 0x74, 0x6f, 0x50, 0x01, 0x5a, - 0x32, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6f, - 0x6d, 0x2f, 0x67, 0x6f, 0x2f, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2f, 0x61, 0x70, 0x69, 0x76, - 0x32, 0x2f, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x70, 0x62, 0x3b, 0x73, 0x70, 0x65, 0x65, 0x63, - 0x68, 0x70, 0x62, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, + 0x61, 0x74, 0x61, 0xda, 0x41, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x30, + 0x2a, 0x2e, 0x2f, 0x76, 0x32, 0x2f, 0x7b, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, + 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, + 0x2f, 0x2a, 0x2f, 0x70, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x73, 0x2f, 0x2a, 0x7d, + 0x12, 0xd0, 0x01, 0x0a, 0x11, 0x55, 0x6e, 0x64, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x50, 0x68, 0x72, + 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x12, 0x30, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, + 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x76, 0x32, 0x2e, + 0x55, 0x6e, 0x64, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x50, 0x68, 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, + 0x74, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, + 0x65, 0x2e, 0x6c, 0x6f, 0x6e, 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, 0x67, 0x2e, 0x4f, 0x70, + 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x22, 0x6a, 0xca, 0x41, 0x1e, 0x0a, 0x09, 0x50, 0x68, + 0x72, 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x12, 0x11, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, + 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0xda, 0x41, 0x04, 0x6e, 0x61, 0x6d, + 0x65, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x3c, 0x3a, 0x01, 0x2a, 0x22, 0x37, 0x2f, 0x76, 0x32, 0x2f, + 0x7b, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, + 0x2f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x2a, 0x2f, 0x70, 0x68, 0x72, + 0x61, 0x73, 0x65, 0x53, 0x65, 0x74, 0x73, 0x2f, 0x2a, 0x7d, 0x3a, 0x75, 0x6e, 0x64, 0x65, 0x6c, + 0x65, 0x74, 0x65, 0x1a, 0x49, 0xca, 0x41, 0x15, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, 0x67, + 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0xd2, 0x41, 0x2e, + 0x68, 0x74, 0x74, 0x70, 0x73, 0x3a, 0x2f, 0x2f, 0x77, 0x77, 0x77, 0x2e, 0x67, 0x6f, 0x6f, 0x67, + 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x61, 0x75, 0x74, 0x68, 0x2f, + 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2d, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x42, 0x89, + 0x03, 0xea, 0x41, 0x78, 0x0a, 0x21, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x6b, 0x6d, 0x73, 0x2e, 0x67, + 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x43, 0x72, + 0x79, 0x70, 0x74, 0x6f, 0x4b, 0x65, 0x79, 0x12, 0x53, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, + 0x73, 0x2f, 0x7b, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x7d, 0x2f, 0x6c, 0x6f, 0x63, 0x61, + 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x7b, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x7d, + 0x2f, 0x6b, 0x65, 0x79, 0x52, 0x69, 0x6e, 0x67, 0x73, 0x2f, 0x7b, 0x6b, 0x65, 0x79, 0x5f, 0x72, + 0x69, 0x6e, 0x67, 0x7d, 0x2f, 0x63, 0x72, 0x79, 0x70, 0x74, 0x6f, 0x4b, 0x65, 0x79, 0x73, 0x2f, + 0x7b, 0x63, 0x72, 0x79, 0x70, 0x74, 0x6f, 0x5f, 0x6b, 0x65, 0x79, 0x7d, 0xea, 0x41, 0xa6, 0x01, + 0x0a, 0x28, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x6b, 0x6d, 0x73, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, + 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x43, 0x72, 0x79, 0x70, 0x74, 0x6f, + 0x4b, 0x65, 0x79, 0x56, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x12, 0x7a, 0x70, 0x72, 0x6f, 0x6a, + 0x65, 0x63, 0x74, 0x73, 0x2f, 0x7b, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x7d, 0x2f, 0x6c, + 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2f, 0x7b, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, + 0x6f, 0x6e, 0x7d, 0x2f, 0x6b, 0x65, 0x79, 0x52, 0x69, 0x6e, 0x67, 0x73, 0x2f, 0x7b, 0x6b, 0x65, + 0x79, 0x5f, 0x72, 0x69, 0x6e, 0x67, 0x7d, 0x2f, 0x63, 0x72, 0x79, 0x70, 0x74, 0x6f, 0x4b, 0x65, + 0x79, 0x73, 0x2f, 0x7b, 0x63, 0x72, 0x79, 0x70, 0x74, 0x6f, 0x5f, 0x6b, 0x65, 0x79, 0x7d, 0x2f, + 0x63, 0x72, 0x79, 0x70, 0x74, 0x6f, 0x4b, 0x65, 0x79, 0x56, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, + 0x73, 0x2f, 0x7b, 0x63, 0x72, 0x79, 0x70, 0x74, 0x6f, 0x5f, 0x6b, 0x65, 0x79, 0x5f, 0x76, 0x65, + 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x7d, 0x0a, 0x1a, 0x63, 0x6f, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, + 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x2e, + 0x76, 0x32, 0x42, 0x10, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x53, 0x70, 0x65, 0x65, 0x63, 0x68, 0x50, + 0x72, 0x6f, 0x74, 0x6f, 0x50, 0x01, 0x5a, 0x32, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x67, 0x6f, + 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x67, 0x6f, 0x2f, 0x73, 0x70, 0x65, 0x65, + 0x63, 0x68, 0x2f, 0x61, 0x70, 0x69, 0x76, 0x32, 0x2f, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x70, + 0x62, 0x3b, 0x73, 0x70, 0x65, 0x65, 0x63, 0x68, 0x70, 0x62, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, + 0x6f, 0x33, } var ( From e41a153be24f3867ab375f9aea25f755270870f8 Mon Sep 17 00:00:00 2001 From: Pascal Terjan Date: Mon, 30 Dec 2024 22:54:52 +0000 Subject: [PATCH 06/16] fix: Make uid.Timestamp work on 32bit architectures (#11353) strconv.Atoi fails because the nanoseconds part of the string does not fit in an int, instead use ParseInt to get an int64. As time.Date only takes an int for the nanoseconds part, use Add() separately instead as it takes a Duration, which is an int64. --- internal/uid/uid.go | 4 ++-- 1 file changed, 2 insertions(+), 2 deletions(-) diff --git a/internal/uid/uid.go b/internal/uid/uid.go index 2f229d647d44..d73e6fb7b2af 100644 --- a/internal/uid/uid.go +++ b/internal/uid/uid.go @@ -131,11 +131,11 @@ func (s *Space) Timestamp(uid string) (time.Time, bool) { y, err1 := strconv.Atoi(subs[1]) m, err2 := strconv.Atoi(subs[2]) d, err3 := strconv.Atoi(subs[3]) - ns, err4 := strconv.Atoi(subs[4]) + ns, err4 := strconv.ParseInt(subs[4], 10, 64) if err1 != nil || err2 != nil || err3 != nil || err4 != nil { return time.Time{}, false } - return time.Date(y, time.Month(m), d, 0, 0, 0, ns, time.UTC), true + return time.Date(y, time.Month(m), d, 0, 0, 0, 0, time.UTC).Add(time.Duration(ns)), true } // Older reports whether uid was created by m and has a timestamp older than From 7f81daf5cb9c443d503bed28aeecb748ec79f094 Mon Sep 17 00:00:00 2001 From: rahul2393 Date: Thu, 2 Jan 2025 14:58:50 +0530 Subject: [PATCH 07/16] chore(spanner): support mutation only operation for read-write mux (#11342) * chore(spanner): support mutation only operation for read-write mux * incorporate changes --- spanner/client.go | 60 +++-- .../internal/testutil/inmem_spanner_server.go | 3 + spanner/mutation.go | 36 ++- spanner/mutation_test.go | 206 +++++++++++++++--- spanner/session.go | 14 +- spanner/transaction.go | 38 ++-- spanner/transaction_test.go | 113 +++++++++- 7 files changed, 381 insertions(+), 89 deletions(-) diff --git a/spanner/client.go b/spanner/client.go index 1ce356266108..5eb8bb164ff9 100644 --- a/spanner/client.go +++ b/spanner/client.go @@ -107,20 +107,19 @@ func parseDatabaseName(db string) (project, instance, database string, err error // Client is a client for reading and writing data to a Cloud Spanner database. // A client is safe to use concurrently, except for its Close method. type Client struct { - sc *sessionClient - idleSessions *sessionPool - logger *log.Logger - qo QueryOptions - ro ReadOptions - ao []ApplyOption - txo TransactionOptions - bwo BatchWriteOptions - ct *commonTags - disableRouteToLeader bool - enableMultiplexedSessionForRW bool - dro *sppb.DirectedReadOptions - otConfig *openTelemetryConfig - metricsTracerFactory *builtinMetricsTracerFactory + sc *sessionClient + idleSessions *sessionPool + logger *log.Logger + qo QueryOptions + ro ReadOptions + ao []ApplyOption + txo TransactionOptions + bwo BatchWriteOptions + ct *commonTags + disableRouteToLeader bool + dro *sppb.DirectedReadOptions + otConfig *openTelemetryConfig + metricsTracerFactory *builtinMetricsTracerFactory } // DatabaseName returns the full name of a database, e.g., @@ -548,20 +547,19 @@ func newClientWithConfig(ctx context.Context, database string, config ClientConf } c = &Client{ - sc: sc, - idleSessions: sp, - logger: config.Logger, - qo: getQueryOptions(config.QueryOptions), - ro: config.ReadOptions, - ao: config.ApplyOptions, - txo: config.TransactionOptions, - bwo: config.BatchWriteOptions, - ct: getCommonTags(sc), - disableRouteToLeader: config.DisableRouteToLeader, - dro: config.DirectedReadOptions, - otConfig: otConfig, - metricsTracerFactory: metricsTracerFactory, - enableMultiplexedSessionForRW: config.enableMultiplexedSessionForRW, + sc: sc, + idleSessions: sp, + logger: config.Logger, + qo: getQueryOptions(config.QueryOptions), + ro: config.ReadOptions, + ao: config.ApplyOptions, + txo: config.TransactionOptions, + bwo: config.BatchWriteOptions, + ct: getCommonTags(sc), + disableRouteToLeader: config.DisableRouteToLeader, + dro: config.DirectedReadOptions, + otConfig: otConfig, + metricsTracerFactory: metricsTracerFactory, } return c, nil } @@ -1025,7 +1023,7 @@ func (c *Client) rwTransaction(ctx context.Context, f func(context.Context, *Rea err error ) if sh == nil || sh.getID() == "" || sh.getClient() == nil { - if c.enableMultiplexedSessionForRW { + if c.idleSessions.isMultiplexedSessionForRWEnabled() { sh, err = c.idleSessions.takeMultiplexed(ctx) } else { // Session handle hasn't been allocated or has been destroyed. @@ -1044,7 +1042,7 @@ func (c *Client) rwTransaction(ctx context.Context, f func(context.Context, *Rea // Note that the t.begin(ctx) call could change the session that is being used by the transaction, as the // BeginTransaction RPC invocation will be retried on a new session if it returns SessionNotFound. t.txReadOnly.sh = sh - if err = t.begin(ctx); err != nil { + if err = t.begin(ctx, nil); err != nil { trace.TracePrintf(ctx, nil, "Error while BeginTransaction during retrying a ReadWrite transaction: %v", ToSpannerError(err)) return ToSpannerError(err) } @@ -1072,7 +1070,7 @@ func (c *Client) rwTransaction(ctx context.Context, f func(context.Context, *Rea return err }) if isUnimplementedErrorForMultiplexedRW(err) { - c.enableMultiplexedSessionForRW = false + c.idleSessions.disableMultiplexedSessionForRW() } return resp, err } diff --git a/spanner/internal/testutil/inmem_spanner_server.go b/spanner/internal/testutil/inmem_spanner_server.go index 86770e4d2948..2955b182a767 100644 --- a/spanner/internal/testutil/inmem_spanner_server.go +++ b/spanner/internal/testutil/inmem_spanner_server.go @@ -1078,6 +1078,9 @@ func (s *inMemSpannerServer) BeginTransaction(ctx context.Context, req *spannerp } s.updateSessionLastUseTime(session.Name) tx := s.beginTransaction(session, req.Options) + if session.Multiplexed && req.MutationKey != nil { + tx.PrecommitToken = s.getPreCommitToken(string(tx.Id), "TransactionPrecommitToken") + } return tx, nil } diff --git a/spanner/mutation.go b/spanner/mutation.go index b9909742d010..7ff9079ed057 100644 --- a/spanner/mutation.go +++ b/spanner/mutation.go @@ -17,7 +17,9 @@ limitations under the License. package spanner import ( + "math/rand" "reflect" + "time" sppb "cloud.google.com/go/spanner/apiv1/spannerpb" "google.golang.org/grpc/codes" @@ -427,16 +429,42 @@ func (m Mutation) proto() (*sppb.Mutation, error) { // mutationsProto turns a spanner.Mutation array into a sppb.Mutation array, // it is convenient for sending batch mutations to Cloud Spanner. -func mutationsProto(ms []*Mutation) ([]*sppb.Mutation, error) { +func mutationsProto(ms []*Mutation) ([]*sppb.Mutation, *sppb.Mutation, error) { + var selectedMutation *Mutation + var nonInsertMutations []*Mutation + l := make([]*sppb.Mutation, 0, len(ms)) for _, m := range ms { + if m.op != opInsert { + nonInsertMutations = append(nonInsertMutations, m) + } + if selectedMutation == nil { + selectedMutation = m + } + // Track the INSERT mutation with the highest number of values if only INSERT mutation were found + if selectedMutation.op == opInsert && m.op == opInsert && len(m.values) > len(selectedMutation.values) { + selectedMutation = m + } + + // Convert the mutation to sppb.Mutation and add to the list pb, err := m.proto() if err != nil { - return nil, err + return nil, nil, err } l = append(l, pb) } - return l, nil + if len(nonInsertMutations) > 0 { + selectedMutation = nonInsertMutations[rand.New(rand.NewSource(time.Now().UnixNano())).Intn(len(nonInsertMutations))] + } + if selectedMutation != nil { + m, err := selectedMutation.proto() + if err != nil { + return nil, nil, err + } + return l, m, nil + } + + return l, nil, nil } // mutationGroupsProto turns a spanner.MutationGroup array into a @@ -444,7 +472,7 @@ func mutationsProto(ms []*Mutation) ([]*sppb.Mutation, error) { func mutationGroupsProto(mgs []*MutationGroup) ([]*sppb.BatchWriteRequest_MutationGroup, error) { gs := make([]*sppb.BatchWriteRequest_MutationGroup, 0, len(mgs)) for _, mg := range mgs { - ms, err := mutationsProto(mg.Mutations) + ms, _, err := mutationsProto(mg.Mutations) if err != nil { return nil, err } diff --git a/spanner/mutation_test.go b/spanner/mutation_test.go index 566b26f892d9..90a9e608de5d 100644 --- a/spanner/mutation_test.go +++ b/spanner/mutation_test.go @@ -18,6 +18,7 @@ package spanner import ( "math/big" + "reflect" "sort" "strings" "testing" @@ -561,61 +562,198 @@ func TestEncodeMutation(t *testing.T) { // Test Encoding an array of mutations. func TestEncodeMutationArray(t *testing.T) { - for _, test := range []struct { - name string - ms []*Mutation - want []*sppb.Mutation - wantErr error + tests := []struct { + name string + ms []*Mutation + want []*sppb.Mutation + wantMutationKey *sppb.Mutation + wantErr error }{ + // Test case for empty mutation list { - "Multiple Mutations", - []*Mutation{ - {opDelete, "t_test", Key{"bar"}, nil, nil}, - {opInsertOrUpdate, "t_test", nil, []string{"key", "val"}, []interface{}{"foo", 1}}, + name: "Empty Mutation List", + ms: []*Mutation{}, + want: []*sppb.Mutation{}, + wantMutationKey: nil, + wantErr: nil, + }, + // Test case for only insert mutations + { + name: "Only Inserts", + ms: []*Mutation{ + {opInsert, "t_test", nil, []string{"key", "val"}, []interface{}{"foo", 1}}, + {opInsert, "t_test", nil, []string{"key", "val"}, []interface{}{"bar", 2}}, + {opInsert, "t_test", nil, []string{"key", "val", "col3"}, []interface{}{"bar2", 3, 4}}, }, - []*sppb.Mutation{ + want: []*sppb.Mutation{ { - Operation: &sppb.Mutation_Delete_{ - Delete: &sppb.Mutation_Delete{ - Table: "t_test", - KeySet: &sppb.KeySet{ - Keys: []*proto3.ListValue{listValueProto(stringProto("bar"))}, + Operation: &sppb.Mutation_Insert{ + Insert: &sppb.Mutation_Write{ + Table: "t_test", + Columns: []string{"key", "val"}, + Values: []*proto3.ListValue{ + listValueProto(stringProto("foo"), intProto(1)), }, }, }, }, { - Operation: &sppb.Mutation_InsertOrUpdate{ - InsertOrUpdate: &sppb.Mutation_Write{ + Operation: &sppb.Mutation_Insert{ + Insert: &sppb.Mutation_Write{ Table: "t_test", Columns: []string{"key", "val"}, - Values: []*proto3.ListValue{listValueProto(stringProto("foo"), intProto(1))}, + Values: []*proto3.ListValue{ + listValueProto(stringProto("bar"), intProto(2)), + }, + }, + }, + }, + { + Operation: &sppb.Mutation_Insert{ + Insert: &sppb.Mutation_Write{ + Table: "t_test", + Columns: []string{"key", "val", "col3"}, + Values: []*proto3.ListValue{ + listValueProto(stringProto("bar2"), intProto(3), intProto(4)), + }, }, }, }, }, - nil, + wantMutationKey: &sppb.Mutation{ + Operation: &sppb.Mutation_Insert{ + Insert: &sppb.Mutation_Write{ + Table: "t_test", + Columns: []string{"key", "val", "col3"}, + Values: []*proto3.ListValue{ + listValueProto(stringProto("bar2"), intProto(3), intProto(4)), + }, + }, + }, + }, + wantErr: nil, }, + // Test case for mixed operations { - "Multiple Mutations - Bad Mutation", - []*Mutation{ + name: "Mixed Operations", + ms: []*Mutation{ + {opInsert, "t_test", nil, []string{"key", "val"}, []interface{}{"foo", 1}}, + {opUpdate, "t_test", nil, []string{"key", "val"}, []interface{}{"bar", 2}}, + }, + want: []*sppb.Mutation{ + { + Operation: &sppb.Mutation_Insert{ + Insert: &sppb.Mutation_Write{ + Table: "t_test", + Columns: []string{"key", "val"}, + Values: []*proto3.ListValue{ + listValueProto(stringProto("foo"), intProto(1)), + }, + }, + }, + }, + { + Operation: &sppb.Mutation_Update{ + Update: &sppb.Mutation_Write{ + Table: "t_test", + Columns: []string{"key", "val"}, + Values: []*proto3.ListValue{ + listValueProto(stringProto("bar"), intProto(2)), + }, + }, + }, + }, + }, + wantMutationKey: &sppb.Mutation{ + Operation: &sppb.Mutation_Update{ + Update: &sppb.Mutation_Write{ + Table: "t_test", + Columns: []string{"key", "val"}, + Values: []*proto3.ListValue{ + listValueProto(stringProto("bar"), intProto(2)), + }, + }, + }, + }, + wantErr: nil, + }, + // Test case for error in mutation + { + name: "Error in Mutation", + ms: []*Mutation{ + {opInsert, "t_test", nil, []string{"key", "val"}, []interface{}{struct{}{}, 1}}, + }, + want: []*sppb.Mutation{}, + wantMutationKey: nil, + wantErr: errEncoderUnsupportedType(struct{}{}), + }, + // Test case for only delete mutations + { + name: "Only Deletes", + ms: []*Mutation{ + {opDelete, "t_test", Key{"foo"}, nil, nil}, {opDelete, "t_test", Key{"bar"}, nil, nil}, - {opInsertOrUpdate, "t_test", nil, []string{"key", "val"}, []interface{}{"foo", struct{}{}}}, }, - []*sppb.Mutation{}, - errEncoderUnsupportedType(struct{}{}), + want: []*sppb.Mutation{ + { + Operation: &sppb.Mutation_Delete_{ + Delete: &sppb.Mutation_Delete{ + Table: "t_test", + KeySet: &sppb.KeySet{ + Keys: []*proto3.ListValue{ + listValueProto(stringProto("foo")), + }, + }, + }, + }, + }, + { + Operation: &sppb.Mutation_Delete_{ + Delete: &sppb.Mutation_Delete{ + Table: "t_test", + KeySet: &sppb.KeySet{ + Keys: []*proto3.ListValue{ + listValueProto(stringProto("bar")), + }, + }, + }, + }, + }, + }, + wantMutationKey: &sppb.Mutation{ + Operation: &sppb.Mutation_Delete_{ + Delete: &sppb.Mutation_Delete{ + Table: "t_test", + KeySet: &sppb.KeySet{ + Keys: []*proto3.ListValue{ + listValueProto(stringProto("bar")), + }, + }, + }, + }, + }, + wantErr: nil, }, - } { - gotProto, gotErr := mutationsProto(test.ms) - if gotErr != nil { - if !testEqual(gotErr, test.wantErr) { - t.Errorf("%v: mutationsProto(%v) returns error %v, want %v", test.name, test.ms, gotErr, test.wantErr) + } + + for _, test := range tests { + t.Run(test.name, func(t *testing.T) { + gotProto, gotMutationKey, gotErr := mutationsProto(test.ms) + if gotErr != nil { + if !testEqual(gotErr, test.wantErr) { + t.Errorf("mutationsProto(%v) returns error %v, want %v", test.ms, gotErr, test.wantErr) + } + return } - continue - } - if !testEqual(gotProto, test.want) { - t.Errorf("%v: mutationsProto(%v) = (%v, nil), want (%v, nil)", test.name, test.ms, gotProto, test.want) - } + if !testEqual(gotProto, test.want) { + t.Errorf("mutationsProto(%v) = (%v, nil), want (%v, nil)", test.ms, gotProto, test.want) + } + if test.wantMutationKey != nil { + if reflect.TypeOf(gotMutationKey.Operation) != reflect.TypeOf(test.wantMutationKey.Operation) { + t.Errorf("mutationsProto(%v) returns mutation key %v, want %v", test.ms, gotMutationKey, test.wantMutationKey) + } + } + }) } } diff --git a/spanner/session.go b/spanner/session.go index 2165fdee04d8..2396bc0ab9ee 100644 --- a/spanner/session.go +++ b/spanner/session.go @@ -508,7 +508,7 @@ type SessionPoolConfig struct { enableMultiplexSession bool - // enableMultiplexedSessionForRW is a flag to enable multiplexed session for read/write transactions, is used in testing + // enableMultiplexedSessionForRW is a flag to enable multiplexed session for read/write transactions enableMultiplexedSessionForRW bool // healthCheckSampleInterval is how often the health checker samples live @@ -810,6 +810,18 @@ func (p *sessionPool) getRatioOfSessionsInUseLocked() float64 { return float64(p.numInUse) / float64(maxSessions) } +func (p *sessionPool) isMultiplexedSessionForRWEnabled() bool { + p.mu.Lock() + defer p.mu.Unlock() + return p.enableMultiplexedSessionForRW +} + +func (p *sessionPool) disableMultiplexedSessionForRW() { + p.mu.Lock() + defer p.mu.Unlock() + p.enableMultiplexedSessionForRW = false +} + // gets sessions which are unexpectedly long-running. func (p *sessionPool) getLongRunningSessionsLocked() []*sessionHandle { usedSessionsRatio := p.getRatioOfSessionsInUseLocked() diff --git a/spanner/transaction.go b/spanner/transaction.go index dbc1c5e969ef..94fb770ead53 100644 --- a/spanner/transaction.go +++ b/spanner/transaction.go @@ -1535,7 +1535,7 @@ func (t *ReadWriteTransaction) setSessionEligibilityForLongRunning(sh *sessionHa } } -func beginTransaction(ctx context.Context, sid string, client spannerClient, opts TransactionOptions) (transactionID, error) { +func beginTransaction(ctx context.Context, sid string, client spannerClient, opts TransactionOptions, mutationKey *sppb.Mutation) (transactionID, *sppb.MultiplexedSessionPrecommitToken, error) { res, err := client.BeginTransaction(ctx, &sppb.BeginTransactionRequest{ Session: sid, Options: &sppb.TransactionOptions{ @@ -1546,14 +1546,16 @@ func beginTransaction(ctx context.Context, sid string, client spannerClient, opt }, ExcludeTxnFromChangeStreams: opts.ExcludeTxnFromChangeStreams, }, + MutationKey: mutationKey, }) if err != nil { - return nil, err + return nil, nil, err } if res.Id == nil { - return nil, spannerErrorf(codes.Unknown, "BeginTransaction returned a transaction with a nil ID.") + return nil, nil, spannerErrorf(codes.Unknown, "BeginTransaction returned a transaction with a nil ID.") } - return res.Id, nil + + return res.Id, res.GetPrecommitToken(), nil } // shouldExplicitBegin checks if ReadWriteTransaction should do an explicit BeginTransaction @@ -1572,7 +1574,7 @@ func (t *ReadWriteTransaction) shouldExplicitBegin(attempt int) bool { } // begin starts a read-write transaction on Cloud Spanner. -func (t *ReadWriteTransaction) begin(ctx context.Context) error { +func (t *ReadWriteTransaction) begin(ctx context.Context, mutation *sppb.Mutation) error { t.mu.Lock() if t.tx != nil { t.state = txActive @@ -1582,8 +1584,9 @@ func (t *ReadWriteTransaction) begin(ctx context.Context) error { t.mu.Unlock() var ( - tx transactionID - err error + tx transactionID + precommitToken *sppb.MultiplexedSessionPrecommitToken + err error ) defer func() { if err != nil && sh != nil { @@ -1601,9 +1604,10 @@ func (t *ReadWriteTransaction) begin(ctx context.Context) error { if sh != nil { sh.updateLastUseTime() } - tx, err = beginTransaction(contextWithOutgoingMetadata(ctx, sh.getMetadata(), t.disableRouteToLeader), sh.getID(), sh.getClient(), t.txOpts) + tx, precommitToken, err = beginTransaction(contextWithOutgoingMetadata(ctx, sh.getMetadata(), t.disableRouteToLeader), sh.getID(), sh.getClient(), t.txOpts, mutation) if isSessionNotFoundError(err) { sh.destroy() + // this should not happen with multiplexed session, but if it does, we should not retry with multiplexed session sh, err = t.sp.take(ctx) if err != nil { return err @@ -1614,6 +1618,7 @@ func (t *ReadWriteTransaction) begin(ctx context.Context) error { } else { err = ToSpannerError(err) } + t.updatePrecommitToken(precommitToken) break } if err == nil { @@ -1660,6 +1665,7 @@ func (co CommitOptions) merge(opts CommitOptions) CommitOptions { func (t *ReadWriteTransaction) commit(ctx context.Context, options CommitOptions) (CommitResponse, error) { resp := CommitResponse{} t.mu.Lock() + mutationProtos, selectedMutationProto, err := mutationsProto(t.wb) if t.tx == nil { if t.state == txClosed { // inline begin transaction failed @@ -1667,16 +1673,18 @@ func (t *ReadWriteTransaction) commit(ctx context.Context, options CommitOptions return resp, errInlineBeginTransactionFailed() } t.mu.Unlock() + if !t.sp.isMultiplexedSessionForRWEnabled() { + selectedMutationProto = nil + } // mutations or empty transaction body only - if err := t.begin(ctx); err != nil { + if err := t.begin(ctx, selectedMutationProto); err != nil { return resp, err } t.mu.Lock() } t.state = txClosed // No further operations after commit. close(t.txReadyOrClosed) - mPb, err := mutationsProto(t.wb) - + precommitToken := t.precommitToken t.mu.Unlock() if err != nil { return resp, err @@ -1700,9 +1708,9 @@ func (t *ReadWriteTransaction) commit(ctx context.Context, options CommitOptions Transaction: &sppb.CommitRequest_TransactionId{ TransactionId: t.tx, }, - PrecommitToken: t.precommitToken, + PrecommitToken: precommitToken, RequestOptions: createRequestOptions(t.txOpts.CommitPriority, "", t.txOpts.TransactionTag), - Mutations: mPb, + Mutations: mutationProtos, ReturnCommitStats: options.ReturnCommitStats, MaxCommitDelay: maxCommitDelay, }, gax.WithGRPCOptions(grpc.Header(&md))) @@ -1883,7 +1891,7 @@ func newReadWriteStmtBasedTransactionWithSessionHandle(ctx context.Context, c *C t.otConfig = c.otConfig // always explicit begin the transactions - if err = t.begin(ctx); err != nil { + if err = t.begin(ctx, nil); err != nil { if sh != nil { sh.recycle() } @@ -1975,7 +1983,7 @@ func (t *writeOnlyTransaction) applyAtLeastOnce(ctx context.Context, ms ...*Muta sh.recycle() } }() - mPb, err := mutationsProto(ms) + mPb, _, err := mutationsProto(ms) if err != nil { // Malformed mutation found, just return the error. return ts, err diff --git a/spanner/transaction_test.go b/spanner/transaction_test.go index 1acd7f72f390..c17d40879cbe 100644 --- a/spanner/transaction_test.go +++ b/spanner/transaction_test.go @@ -413,19 +413,31 @@ func TestReadWriteTransaction_PrecommitToken(t *testing.T) { query bool update bool batchUpdate bool + mutationsOnly bool expectedPrecommitToken string expectedSequenceNumber int32 } testCases := []testCase{ - {"Only Query", true, false, false, "PartialResultSetPrecommitToken", 3}, //since mock server is returning 3 rows - {"Query and Update", true, true, false, "ResultSetPrecommitToken", 4}, - {"Query, Update, and Batch Update", true, true, true, "ExecuteBatchDmlResponsePrecommitToken", 5}, + {"Only Query", true, false, false, false, "PartialResultSetPrecommitToken", 3}, + {"Query and Update", true, true, false, false, "ResultSetPrecommitToken", 4}, + {"Query, Update, and Batch Update", true, true, true, false, "ExecuteBatchDmlResponsePrecommitToken", 5}, + {"Only Mutations", false, false, false, true, "TransactionPrecommitToken", 1}, } for _, tc := range testCases { t.Run(tc.name, func(t *testing.T) { _, err := client.ReadWriteTransaction(ctx, func(ctx context.Context, tx *ReadWriteTransaction) error { + if tc.mutationsOnly { + ms := []*Mutation{ + Insert("t_foo", []string{"col1", "col2"}, []interface{}{int64(1), int64(2)}), + Update("t_foo", []string{"col1", "col2"}, []interface{}{"one", []byte(nil)}), + } + if err := tx.BufferWrite(ms); err != nil { + return err + } + } + if tc.query { iter := tx.Query(ctx, NewStatement(SelectSingerIDAlbumIDAlbumTitleFromAlbums)) defer iter.Stop() @@ -463,8 +475,19 @@ func TestReadWriteTransaction_PrecommitToken(t *testing.T) { for _, req := range requests { if c, ok := req.(*sppb.CommitRequest); ok { commitReq = c - break } + if b, ok := req.(*sppb.BeginTransactionRequest); ok { + if !strings.Contains(b.GetSession(), "multiplexed") { + t.Errorf("Expected session to be multiplexed") + } + if b.MutationKey == nil { + t.Fatalf("Expected BeginTransaction request to contain a mutation key") + } + } + + } + if !strings.Contains(commitReq.GetSession(), "multiplexed") { + t.Errorf("Expected session to be multiplexed") } if commitReq.PrecommitToken == nil || len(commitReq.PrecommitToken.GetPrecommitToken()) == 0 { t.Fatalf("Expected commit request to contain a valid precommitToken, got: %v", commitReq.PrecommitToken) @@ -481,6 +504,88 @@ func TestReadWriteTransaction_PrecommitToken(t *testing.T) { } } +func TestMutationOnlyCaseAborted(t *testing.T) { + t.Parallel() + ctx := context.Background() + + // Define mutations to apply + mutations := []*Mutation{ + Insert("FOO", []string{"ID", "NAME"}, []interface{}{int64(1), "Bar"}), + } + + // Define a function to verify requests + verifyRequests := func(server *MockedSpannerInMemTestServer) { + var numBeginReq, numCommitReq int + // Verify that for mutation-only case, a mutation key is set in BeginTransactionRequest + requests := drainRequestsFromServer(server.TestSpanner) + for _, req := range requests { + if beginReq, ok := req.(*sppb.BeginTransactionRequest); ok { + if beginReq.GetMutationKey() == nil { + t.Fatalf("Expected mutation key with insert operation") + } + if !strings.Contains(beginReq.GetSession(), "multiplexed") { + t.Errorf("Expected session to be multiplexed") + } + numBeginReq++ + } + if commitReq, ok := req.(*sppb.CommitRequest); ok { + if commitReq.GetPrecommitToken() == nil || !strings.Contains(string(commitReq.GetPrecommitToken().PrecommitToken), "TransactionPrecommitToken") { + t.Errorf("Expected precommit token 'TransactionPrecommitToken', got %v", commitReq.GetPrecommitToken()) + } + if !strings.Contains(commitReq.GetSession(), "multiplexed") { + t.Errorf("Expected session to be multiplexed") + } + numCommitReq++ + } + } + if numBeginReq != 2 || numCommitReq != 2 { + t.Fatalf("Expected 2 BeginTransactionRequests and 2 CommitRequests, got %d and %d", numBeginReq, numCommitReq) + } + } + + // Test both ReadWriteTransaction and client.Apply + for _, method := range []string{"ReadWriteTransaction", "Apply"} { + t.Run(method, func(t *testing.T) { + server, client, teardown := setupMockedTestServerWithConfig(t, ClientConfig{ + DisableNativeMetrics: true, + SessionPoolConfig: SessionPoolConfig{ + MinOpened: 1, + MaxOpened: 1, + enableMultiplexSession: true, + enableMultiplexedSessionForRW: true, + }, + }) + defer teardown() + + // Simulate an aborted transaction on the first commit attempt + server.TestSpanner.PutExecutionTime(MethodCommitTransaction, + SimulatedExecutionTime{ + Errors: []error{status.Errorf(codes.Aborted, "Transaction aborted")}, + }) + switch method { + case "ReadWriteTransaction": + _, err := client.ReadWriteTransaction(ctx, func(ctx context.Context, tx *ReadWriteTransaction) error { + if err := tx.BufferWrite(mutations); err != nil { + return err + } + return nil + }) + if err != nil { + t.Fatalf("ReadWriteTransaction failed: %v", err) + } + case "Apply": + _, err := client.Apply(ctx, mutations) + if err != nil { + t.Fatalf("Apply failed: %v", err) + } + } + + // Verify requests for the current method + verifyRequests(server) + }) + } +} + func TestBatchDML_WithMultipleDML(t *testing.T) { t.Parallel() ctx := context.Background() From e904ee645048f31d484dd4dc2ef29803c21a6f9b Mon Sep 17 00:00:00 2001 From: "release-please[bot]" <55107282+release-please[bot]@users.noreply.github.com> Date: Thu, 2 Jan 2025 11:11:49 -0500 Subject: [PATCH 08/16] chore(main): release logging 1.13.0 (#11026) Co-authored-by: release-please[bot] <55107282+release-please[bot]@users.noreply.github.com> --- .release-please-manifest-individual.json | 2 +- logging/CHANGES.md | 15 ++++++++++++++- logging/internal/version.go | 2 +- 3 files changed, 16 insertions(+), 3 deletions(-) diff --git a/.release-please-manifest-individual.json b/.release-please-manifest-individual.json index 962a661cc2b5..f7c0ab189278 100644 --- a/.release-please-manifest-individual.json +++ b/.release-please-manifest-individual.json @@ -6,7 +6,7 @@ "datastore": "1.20.0", "errorreporting": "0.3.2", "firestore": "1.17.0", - "logging": "1.12.0", + "logging": "1.13.0", "profiler": "0.4.2", "pubsub": "1.45.3", "pubsublite": "1.8.2", diff --git a/logging/CHANGES.md b/logging/CHANGES.md index 03169c86b319..cb66918a03b8 100644 --- a/logging/CHANGES.md +++ b/logging/CHANGES.md @@ -1,5 +1,19 @@ # Changes +## [1.13.0](https://github.com/googleapis/google-cloud-go/compare/logging/v1.12.0...logging/v1.13.0) (2025-01-02) + + +### Features + +* **logging:** Change go gapic transport to grpc+rest in logging ([#11289](https://github.com/googleapis/google-cloud-go/issues/11289)) ([a5f250b](https://github.com/googleapis/google-cloud-go/commit/a5f250baf8085bdb07807869a7c4a3a0ca3f535d)) + + +### Bug Fixes + +* **logging:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) +* **logging:** Update google.golang.org/api to v0.203.0 ([8bb87d5](https://github.com/googleapis/google-cloud-go/commit/8bb87d56af1cba736e0fe243979723e747e5e11e)) +* **logging:** WARNING: On approximately Dec 1, 2024, an update to Protobuf will change service registration function signatures to use an interface instead of a concrete type in generated .pb.go files. This change is expected to affect very few if any users of this client library. For more information, see https://togithub.com/googleapis/google-cloud-go/issues/11020. ([8bb87d5](https://github.com/googleapis/google-cloud-go/commit/8bb87d56af1cba736e0fe243979723e747e5e11e)) + ## [1.12.0](https://github.com/googleapis/google-cloud-go/compare/logging/v1.11.0...logging/v1.12.0) (2024-10-16) @@ -202,4 +216,3 @@ This is the first tag to carve out logging as its own module. See: https://github.com/golang/go/wiki/Modules#is-it-possible-to-add-a-module-to-a-multi-module-repository. - diff --git a/logging/internal/version.go b/logging/internal/version.go index 4518b5fb4070..efedadbea253 100644 --- a/logging/internal/version.go +++ b/logging/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.12.0" +const Version = "1.13.0" From e2796a8c1460211fc2f4e78f37e15e8e2b6e8179 Mon Sep 17 00:00:00 2001 From: "gcf-owl-bot[bot]" <78513119+gcf-owl-bot[bot]@users.noreply.github.com> Date: Thu, 2 Jan 2025 18:08:22 +0000 Subject: [PATCH 09/16] chore(parallelstore): fix links in documentation (#11358) - [ ] Regenerate this pull request now. docs(parallelstore): A comment for field `requested_cancellation` in message `.google.cloud.parallelstore.v1beta.OperationMetadata` is changed docs(parallelstore): A comment for field `requested_cancellation` in message `.google.cloud.parallelstore.v1beta.ImportDataMetadata` is changed docs(parallelstore): A comment for field `requested_cancellation` in message `.google.cloud.parallelstore.v1beta.ExportDataMetadata` is changed PiperOrigin-RevId: 710797407 Source-Link: https://togithub.com/googleapis/googleapis/commit/52e410823122cf44d265c3beecb86c773db248a2 Source-Link: https://togithub.com/googleapis/googleapis-gen/commit/955605b9457aa6185e2bc2f5657fef0fc12cfe6c Copy-Tag: eyJwIjoiLmdpdGh1Yi8uT3dsQm90LnlhbWwiLCJoIjoiOTU1NjA1Yjk0NTdhYTYxODVlMmJjMmY1NjU3ZmVmMGZjMTJjZmU2YyJ9 --- .../apiv2/snippet_metadata.google.storage.control.v2.json | 2 +- parallelstore/apiv1beta/parallelstorepb/parallelstore.pb.go | 6 +++--- 2 files changed, 4 insertions(+), 4 deletions(-) diff --git a/internal/generated/snippets/storage/control/apiv2/snippet_metadata.google.storage.control.v2.json b/internal/generated/snippets/storage/control/apiv2/snippet_metadata.google.storage.control.v2.json index c4558f12f5a8..c6a30232588b 100644 --- a/internal/generated/snippets/storage/control/apiv2/snippet_metadata.google.storage.control.v2.json +++ b/internal/generated/snippets/storage/control/apiv2/snippet_metadata.google.storage.control.v2.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/storage/control/apiv2", - "version": "1.48.0", + "version": "1.49.0", "language": "GO", "apis": [ { diff --git a/parallelstore/apiv1beta/parallelstorepb/parallelstore.pb.go b/parallelstore/apiv1beta/parallelstorepb/parallelstore.pb.go index 293e2f28ec46..0b77a5aa4def 100755 --- a/parallelstore/apiv1beta/parallelstorepb/parallelstore.pb.go +++ b/parallelstore/apiv1beta/parallelstorepb/parallelstore.pb.go @@ -994,7 +994,7 @@ type OperationMetadata struct { StatusMessage string `protobuf:"bytes,5,opt,name=status_message,json=statusMessage,proto3" json:"status_message,omitempty"` // Output only. Identifies whether the user has requested cancellation // of the operation. Operations that have been cancelled successfully - // have [Operation.error][] value with a + // have [Operation.error][google.longrunning.Operation.error] value with a // [google.rpc.Status.code][google.rpc.Status.code] of 1, corresponding to // `Code.CANCELLED`. RequestedCancellation bool `protobuf:"varint,6,opt,name=requested_cancellation,json=requestedCancellation,proto3" json:"requested_cancellation,omitempty"` @@ -1629,7 +1629,7 @@ type ImportDataMetadata struct { StatusMessage string `protobuf:"bytes,6,opt,name=status_message,json=statusMessage,proto3" json:"status_message,omitempty"` // Output only. Identifies whether the user has requested cancellation // of the operation. Operations that have successfully been cancelled - // have [Operation.error][] value with a + // have [Operation.error][google.longrunning.Operation.error] value with a // [google.rpc.Status.code][google.rpc.Status.code] of 1, corresponding to // `Code.CANCELLED`. RequestedCancellation bool `protobuf:"varint,7,opt,name=requested_cancellation,json=requestedCancellation,proto3" json:"requested_cancellation,omitempty"` @@ -1780,7 +1780,7 @@ type ExportDataMetadata struct { StatusMessage string `protobuf:"bytes,6,opt,name=status_message,json=statusMessage,proto3" json:"status_message,omitempty"` // Output only. Identifies whether the user has requested cancellation // of the operation. Operations that have successfully been cancelled - // have [Operation.error][] value with a + // have [Operation.error][google.longrunning.Operation.error] value with a // [google.rpc.Status.code][google.rpc.Status.code] of 1, corresponding to // `Code.CANCELLED`. RequestedCancellation bool `protobuf:"varint,7,opt,name=requested_cancellation,json=requestedCancellation,proto3" json:"requested_cancellation,omitempty"` From d45f1a01ebff868418aa14fe762ef7d1334f797d Mon Sep 17 00:00:00 2001 From: Vinayaka Batwara <52167385+Vinayaka-B@users.noreply.github.com> Date: Thu, 2 Jan 2025 23:47:19 +0530 Subject: [PATCH 10/16] feat(civil): add AddMonths, AddYears and Weekday methods to Date (#11340) --- civil/civil.go | 17 +++++++ civil/civil_test.go | 116 ++++++++++++++++++++++++++++++++++++++++++++ 2 files changed, 133 insertions(+) diff --git a/civil/civil.go b/civil/civil.go index cf663022dea4..9e9541dfa6d3 100644 --- a/civil/civil.go +++ b/civil/civil.go @@ -86,6 +86,18 @@ func (d Date) AddDays(n int) Date { return DateOf(d.In(time.UTC).AddDate(0, 0, n)) } +// AddMonths returns the date that is n months in the future. +// n can also be negative to go into the past. +func (d Date) AddMonths(n int) Date { + return DateOf(d.In(time.UTC).AddDate(0, n, 0)) +} + +// AddYears returns the date that is n years in the future. +// n can also be negative to go into the past. +func (d Date) AddYears(n int) Date { + return DateOf(d.In(time.UTC).AddDate(n, 0, 0)) +} + // DaysSince returns the signed number of days between the date and s, not including the end day. // This is the inverse operation to AddDays. func (d Date) DaysSince(s Date) (days int) { @@ -127,6 +139,11 @@ func (d Date) IsZero() bool { return (d.Year == 0) && (int(d.Month) == 0) && (d.Day == 0) } +// Weekday returns the day of the week for the date. +func (d Date) Weekday() time.Weekday { + return d.In(time.UTC).Weekday() +} + // MarshalText implements the encoding.TextMarshaler interface. // The output is the result of d.String(). func (d Date) MarshalText() ([]byte, error) { diff --git a/civil/civil_test.go b/civil/civil_test.go index 590e77b90af9..23cc469d6991 100644 --- a/civil/civil_test.go +++ b/civil/civil_test.go @@ -163,6 +163,106 @@ func TestDateArithmetic(t *testing.T) { } } +func TestDateArithmeticMonths(t *testing.T) { + for _, test := range []struct { + desc string + start Date + end Date + months int + }{ + { + desc: "zero months noop", + start: Date{2024, 12, 16}, + end: Date{2024, 12, 16}, + months: 0, + }, + { + desc: "crossing a year boundary", + start: Date{2014, 8, 31}, + end: Date{2015, 1, 31}, + months: 5, + }, + { + desc: "negative number of months", + start: Date{2015, 1, 1}, + end: Date{2014, 12, 1}, + months: -1, + }, + { + desc: "full leap year", + start: Date{2008, 1, 1}, + end: Date{2009, 1, 1}, + months: 12, + }, + { + desc: "full non-leap year", + start: Date{1997, 1, 1}, + end: Date{1998, 1, 1}, + months: 12, + }, + { + desc: "crossing a leap second", + start: Date{1972, 6, 30}, + end: Date{1972, 7, 30}, + months: 1, + }, + { + desc: "dates before the unix epoch", + start: Date{101, 1, 1}, + end: Date{101, 6, 1}, + months: 5, + }, + } { + if got := test.start.AddMonths(test.months); got.Compare(test.end) != 0 { + t.Errorf("[%s] %#v.AddMonths(%v) = %#v, want %#v", test.desc, test.start, test.months, got, test.end) + } + } +} + +func TestDateArithmeticYears(t *testing.T) { + for _, test := range []struct { + desc string + start Date + end Date + years int + }{ + { + desc: "zero years noop", + start: Date{2024, 6, 19}, + end: Date{2024, 6, 19}, + years: 0, + }, + { + desc: "positive number of years", + start: Date{2012, 4, 29}, + end: Date{2014, 4, 29}, + years: 2, + }, + { + desc: "negative number of years", + start: Date{2027, 1, 1}, + end: Date{2024, 1, 1}, + years: -3, + }, + { + desc: "crossing a leap second", + start: Date{1972, 6, 30}, + end: Date{1973, 6, 30}, + years: 1, + }, + { + desc: "dates before the unix epoch", + start: Date{99, 1, 1}, + end: Date{102, 1, 1}, + years: 3, + }, + } { + if got := test.start.AddYears(test.years); got.Compare(test.end) != 0 { + t.Errorf("[%s] %#v.AddDays(%v) = %#v, want %#v", test.desc, test.start, test.years, got, test.end) + } + } +} + func TestDateBefore(t *testing.T) { for _, test := range []struct { d1, d2 Date @@ -226,6 +326,22 @@ func TestDateIsZero(t *testing.T) { } } +func TestDateWeekday(t *testing.T) { + for _, test := range []struct { + date Date + want time.Weekday + }{ + {Date{2024, 12, 21}, time.Saturday}, + {Date{1900, 1, 1}, time.Monday}, + {Date{2482, 3, 17}, time.Tuesday}, + } { + got := test.date.Weekday() + if got != test.want { + t.Errorf("%#v: got %v, want %v", test.date, got, test.want) + } + } +} + func TestTimeToString(t *testing.T) { for _, test := range []struct { str string From 00c6c0b02afce520a71a455c44d12be5991103cf Mon Sep 17 00:00:00 2001 From: "release-please[bot]" <55107282+release-please[bot]@users.noreply.github.com> Date: Thu, 2 Jan 2025 11:25:02 -0700 Subject: [PATCH 11/16] chore(main): release 0.118.0 (#11360) --- .release-please-manifest.json | 2 +- CHANGES.md | 7 +++++++ 2 files changed, 8 insertions(+), 1 deletion(-) diff --git a/.release-please-manifest.json b/.release-please-manifest.json index 3200815ccada..87c6277740c6 100644 --- a/.release-please-manifest.json +++ b/.release-please-manifest.json @@ -1,3 +1,3 @@ { - ".": "0.117.0" + ".": "0.118.0" } diff --git a/CHANGES.md b/CHANGES.md index c8d214a8e30b..74c920023e3b 100644 --- a/CHANGES.md +++ b/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [0.118.0](https://github.com/googleapis/google-cloud-go/compare/v0.117.0...v0.118.0) (2025-01-02) + + +### Features + +* **civil:** Add AddMonths, AddYears and Weekday methods to Date ([#11340](https://github.com/googleapis/google-cloud-go/issues/11340)) ([d45f1a0](https://github.com/googleapis/google-cloud-go/commit/d45f1a01ebff868418aa14fe762ef7d1334f797d)) + ## [0.117.0](https://github.com/googleapis/google-cloud-go/compare/v0.116.0...v0.117.0) (2024-12-16) From b7a7787ebf5e1521d2dab685a3a37bb0ea7732d8 Mon Sep 17 00:00:00 2001 From: "release-please[bot]" <55107282+release-please[bot]@users.noreply.github.com> Date: Thu, 2 Jan 2025 12:03:39 -0700 Subject: [PATCH 12/16] chore: release main (#11321) --- .release-please-manifest-submodules.json | 298 +++++++++---------- accessapproval/CHANGES.md | 7 + accesscontextmanager/CHANGES.md | 7 + advisorynotifications/CHANGES.md | 7 + advisorynotifications/internal/version.go | 2 +- alloydb/CHANGES.md | 7 + alloydb/internal/version.go | 2 +- analytics/CHANGES.md | 7 + analytics/internal/version.go | 2 +- apigateway/CHANGES.md | 7 + apigeeconnect/CHANGES.md | 7 + apigeeregistry/CHANGES.md | 7 + apihub/CHANGES.md | 7 + apihub/internal/version.go | 2 +- apikeys/CHANGES.md | 7 + appengine/CHANGES.md | 7 + apphub/CHANGES.md | 7 + apphub/internal/version.go | 2 +- apps/CHANGES.md | 7 + apps/internal/version.go | 2 +- area120/CHANGES.md | 7 + artifactregistry/CHANGES.md | 7 + asset/CHANGES.md | 7 + asset/internal/version.go | 2 +- assuredworkloads/CHANGES.md | 7 + automl/CHANGES.md | 7 + backupdr/CHANGES.md | 7 + backupdr/internal/version.go | 2 +- baremetalsolution/CHANGES.md | 7 + batch/CHANGES.md | 12 + batch/internal/version.go | 2 +- beyondcorp/CHANGES.md | 7 + billing/CHANGES.md | 7 + binaryauthorization/CHANGES.md | 7 + binaryauthorization/internal/version.go | 2 +- certificatemanager/CHANGES.md | 7 + certificatemanager/internal/version.go | 2 +- channel/CHANGES.md | 7 + chat/CHANGES.md | 7 + chat/internal/version.go | 2 +- cloudbuild/CHANGES.md | 7 + cloudbuild/internal/version.go | 2 +- cloudcontrolspartner/CHANGES.md | 7 + cloudcontrolspartner/internal/version.go | 2 +- clouddms/CHANGES.md | 7 + cloudprofiler/CHANGES.md | 7 + cloudprofiler/internal/version.go | 2 +- cloudquotas/CHANGES.md | 7 + cloudquotas/internal/version.go | 2 +- cloudtasks/CHANGES.md | 7 + commerce/CHANGES.md | 7 + commerce/internal/version.go | 2 +- compute/CHANGES.md | 7 + compute/internal/version.go | 2 +- confidentialcomputing/CHANGES.md | 7 + confidentialcomputing/internal/version.go | 2 +- config/CHANGES.md | 7 + config/internal/version.go | 2 +- contactcenterinsights/CHANGES.md | 7 + contactcenterinsights/internal/version.go | 2 +- container/CHANGES.md | 7 + container/internal/version.go | 2 +- containeranalysis/CHANGES.md | 7 + containeranalysis/internal/version.go | 2 +- datacatalog/CHANGES.md | 7 + datacatalog/internal/version.go | 2 +- dataflow/CHANGES.md | 7 + dataform/CHANGES.md | 7 + dataform/internal/version.go | 2 +- datafusion/CHANGES.md | 7 + datalabeling/CHANGES.md | 7 + dataplex/CHANGES.md | 17 ++ dataplex/internal/version.go | 2 +- dataproc/CHANGES.md | 7 + dataproc/internal/version.go | 2 +- dataqna/CHANGES.md | 7 + datastream/CHANGES.md | 7 + deploy/CHANGES.md | 7 + deploy/internal/version.go | 2 +- developerconnect/CHANGES.md | 7 + developerconnect/internal/version.go | 2 +- dialogflow/CHANGES.md | 7 + dialogflow/internal/version.go | 2 +- discoveryengine/CHANGES.md | 7 + discoveryengine/internal/version.go | 2 +- dlp/CHANGES.md | 7 + dlp/internal/version.go | 2 +- documentai/CHANGES.md | 7 + documentai/internal/version.go | 2 +- domains/CHANGES.md | 7 + edgecontainer/CHANGES.md | 7 + edgecontainer/internal/version.go | 2 +- edgenetwork/CHANGES.md | 7 + edgenetwork/internal/version.go | 2 +- essentialcontacts/CHANGES.md | 7 + eventarc/CHANGES.md | 7 + filestore/CHANGES.md | 7 + filestore/internal/version.go | 2 +- functions/CHANGES.md | 7 + functions/internal/version.go | 2 +- gkebackup/CHANGES.md | 7 + gkebackup/internal/version.go | 2 +- gkeconnect/CHANGES.md | 7 + gkehub/CHANGES.md | 7 + gkemulticloud/CHANGES.md | 18 ++ gkemulticloud/internal/version.go | 2 +- grafeas/CHANGES.md | 7 + gsuiteaddons/CHANGES.md | 7 + iam/CHANGES.md | 7 + iap/CHANGES.md | 7 + identitytoolkit/CHANGES.md | 7 + identitytoolkit/internal/version.go | 2 +- ids/CHANGES.md | 7 + iot/CHANGES.md | 7 + kms/CHANGES.md | 7 + kms/internal/version.go | 2 +- language/CHANGES.md | 7 + language/internal/version.go | 2 +- lifesciences/CHANGES.md | 7 + longrunning/CHANGES.md | 7 + managedidentities/CHANGES.md | 7 + managedkafka/CHANGES.md | 7 + managedkafka/internal/version.go | 2 +- maps/CHANGES.md | 7 + maps/internal/version.go | 2 +- mediatranslation/CHANGES.md | 7 + memcache/CHANGES.md | 7 + memorystore/CHANGES.md | 7 + memorystore/internal/version.go | 2 +- metastore/CHANGES.md | 7 + migrationcenter/CHANGES.md | 7 + migrationcenter/internal/version.go | 2 +- monitoring/CHANGES.md | 7 + monitoring/internal/version.go | 2 +- netapp/CHANGES.md | 7 + netapp/internal/version.go | 2 +- networkconnectivity/CHANGES.md | 7 + networkmanagement/CHANGES.md | 7 + networkmanagement/internal/version.go | 2 +- networksecurity/CHANGES.md | 7 + networkservices/CHANGES.md | 7 + networkservices/internal/version.go | 2 +- notebooks/CHANGES.md | 7 + optimization/CHANGES.md | 7 + oracledatabase/CHANGES.md | 7 + oracledatabase/internal/version.go | 2 +- orchestration/CHANGES.md | 7 + orchestration/internal/version.go | 2 +- orgpolicy/CHANGES.md | 7 + orgpolicy/internal/version.go | 2 +- osconfig/CHANGES.md | 7 + osconfig/internal/version.go | 2 +- oslogin/CHANGES.md | 7 + oslogin/internal/version.go | 2 +- parallelstore/CHANGES.md | 14 + parallelstore/internal/version.go | 2 +- phishingprotection/CHANGES.md | 7 + policysimulator/CHANGES.md | 7 + policytroubleshooter/CHANGES.md | 7 + privatecatalog/CHANGES.md | 7 + privilegedaccessmanager/CHANGES.md | 7 + privilegedaccessmanager/internal/version.go | 2 +- rapidmigrationassessment/CHANGES.md | 7 + recaptchaenterprise/CHANGES.md | 7 + recaptchaenterprise/internal/version.go | 2 +- recommendationengine/CHANGES.md | 7 + recommender/CHANGES.md | 7 + recommender/internal/version.go | 2 +- redis/CHANGES.md | 7 + redis/internal/version.go | 2 +- resourcemanager/CHANGES.md | 7 + resourcesettings/CHANGES.md | 7 + resourcesettings/internal/version.go | 2 +- retail/CHANGES.md | 7 + retail/internal/version.go | 2 +- run/CHANGES.md | 7 + scheduler/CHANGES.md | 7 + secretmanager/CHANGES.md | 7 + secretmanager/internal/version.go | 2 +- securesourcemanager/CHANGES.md | 7 + securesourcemanager/internal/version.go | 2 +- security/CHANGES.md | 7 + security/internal/version.go | 2 +- securitycenter/CHANGES.md | 7 + securitycenter/internal/version.go | 2 +- securitycentermanagement/CHANGES.md | 7 + securitycentermanagement/internal/version.go | 2 +- securityposture/CHANGES.md | 7 + securityposture/internal/version.go | 2 +- servicecontrol/CHANGES.md | 7 + servicecontrol/internal/version.go | 2 +- servicedirectory/CHANGES.md | 7 + servicehealth/CHANGES.md | 12 + servicehealth/internal/version.go | 2 +- servicemanagement/CHANGES.md | 7 + serviceusage/CHANGES.md | 7 + shell/CHANGES.md | 7 + shopping/CHANGES.md | 29 ++ shopping/internal/version.go | 2 +- speech/CHANGES.md | 17 ++ speech/internal/version.go | 2 +- storageinsights/CHANGES.md | 7 + storagetransfer/CHANGES.md | 7 + streetview/CHANGES.md | 7 + streetview/internal/version.go | 2 +- support/CHANGES.md | 7 + talent/CHANGES.md | 7 + telcoautomation/CHANGES.md | 7 + telcoautomation/internal/version.go | 2 +- texttospeech/CHANGES.md | 7 + tpu/CHANGES.md | 7 + trace/CHANGES.md | 7 + translate/CHANGES.md | 7 + translate/internal/version.go | 2 +- video/CHANGES.md | 7 + video/internal/version.go | 2 +- videointelligence/CHANGES.md | 7 + vision/CHANGES.md | 7 + vision/internal/version.go | 2 +- visionai/CHANGES.md | 7 + visionai/internal/version.go | 2 +- vmmigration/CHANGES.md | 7 + vmwareengine/CHANGES.md | 7 + vmwareengine/internal/version.go | 2 +- vpcaccess/CHANGES.md | 7 + webrisk/CHANGES.md | 7 + websecurityscanner/CHANGES.md | 7 + workflows/CHANGES.md | 7 + workstations/CHANGES.md | 7 + workstations/internal/version.go | 2 +- 230 files changed, 1342 insertions(+), 229 deletions(-) diff --git a/.release-please-manifest-submodules.json b/.release-please-manifest-submodules.json index 0c8cc178b741..36b0c323392e 100644 --- a/.release-please-manifest-submodules.json +++ b/.release-please-manifest-submodules.json @@ -1,154 +1,154 @@ { - "accessapproval": "1.8.2", - "accesscontextmanager": "1.9.2", - "advisorynotifications": "1.5.2", + "accessapproval": "1.8.3", + "accesscontextmanager": "1.9.3", + "advisorynotifications": "1.5.3", "ai": "0.9.0", "aiplatform": "1.69.0", - "alloydb": "1.14.0", - "analytics": "0.25.2", - "apigateway": "1.7.2", - "apigeeconnect": "1.7.2", - "apigeeregistry": "0.9.2", - "apihub": "0.1.2", - "apikeys": "1.2.2", - "appengine": "1.9.2", - "apphub": "0.2.2", - "apps": "0.5.2", - "area120": "0.9.2", - "artifactregistry": "1.16.0", - "asset": "1.20.3", - "assuredworkloads": "1.12.2", - "automl": "1.14.3", - "backupdr": "1.2.1", - "baremetalsolution": "1.3.2", - "batch": "1.11.4", - "beyondcorp": "1.1.2", - "billing": "1.20.0", - "binaryauthorization": "1.9.2", - "certificatemanager": "1.9.2", - "channel": "1.19.1", - "chat": "0.9.0", - "cloudbuild": "1.19.1", - "cloudcontrolspartner": "1.2.1", - "clouddms": "1.8.2", - "cloudprofiler": "0.4.2", - "cloudquotas": "1.2.0", - "cloudtasks": "1.13.2", - "commerce": "1.2.1", - "compute": "1.31.0", + "alloydb": "1.14.1", + "analytics": "0.25.3", + "apigateway": "1.7.3", + "apigeeconnect": "1.7.3", + "apigeeregistry": "0.9.3", + "apihub": "0.1.3", + "apikeys": "1.2.3", + "appengine": "1.9.3", + "apphub": "0.2.3", + "apps": "0.5.3", + "area120": "0.9.3", + "artifactregistry": "1.16.1", + "asset": "1.20.4", + "assuredworkloads": "1.12.3", + "automl": "1.14.4", + "backupdr": "1.2.2", + "baremetalsolution": "1.3.3", + "batch": "1.11.5", + "beyondcorp": "1.1.3", + "billing": "1.20.1", + "binaryauthorization": "1.9.3", + "certificatemanager": "1.9.3", + "channel": "1.19.2", + "chat": "0.9.1", + "cloudbuild": "1.19.2", + "cloudcontrolspartner": "1.2.2", + "clouddms": "1.8.3", + "cloudprofiler": "0.4.3", + "cloudquotas": "1.2.1", + "cloudtasks": "1.13.3", + "commerce": "1.2.2", + "compute": "1.31.1", "compute/metadata": "0.6.0", - "confidentialcomputing": "1.8.0", - "config": "1.2.0", - "contactcenterinsights": "1.17.0", - "container": "1.42.0", - "containeranalysis": "0.13.2", - "datacatalog": "1.24.1", - "dataflow": "0.10.2", - "dataform": "0.10.2", - "datafusion": "1.8.2", - "datalabeling": "0.9.2", - "dataplex": "1.20.0", - "dataproc": "2.10.0", - "dataqna": "0.9.2", - "datastream": "1.12.0", - "deploy": "1.26.0", - "developerconnect": "0.3.0", - "dialogflow": "1.64.0", - "discoveryengine": "1.16.0", - "dlp": "1.20.0", - "documentai": "1.35.0", - "domains": "0.10.2", - "edgecontainer": "1.4.0", - "edgenetwork": "1.2.2", - "essentialcontacts": "1.7.2", - "eventarc": "1.15.0", - "filestore": "1.9.2", - "functions": "1.19.2", - "gkebackup": "1.6.2", - "gkeconnect": "0.12.0", - "gkehub": "0.15.2", - "gkemulticloud": "1.4.1", - "grafeas": "0.3.12", - "gsuiteaddons": "1.7.2", - "iam": "1.3.0", - "iap": "1.10.2", - "identitytoolkit": "0.2.2", - "ids": "1.5.2", - "iot": "1.8.2", - "kms": "1.20.3", - "language": "1.14.2", - "lifesciences": "0.10.2", - "longrunning": "0.6.3", - "managedidentities": "1.7.2", - "managedkafka": "0.3.0", - "maps": "1.17.0", - "mediatranslation": "0.9.2", - "memcache": "1.11.2", - "memorystore": "0.1.0", - "metastore": "1.14.2", - "migrationcenter": "1.1.2", - "monitoring": "1.22.0", - "netapp": "1.5.0", - "networkconnectivity": "1.16.0", - "networkmanagement": "1.17.0", - "networksecurity": "0.10.2", - "networkservices": "0.2.2", - "notebooks": "1.12.2", - "optimization": "1.7.2", - "oracledatabase": "0.1.2", - "orchestration": "1.11.2", - "orgpolicy": "1.14.1", - "osconfig": "1.14.2", - "oslogin": "1.14.2", - "parallelstore": "0.9.0", - "phishingprotection": "0.9.2", - "policysimulator": "0.3.2", - "policytroubleshooter": "1.11.2", - "privatecatalog": "0.10.2", - "privilegedaccessmanager": "0.2.2", - "rapidmigrationassessment": "1.1.2", - "recaptchaenterprise": "2.19.1", - "recommendationengine": "0.9.2", - "recommender": "1.13.2", - "redis": "1.17.2", - "resourcemanager": "1.10.2", - "resourcesettings": "1.8.2", - "retail": "1.19.1", - "run": "1.8.0", - "scheduler": "1.11.2", - "secretmanager": "1.14.2", - "securesourcemanager": "1.3.0", - "security": "1.18.2", - "securitycenter": "1.35.2", - "securitycentermanagement": "1.1.2", - "securityposture": "0.2.2", - "servicecontrol": "1.14.2", - "servicedirectory": "1.12.2", - "servicehealth": "1.2.0", - "servicemanagement": "1.10.2", - "serviceusage": "1.9.2", - "shell": "1.8.2", - "shopping": "0.14.0", - "speech": "1.25.2", - "storageinsights": "1.1.2", - "storagetransfer": "1.12.0", - "streetview": "0.2.2", - "support": "1.1.2", - "talent": "1.7.2", - "telcoautomation": "1.1.2", - "texttospeech": "1.10.0", - "tpu": "1.7.2", - "trace": "1.11.2", - "translate": "1.12.2", - "video": "1.23.2", - "videointelligence": "1.12.2", - "vision": "2.9.2", - "visionai": "0.4.2", - "vmmigration": "1.8.2", - "vmwareengine": "1.3.2", - "vpcaccess": "1.8.2", - "webrisk": "1.10.2", - "websecurityscanner": "1.7.2", - "workflows": "1.13.2", - "workstations": "1.1.2" + "confidentialcomputing": "1.8.1", + "config": "1.2.1", + "contactcenterinsights": "1.17.1", + "container": "1.42.1", + "containeranalysis": "0.13.3", + "datacatalog": "1.24.2", + "dataflow": "0.10.3", + "dataform": "0.10.3", + "datafusion": "1.8.3", + "datalabeling": "0.9.3", + "dataplex": "1.21.0", + "dataproc": "2.10.1", + "dataqna": "0.9.3", + "datastream": "1.12.1", + "deploy": "1.26.1", + "developerconnect": "0.3.1", + "dialogflow": "1.64.1", + "discoveryengine": "1.16.1", + "dlp": "1.20.1", + "documentai": "1.35.1", + "domains": "0.10.3", + "edgecontainer": "1.4.1", + "edgenetwork": "1.2.3", + "essentialcontacts": "1.7.3", + "eventarc": "1.15.1", + "filestore": "1.9.3", + "functions": "1.19.3", + "gkebackup": "1.6.3", + "gkeconnect": "0.12.1", + "gkehub": "0.15.3", + "gkemulticloud": "1.5.0", + "grafeas": "0.3.13", + "gsuiteaddons": "1.7.3", + "iam": "1.3.1", + "iap": "1.10.3", + "identitytoolkit": "0.2.3", + "ids": "1.5.3", + "iot": "1.8.3", + "kms": "1.20.4", + "language": "1.14.3", + "lifesciences": "0.10.3", + "longrunning": "0.6.4", + "managedidentities": "1.7.3", + "managedkafka": "0.3.1", + "maps": "1.17.1", + "mediatranslation": "0.9.3", + "memcache": "1.11.3", + "memorystore": "0.1.1", + "metastore": "1.14.3", + "migrationcenter": "1.1.3", + "monitoring": "1.22.1", + "netapp": "1.5.1", + "networkconnectivity": "1.16.1", + "networkmanagement": "1.17.1", + "networksecurity": "0.10.3", + "networkservices": "0.2.3", + "notebooks": "1.12.3", + "optimization": "1.7.3", + "oracledatabase": "0.1.3", + "orchestration": "1.11.3", + "orgpolicy": "1.14.2", + "osconfig": "1.14.3", + "oslogin": "1.14.3", + "parallelstore": "0.9.1", + "phishingprotection": "0.9.3", + "policysimulator": "0.3.3", + "policytroubleshooter": "1.11.3", + "privatecatalog": "0.10.3", + "privilegedaccessmanager": "0.2.3", + "rapidmigrationassessment": "1.1.3", + "recaptchaenterprise": "2.19.2", + "recommendationengine": "0.9.3", + "recommender": "1.13.3", + "redis": "1.17.3", + "resourcemanager": "1.10.3", + "resourcesettings": "1.8.3", + "retail": "1.19.2", + "run": "1.8.1", + "scheduler": "1.11.3", + "secretmanager": "1.14.3", + "securesourcemanager": "1.3.1", + "security": "1.18.3", + "securitycenter": "1.35.3", + "securitycentermanagement": "1.1.3", + "securityposture": "0.2.3", + "servicecontrol": "1.14.3", + "servicedirectory": "1.12.3", + "servicehealth": "1.2.1", + "servicemanagement": "1.10.3", + "serviceusage": "1.9.3", + "shell": "1.8.3", + "shopping": "0.15.0", + "speech": "1.26.0", + "storageinsights": "1.1.3", + "storagetransfer": "1.12.1", + "streetview": "0.2.3", + "support": "1.1.3", + "talent": "1.7.3", + "telcoautomation": "1.1.3", + "texttospeech": "1.10.1", + "tpu": "1.7.3", + "trace": "1.11.3", + "translate": "1.12.3", + "video": "1.23.3", + "videointelligence": "1.12.3", + "vision": "2.9.3", + "visionai": "0.4.3", + "vmmigration": "1.8.3", + "vmwareengine": "1.3.3", + "vpcaccess": "1.8.3", + "webrisk": "1.10.3", + "websecurityscanner": "1.7.3", + "workflows": "1.13.3", + "workstations": "1.1.3" } diff --git a/accessapproval/CHANGES.md b/accessapproval/CHANGES.md index a02fbeb11a8a..72c898677025 100644 --- a/accessapproval/CHANGES.md +++ b/accessapproval/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.8.3](https://github.com/googleapis/google-cloud-go/compare/accessapproval/v1.8.2...accessapproval/v1.8.3) (2025-01-02) + + +### Bug Fixes + +* **accessapproval:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.8.2](https://github.com/googleapis/google-cloud-go/compare/accessapproval/v1.8.1...accessapproval/v1.8.2) (2024-10-23) diff --git a/accesscontextmanager/CHANGES.md b/accesscontextmanager/CHANGES.md index 12e045a32b0d..96ce56f273a6 100644 --- a/accesscontextmanager/CHANGES.md +++ b/accesscontextmanager/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.9.3](https://github.com/googleapis/google-cloud-go/compare/accesscontextmanager/v1.9.2...accesscontextmanager/v1.9.3) (2025-01-02) + + +### Bug Fixes + +* **accesscontextmanager:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.9.2](https://github.com/googleapis/google-cloud-go/compare/accesscontextmanager/v1.9.1...accesscontextmanager/v1.9.2) (2024-10-23) diff --git a/advisorynotifications/CHANGES.md b/advisorynotifications/CHANGES.md index d28ef749f5c4..d3de50b4079d 100644 --- a/advisorynotifications/CHANGES.md +++ b/advisorynotifications/CHANGES.md @@ -1,6 +1,13 @@ # Changelog +## [1.5.3](https://github.com/googleapis/google-cloud-go/compare/advisorynotifications/v1.5.2...advisorynotifications/v1.5.3) (2025-01-02) + + +### Bug Fixes + +* **advisorynotifications:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.5.2](https://github.com/googleapis/google-cloud-go/compare/advisorynotifications/v1.5.1...advisorynotifications/v1.5.2) (2024-10-23) diff --git a/advisorynotifications/internal/version.go b/advisorynotifications/internal/version.go index 1b05760aac16..bf08d0d9ad6b 100644 --- a/advisorynotifications/internal/version.go +++ b/advisorynotifications/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.5.2" +const Version = "1.5.3" diff --git a/alloydb/CHANGES.md b/alloydb/CHANGES.md index 735f7c9b1c07..708b6117516f 100644 --- a/alloydb/CHANGES.md +++ b/alloydb/CHANGES.md @@ -2,6 +2,13 @@ +## [1.14.1](https://github.com/googleapis/google-cloud-go/compare/alloydb/v1.14.0...alloydb/v1.14.1) (2025-01-02) + + +### Bug Fixes + +* **alloydb:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.14.0](https://github.com/googleapis/google-cloud-go/compare/alloydb/v1.13.0...alloydb/v1.14.0) (2024-11-14) diff --git a/alloydb/internal/version.go b/alloydb/internal/version.go index fdc89470d056..b09aaed7fddd 100644 --- a/alloydb/internal/version.go +++ b/alloydb/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.14.0" +const Version = "1.14.1" diff --git a/analytics/CHANGES.md b/analytics/CHANGES.md index 912a1b89f0d4..92df4c6083f7 100644 --- a/analytics/CHANGES.md +++ b/analytics/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [0.25.3](https://github.com/googleapis/google-cloud-go/compare/analytics/v0.25.2...analytics/v0.25.3) (2025-01-02) + + +### Bug Fixes + +* **analytics:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.25.2](https://github.com/googleapis/google-cloud-go/compare/analytics/v0.25.1...analytics/v0.25.2) (2024-10-23) diff --git a/analytics/internal/version.go b/analytics/internal/version.go index 697414b2021a..c0a91edf3063 100644 --- a/analytics/internal/version.go +++ b/analytics/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "0.25.2" +const Version = "0.25.3" diff --git a/apigateway/CHANGES.md b/apigateway/CHANGES.md index d8865498a56f..430121a0056f 100644 --- a/apigateway/CHANGES.md +++ b/apigateway/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.7.3](https://github.com/googleapis/google-cloud-go/compare/apigateway/v1.7.2...apigateway/v1.7.3) (2025-01-02) + + +### Bug Fixes + +* **apigateway:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.7.2](https://github.com/googleapis/google-cloud-go/compare/apigateway/v1.7.1...apigateway/v1.7.2) (2024-10-23) diff --git a/apigeeconnect/CHANGES.md b/apigeeconnect/CHANGES.md index 8fb2a6f2f81d..28f5de5eb66b 100644 --- a/apigeeconnect/CHANGES.md +++ b/apigeeconnect/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.7.3](https://github.com/googleapis/google-cloud-go/compare/apigeeconnect/v1.7.2...apigeeconnect/v1.7.3) (2025-01-02) + + +### Bug Fixes + +* **apigeeconnect:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.7.2](https://github.com/googleapis/google-cloud-go/compare/apigeeconnect/v1.7.1...apigeeconnect/v1.7.2) (2024-10-23) diff --git a/apigeeregistry/CHANGES.md b/apigeeregistry/CHANGES.md index 945e5df57dc5..fc46e1594c7c 100644 --- a/apigeeregistry/CHANGES.md +++ b/apigeeregistry/CHANGES.md @@ -1,5 +1,12 @@ # Changelog +## [0.9.3](https://github.com/googleapis/google-cloud-go/compare/apigeeregistry/v0.9.2...apigeeregistry/v0.9.3) (2025-01-02) + + +### Bug Fixes + +* **apigeeregistry:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.9.2](https://github.com/googleapis/google-cloud-go/compare/apigeeregistry/v0.9.1...apigeeregistry/v0.9.2) (2024-10-23) diff --git a/apihub/CHANGES.md b/apihub/CHANGES.md index d1634594cdb5..0b94cc5741be 100644 --- a/apihub/CHANGES.md +++ b/apihub/CHANGES.md @@ -1,5 +1,12 @@ # Changelog +## [0.1.3](https://github.com/googleapis/google-cloud-go/compare/apihub/v0.1.2...apihub/v0.1.3) (2025-01-02) + + +### Bug Fixes + +* **apihub:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.1.2](https://github.com/googleapis/google-cloud-go/compare/apihub/v0.1.1...apihub/v0.1.2) (2024-10-23) diff --git a/apihub/internal/version.go b/apihub/internal/version.go index 7196f28b8f6e..14256f5b3c99 100644 --- a/apihub/internal/version.go +++ b/apihub/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "0.1.2" +const Version = "0.1.3" diff --git a/apikeys/CHANGES.md b/apikeys/CHANGES.md index e1fb7f431539..00345e842e4f 100644 --- a/apikeys/CHANGES.md +++ b/apikeys/CHANGES.md @@ -1,6 +1,13 @@ # Changelog +## [1.2.3](https://github.com/googleapis/google-cloud-go/compare/apikeys/v1.2.2...apikeys/v1.2.3) (2025-01-02) + + +### Bug Fixes + +* **apikeys:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.2.2](https://github.com/googleapis/google-cloud-go/compare/apikeys/v1.2.1...apikeys/v1.2.2) (2024-10-23) diff --git a/appengine/CHANGES.md b/appengine/CHANGES.md index be9470f94135..c8495aa6e432 100644 --- a/appengine/CHANGES.md +++ b/appengine/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.9.3](https://github.com/googleapis/google-cloud-go/compare/appengine/v1.9.2...appengine/v1.9.3) (2025-01-02) + + +### Bug Fixes + +* **appengine:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.9.2](https://github.com/googleapis/google-cloud-go/compare/appengine/v1.9.1...appengine/v1.9.2) (2024-10-23) diff --git a/apphub/CHANGES.md b/apphub/CHANGES.md index de265d985053..1d2614a94116 100644 --- a/apphub/CHANGES.md +++ b/apphub/CHANGES.md @@ -1,5 +1,12 @@ # Changelog +## [0.2.3](https://github.com/googleapis/google-cloud-go/compare/apphub/v0.2.2...apphub/v0.2.3) (2025-01-02) + + +### Bug Fixes + +* **apphub:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.2.2](https://github.com/googleapis/google-cloud-go/compare/apphub/v0.2.1...apphub/v0.2.2) (2024-10-23) diff --git a/apphub/internal/version.go b/apphub/internal/version.go index 8d343af28cdf..37101c109e28 100644 --- a/apphub/internal/version.go +++ b/apphub/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "0.2.2" +const Version = "0.2.3" diff --git a/apps/CHANGES.md b/apps/CHANGES.md index d2fec839ee9b..0972907c32b7 100644 --- a/apps/CHANGES.md +++ b/apps/CHANGES.md @@ -1,5 +1,12 @@ # Changelog +## [0.5.3](https://github.com/googleapis/google-cloud-go/compare/apps/v0.5.2...apps/v0.5.3) (2025-01-02) + + +### Bug Fixes + +* **apps:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.5.2](https://github.com/googleapis/google-cloud-go/compare/apps/v0.5.1...apps/v0.5.2) (2024-10-23) diff --git a/apps/internal/version.go b/apps/internal/version.go index cd122fe1e37a..50b6b0abbcdc 100644 --- a/apps/internal/version.go +++ b/apps/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "0.5.2" +const Version = "0.5.3" diff --git a/area120/CHANGES.md b/area120/CHANGES.md index fa72b5719184..4a45da0529b0 100644 --- a/area120/CHANGES.md +++ b/area120/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [0.9.3](https://github.com/googleapis/google-cloud-go/compare/area120/v0.9.2...area120/v0.9.3) (2025-01-02) + + +### Bug Fixes + +* **area120:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.9.2](https://github.com/googleapis/google-cloud-go/compare/area120/v0.9.1...area120/v0.9.2) (2024-10-23) diff --git a/artifactregistry/CHANGES.md b/artifactregistry/CHANGES.md index 3fa60308886c..0f93b894010b 100644 --- a/artifactregistry/CHANGES.md +++ b/artifactregistry/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.16.1](https://github.com/googleapis/google-cloud-go/compare/artifactregistry/v1.16.0...artifactregistry/v1.16.1) (2025-01-02) + + +### Bug Fixes + +* **artifactregistry:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.16.0](https://github.com/googleapis/google-cloud-go/compare/artifactregistry/v1.15.2...artifactregistry/v1.16.0) (2024-11-06) diff --git a/asset/CHANGES.md b/asset/CHANGES.md index 81ebeab63a1c..b018e1cee4fe 100644 --- a/asset/CHANGES.md +++ b/asset/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.20.4](https://github.com/googleapis/google-cloud-go/compare/asset/v1.20.3...asset/v1.20.4) (2025-01-02) + + +### Bug Fixes + +* **asset:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.20.3](https://github.com/googleapis/google-cloud-go/compare/asset/v1.20.2...asset/v1.20.3) (2024-10-23) diff --git a/asset/internal/version.go b/asset/internal/version.go index a8a51fdaa7a2..b3799f0518e5 100644 --- a/asset/internal/version.go +++ b/asset/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.20.3" +const Version = "1.20.4" diff --git a/assuredworkloads/CHANGES.md b/assuredworkloads/CHANGES.md index a4e07479f380..d279ae79deb1 100644 --- a/assuredworkloads/CHANGES.md +++ b/assuredworkloads/CHANGES.md @@ -1,6 +1,13 @@ # Changes +## [1.12.3](https://github.com/googleapis/google-cloud-go/compare/assuredworkloads/v1.12.2...assuredworkloads/v1.12.3) (2025-01-02) + + +### Bug Fixes + +* **assuredworkloads:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.12.2](https://github.com/googleapis/google-cloud-go/compare/assuredworkloads/v1.12.1...assuredworkloads/v1.12.2) (2024-10-23) diff --git a/automl/CHANGES.md b/automl/CHANGES.md index 789a9572b205..2035058860f6 100644 --- a/automl/CHANGES.md +++ b/automl/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.14.4](https://github.com/googleapis/google-cloud-go/compare/automl/v1.14.3...automl/v1.14.4) (2025-01-02) + + +### Bug Fixes + +* **automl:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.14.3](https://github.com/googleapis/google-cloud-go/compare/automl/v1.14.2...automl/v1.14.3) (2024-12-11) diff --git a/backupdr/CHANGES.md b/backupdr/CHANGES.md index d9ae5fbdabe9..f073bf97bc6a 100644 --- a/backupdr/CHANGES.md +++ b/backupdr/CHANGES.md @@ -2,6 +2,13 @@ +## [1.2.2](https://github.com/googleapis/google-cloud-go/compare/backupdr/v1.2.1...backupdr/v1.2.2) (2025-01-02) + + +### Bug Fixes + +* **backupdr:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.2.1](https://github.com/googleapis/google-cloud-go/compare/backupdr/v1.2.0...backupdr/v1.2.1) (2024-10-23) diff --git a/backupdr/internal/version.go b/backupdr/internal/version.go index a479f896e666..095cfc163e0f 100644 --- a/backupdr/internal/version.go +++ b/backupdr/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.2.1" +const Version = "1.2.2" diff --git a/baremetalsolution/CHANGES.md b/baremetalsolution/CHANGES.md index 6f0ffb473e2c..5d5158eb391f 100644 --- a/baremetalsolution/CHANGES.md +++ b/baremetalsolution/CHANGES.md @@ -1,6 +1,13 @@ # Changelog +## [1.3.3](https://github.com/googleapis/google-cloud-go/compare/baremetalsolution/v1.3.2...baremetalsolution/v1.3.3) (2025-01-02) + + +### Bug Fixes + +* **baremetalsolution:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.3.2](https://github.com/googleapis/google-cloud-go/compare/baremetalsolution/v1.3.1...baremetalsolution/v1.3.2) (2024-10-23) diff --git a/batch/CHANGES.md b/batch/CHANGES.md index 234e05aa22f4..10d6f5fe4f6a 100644 --- a/batch/CHANGES.md +++ b/batch/CHANGES.md @@ -1,6 +1,18 @@ # Changelog +## [1.11.5](https://github.com/googleapis/google-cloud-go/compare/batch/v1.11.4...batch/v1.11.5) (2025-01-02) + + +### Bug Fixes + +* **batch:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + + +### Documentation + +* **batch:** Fix broken references in comments ([#11316](https://github.com/googleapis/google-cloud-go/issues/11316)) ([8ebcc6d](https://github.com/googleapis/google-cloud-go/commit/8ebcc6d276fc881c3914b5a7af3265a04e718e45)) + ## [1.11.4](https://github.com/googleapis/google-cloud-go/compare/batch/v1.11.3...batch/v1.11.4) (2024-12-11) diff --git a/batch/internal/version.go b/batch/internal/version.go index 5be41863ed25..7e6270d86a7b 100644 --- a/batch/internal/version.go +++ b/batch/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.11.4" +const Version = "1.11.5" diff --git a/beyondcorp/CHANGES.md b/beyondcorp/CHANGES.md index 172a85328e8a..58f9b89a4229 100644 --- a/beyondcorp/CHANGES.md +++ b/beyondcorp/CHANGES.md @@ -1,6 +1,13 @@ # Changelog +## [1.1.3](https://github.com/googleapis/google-cloud-go/compare/beyondcorp/v1.1.2...beyondcorp/v1.1.3) (2025-01-02) + + +### Bug Fixes + +* **beyondcorp:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.1.2](https://github.com/googleapis/google-cloud-go/compare/beyondcorp/v1.1.1...beyondcorp/v1.1.2) (2024-10-23) diff --git a/billing/CHANGES.md b/billing/CHANGES.md index f2ffed3bbb52..a19e8b8ec787 100644 --- a/billing/CHANGES.md +++ b/billing/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.20.1](https://github.com/googleapis/google-cloud-go/compare/billing/v1.20.0...billing/v1.20.1) (2025-01-02) + + +### Bug Fixes + +* **billing:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.20.0](https://github.com/googleapis/google-cloud-go/compare/billing/v1.19.2...billing/v1.20.0) (2024-12-04) diff --git a/binaryauthorization/CHANGES.md b/binaryauthorization/CHANGES.md index 29499ee884fb..a8481a5f9ae3 100644 --- a/binaryauthorization/CHANGES.md +++ b/binaryauthorization/CHANGES.md @@ -1,6 +1,13 @@ # Changes +## [1.9.3](https://github.com/googleapis/google-cloud-go/compare/binaryauthorization/v1.9.2...binaryauthorization/v1.9.3) (2025-01-02) + + +### Bug Fixes + +* **binaryauthorization:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.9.2](https://github.com/googleapis/google-cloud-go/compare/binaryauthorization/v1.9.1...binaryauthorization/v1.9.2) (2024-10-23) diff --git a/binaryauthorization/internal/version.go b/binaryauthorization/internal/version.go index 0d65872417b6..c754de783b4e 100644 --- a/binaryauthorization/internal/version.go +++ b/binaryauthorization/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.9.2" +const Version = "1.9.3" diff --git a/certificatemanager/CHANGES.md b/certificatemanager/CHANGES.md index 4d3d65879cf6..07b0f2a44eec 100644 --- a/certificatemanager/CHANGES.md +++ b/certificatemanager/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.9.3](https://github.com/googleapis/google-cloud-go/compare/certificatemanager/v1.9.2...certificatemanager/v1.9.3) (2025-01-02) + + +### Bug Fixes + +* **certificatemanager:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.9.2](https://github.com/googleapis/google-cloud-go/compare/certificatemanager/v1.9.1...certificatemanager/v1.9.2) (2024-10-23) diff --git a/certificatemanager/internal/version.go b/certificatemanager/internal/version.go index 5b397889d866..16975147820e 100644 --- a/certificatemanager/internal/version.go +++ b/certificatemanager/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.9.2" +const Version = "1.9.3" diff --git a/channel/CHANGES.md b/channel/CHANGES.md index 6f216b0a5837..cfdefea84e23 100644 --- a/channel/CHANGES.md +++ b/channel/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.19.2](https://github.com/googleapis/google-cloud-go/compare/channel/v1.19.1...channel/v1.19.2) (2025-01-02) + + +### Bug Fixes + +* **channel:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.19.1](https://github.com/googleapis/google-cloud-go/compare/channel/v1.19.0...channel/v1.19.1) (2024-10-23) diff --git a/chat/CHANGES.md b/chat/CHANGES.md index 424e47da095e..3e6b839fc691 100644 --- a/chat/CHANGES.md +++ b/chat/CHANGES.md @@ -1,5 +1,12 @@ # Changelog +## [0.9.1](https://github.com/googleapis/google-cloud-go/compare/chat/v0.9.0...chat/v0.9.1) (2025-01-02) + + +### Bug Fixes + +* **chat:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.9.0](https://github.com/googleapis/google-cloud-go/compare/chat/v0.8.0...chat/v0.9.0) (2024-12-11) diff --git a/chat/internal/version.go b/chat/internal/version.go index 34e4a80edf09..2d3b14c67e41 100644 --- a/chat/internal/version.go +++ b/chat/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "0.9.0" +const Version = "0.9.1" diff --git a/cloudbuild/CHANGES.md b/cloudbuild/CHANGES.md index f97ef74fa96f..6e26d4ded130 100644 --- a/cloudbuild/CHANGES.md +++ b/cloudbuild/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.19.2](https://github.com/googleapis/google-cloud-go/compare/cloudbuild/v1.19.1...cloudbuild/v1.19.2) (2025-01-02) + + +### Bug Fixes + +* **cloudbuild:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.19.1](https://github.com/googleapis/google-cloud-go/compare/cloudbuild/v1.19.0...cloudbuild/v1.19.1) (2024-12-11) diff --git a/cloudbuild/internal/version.go b/cloudbuild/internal/version.go index a5b020992b84..50a4f1c453a7 100644 --- a/cloudbuild/internal/version.go +++ b/cloudbuild/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.19.1" +const Version = "1.19.2" diff --git a/cloudcontrolspartner/CHANGES.md b/cloudcontrolspartner/CHANGES.md index 38a3b08817a4..13003929a807 100644 --- a/cloudcontrolspartner/CHANGES.md +++ b/cloudcontrolspartner/CHANGES.md @@ -2,6 +2,13 @@ +## [1.2.2](https://github.com/googleapis/google-cloud-go/compare/cloudcontrolspartner/v1.2.1...cloudcontrolspartner/v1.2.2) (2025-01-02) + + +### Bug Fixes + +* **cloudcontrolspartner:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.2.1](https://github.com/googleapis/google-cloud-go/compare/cloudcontrolspartner/v1.2.0...cloudcontrolspartner/v1.2.1) (2024-10-23) diff --git a/cloudcontrolspartner/internal/version.go b/cloudcontrolspartner/internal/version.go index a479f896e666..095cfc163e0f 100644 --- a/cloudcontrolspartner/internal/version.go +++ b/cloudcontrolspartner/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.2.1" +const Version = "1.2.2" diff --git a/clouddms/CHANGES.md b/clouddms/CHANGES.md index d71778019324..19295ccc01b2 100644 --- a/clouddms/CHANGES.md +++ b/clouddms/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.8.3](https://github.com/googleapis/google-cloud-go/compare/clouddms/v1.8.2...clouddms/v1.8.3) (2025-01-02) + + +### Bug Fixes + +* **clouddms:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.8.2](https://github.com/googleapis/google-cloud-go/compare/clouddms/v1.8.1...clouddms/v1.8.2) (2024-10-23) diff --git a/cloudprofiler/CHANGES.md b/cloudprofiler/CHANGES.md index 0428a275ff01..4b5733124058 100644 --- a/cloudprofiler/CHANGES.md +++ b/cloudprofiler/CHANGES.md @@ -1,6 +1,13 @@ # Changelog +## [0.4.3](https://github.com/googleapis/google-cloud-go/compare/cloudprofiler/v0.4.2...cloudprofiler/v0.4.3) (2025-01-02) + + +### Bug Fixes + +* **cloudprofiler:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.4.2](https://github.com/googleapis/google-cloud-go/compare/cloudprofiler/v0.4.1...cloudprofiler/v0.4.2) (2024-10-23) diff --git a/cloudprofiler/internal/version.go b/cloudprofiler/internal/version.go index cd226a52f24b..ed2222e18fee 100644 --- a/cloudprofiler/internal/version.go +++ b/cloudprofiler/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "0.4.2" +const Version = "0.4.3" diff --git a/cloudquotas/CHANGES.md b/cloudquotas/CHANGES.md index 024021b7a9d5..6d34909e073b 100644 --- a/cloudquotas/CHANGES.md +++ b/cloudquotas/CHANGES.md @@ -2,6 +2,13 @@ +## [1.2.1](https://github.com/googleapis/google-cloud-go/compare/cloudquotas/v1.2.0...cloudquotas/v1.2.1) (2025-01-02) + + +### Bug Fixes + +* **cloudquotas:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.2.0](https://github.com/googleapis/google-cloud-go/compare/cloudquotas/v1.1.2...cloudquotas/v1.2.0) (2024-11-14) diff --git a/cloudquotas/internal/version.go b/cloudquotas/internal/version.go index edbfc72a8946..a479f896e666 100644 --- a/cloudquotas/internal/version.go +++ b/cloudquotas/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.2.0" +const Version = "1.2.1" diff --git a/cloudtasks/CHANGES.md b/cloudtasks/CHANGES.md index 5642b8663f3e..46c57c8de6f5 100644 --- a/cloudtasks/CHANGES.md +++ b/cloudtasks/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.13.3](https://github.com/googleapis/google-cloud-go/compare/cloudtasks/v1.13.2...cloudtasks/v1.13.3) (2025-01-02) + + +### Bug Fixes + +* **cloudtasks:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.13.2](https://github.com/googleapis/google-cloud-go/compare/cloudtasks/v1.13.1...cloudtasks/v1.13.2) (2024-10-23) diff --git a/commerce/CHANGES.md b/commerce/CHANGES.md index 0cc52d610e57..277a43b6d037 100644 --- a/commerce/CHANGES.md +++ b/commerce/CHANGES.md @@ -1,6 +1,13 @@ # Changelog +## [1.2.2](https://github.com/googleapis/google-cloud-go/compare/commerce/v1.2.1...commerce/v1.2.2) (2025-01-02) + + +### Bug Fixes + +* **commerce:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.2.1](https://github.com/googleapis/google-cloud-go/compare/commerce/v1.2.0...commerce/v1.2.1) (2024-10-23) diff --git a/commerce/internal/version.go b/commerce/internal/version.go index e9cfc3bff1a8..0efd895730e6 100644 --- a/commerce/internal/version.go +++ b/commerce/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.2.1" +const Version = "1.2.2" diff --git a/compute/CHANGES.md b/compute/CHANGES.md index 6f476d677d22..01d199d3e217 100644 --- a/compute/CHANGES.md +++ b/compute/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.31.1](https://github.com/googleapis/google-cloud-go/compare/compute/v1.31.0...compute/v1.31.1) (2025-01-02) + + +### Bug Fixes + +* **compute:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.31.0](https://github.com/googleapis/google-cloud-go/compare/compute/v1.30.0...compute/v1.31.0) (2024-12-13) diff --git a/compute/internal/version.go b/compute/internal/version.go index 9c7380dc515f..e93d90d7f154 100644 --- a/compute/internal/version.go +++ b/compute/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.31.0" +const Version = "1.31.1" diff --git a/confidentialcomputing/CHANGES.md b/confidentialcomputing/CHANGES.md index d8e998f6b630..584112872339 100644 --- a/confidentialcomputing/CHANGES.md +++ b/confidentialcomputing/CHANGES.md @@ -1,6 +1,13 @@ # Changelog +## [1.8.1](https://github.com/googleapis/google-cloud-go/compare/confidentialcomputing/v1.8.0...confidentialcomputing/v1.8.1) (2025-01-02) + + +### Bug Fixes + +* **confidentialcomputing:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.8.0](https://github.com/googleapis/google-cloud-go/compare/confidentialcomputing/v1.7.2...confidentialcomputing/v1.8.0) (2024-12-04) diff --git a/confidentialcomputing/internal/version.go b/confidentialcomputing/internal/version.go index 2380204fa595..73a1a6c6ded2 100644 --- a/confidentialcomputing/internal/version.go +++ b/confidentialcomputing/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.8.0" +const Version = "1.8.1" diff --git a/config/CHANGES.md b/config/CHANGES.md index f4dd6fb80868..c9aee382cbc7 100644 --- a/config/CHANGES.md +++ b/config/CHANGES.md @@ -1,6 +1,13 @@ # Changelog +## [1.2.1](https://github.com/googleapis/google-cloud-go/compare/config/v1.2.0...config/v1.2.1) (2025-01-02) + + +### Bug Fixes + +* **config:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.2.0](https://github.com/googleapis/google-cloud-go/compare/config/v1.1.2...config/v1.2.0) (2024-12-13) diff --git a/config/internal/version.go b/config/internal/version.go index 397121d779b7..e9cfc3bff1a8 100644 --- a/config/internal/version.go +++ b/config/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.2.0" +const Version = "1.2.1" diff --git a/contactcenterinsights/CHANGES.md b/contactcenterinsights/CHANGES.md index 64d38a730b67..4c04177ed21f 100644 --- a/contactcenterinsights/CHANGES.md +++ b/contactcenterinsights/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.17.1](https://github.com/googleapis/google-cloud-go/compare/contactcenterinsights/v1.17.0...contactcenterinsights/v1.17.1) (2025-01-02) + + +### Bug Fixes + +* **contactcenterinsights:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.17.0](https://github.com/googleapis/google-cloud-go/compare/contactcenterinsights/v1.16.0...contactcenterinsights/v1.17.0) (2024-12-18) diff --git a/contactcenterinsights/internal/version.go b/contactcenterinsights/internal/version.go index 6607c695d5cb..2d7d8774486c 100644 --- a/contactcenterinsights/internal/version.go +++ b/contactcenterinsights/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.17.0" +const Version = "1.17.1" diff --git a/container/CHANGES.md b/container/CHANGES.md index 5a68fd179995..eff3eb4ad22d 100644 --- a/container/CHANGES.md +++ b/container/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.42.1](https://github.com/googleapis/google-cloud-go/compare/container/v1.42.0...container/v1.42.1) (2025-01-02) + + +### Bug Fixes + +* **container:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.42.0](https://github.com/googleapis/google-cloud-go/compare/container/v1.41.0...container/v1.42.0) (2024-11-14) diff --git a/container/internal/version.go b/container/internal/version.go index f37b860085c8..aefb58064367 100644 --- a/container/internal/version.go +++ b/container/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.42.0" +const Version = "1.42.1" diff --git a/containeranalysis/CHANGES.md b/containeranalysis/CHANGES.md index d4399833bd93..6fa0ec135f1a 100644 --- a/containeranalysis/CHANGES.md +++ b/containeranalysis/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [0.13.3](https://github.com/googleapis/google-cloud-go/compare/containeranalysis/v0.13.2...containeranalysis/v0.13.3) (2025-01-02) + + +### Bug Fixes + +* **containeranalysis:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.13.2](https://github.com/googleapis/google-cloud-go/compare/containeranalysis/v0.13.1...containeranalysis/v0.13.2) (2024-10-23) diff --git a/containeranalysis/internal/version.go b/containeranalysis/internal/version.go index b039c1da65ea..c19f4abcd8da 100644 --- a/containeranalysis/internal/version.go +++ b/containeranalysis/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "0.13.2" +const Version = "0.13.3" diff --git a/datacatalog/CHANGES.md b/datacatalog/CHANGES.md index a429ad28ecc5..1984f93cdfd1 100644 --- a/datacatalog/CHANGES.md +++ b/datacatalog/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.24.2](https://github.com/googleapis/google-cloud-go/compare/datacatalog/v1.24.1...datacatalog/v1.24.2) (2025-01-02) + + +### Bug Fixes + +* **datacatalog:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.24.1](https://github.com/googleapis/google-cloud-go/compare/datacatalog/v1.24.0...datacatalog/v1.24.1) (2024-12-18) diff --git a/datacatalog/internal/version.go b/datacatalog/internal/version.go index 3e6c62c9201f..e199c1168a15 100644 --- a/datacatalog/internal/version.go +++ b/datacatalog/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.24.1" +const Version = "1.24.2" diff --git a/dataflow/CHANGES.md b/dataflow/CHANGES.md index 065c1f0f8248..81e145036bd4 100644 --- a/dataflow/CHANGES.md +++ b/dataflow/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [0.10.3](https://github.com/googleapis/google-cloud-go/compare/dataflow/v0.10.2...dataflow/v0.10.3) (2025-01-02) + + +### Bug Fixes + +* **dataflow:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.10.2](https://github.com/googleapis/google-cloud-go/compare/dataflow/v0.10.1...dataflow/v0.10.2) (2024-10-23) diff --git a/dataform/CHANGES.md b/dataform/CHANGES.md index c746c6dc9b7f..6ad63630a0b7 100644 --- a/dataform/CHANGES.md +++ b/dataform/CHANGES.md @@ -1,5 +1,12 @@ # Changelog +## [0.10.3](https://github.com/googleapis/google-cloud-go/compare/dataform/v0.10.2...dataform/v0.10.3) (2025-01-02) + + +### Bug Fixes + +* **dataform:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.10.2](https://github.com/googleapis/google-cloud-go/compare/dataform/v0.10.1...dataform/v0.10.2) (2024-10-23) diff --git a/dataform/internal/version.go b/dataform/internal/version.go index 51115991e5c0..4fd65eb8d5e0 100644 --- a/dataform/internal/version.go +++ b/dataform/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "0.10.2" +const Version = "0.10.3" diff --git a/datafusion/CHANGES.md b/datafusion/CHANGES.md index 7b791a0535e3..699f13aea636 100644 --- a/datafusion/CHANGES.md +++ b/datafusion/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.8.3](https://github.com/googleapis/google-cloud-go/compare/datafusion/v1.8.2...datafusion/v1.8.3) (2025-01-02) + + +### Bug Fixes + +* **datafusion:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.8.2](https://github.com/googleapis/google-cloud-go/compare/datafusion/v1.8.1...datafusion/v1.8.2) (2024-10-23) diff --git a/datalabeling/CHANGES.md b/datalabeling/CHANGES.md index ac82b019ba28..f3f66dedaf97 100644 --- a/datalabeling/CHANGES.md +++ b/datalabeling/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [0.9.3](https://github.com/googleapis/google-cloud-go/compare/datalabeling/v0.9.2...datalabeling/v0.9.3) (2025-01-02) + + +### Bug Fixes + +* **datalabeling:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.9.2](https://github.com/googleapis/google-cloud-go/compare/datalabeling/v0.9.1...datalabeling/v0.9.2) (2024-10-23) diff --git a/dataplex/CHANGES.md b/dataplex/CHANGES.md index bc01c963be6e..053ea37abe06 100644 --- a/dataplex/CHANGES.md +++ b/dataplex/CHANGES.md @@ -1,6 +1,23 @@ # Changes +## [1.21.0](https://github.com/googleapis/google-cloud-go/compare/dataplex/v1.20.0...dataplex/v1.21.0) (2025-01-02) + + +### Features + +* **dataplex:** A new field `force` is added to message `.google.cloud.dataplex.v1.DeleteDataScanRequest` ([8ebcc6d](https://github.com/googleapis/google-cloud-go/commit/8ebcc6d276fc881c3914b5a7af3265a04e718e45)) + + +### Bug Fixes + +* **dataplex:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + + +### Documentation + +* **dataplex:** Miscellaneous doc updates ([8ebcc6d](https://github.com/googleapis/google-cloud-go/commit/8ebcc6d276fc881c3914b5a7af3265a04e718e45)) + ## [1.20.0](https://github.com/googleapis/google-cloud-go/compare/dataplex/v1.19.2...dataplex/v1.20.0) (2024-11-19) diff --git a/dataplex/internal/version.go b/dataplex/internal/version.go index 0b0f0e914120..b1672963f6c5 100644 --- a/dataplex/internal/version.go +++ b/dataplex/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.20.0" +const Version = "1.21.0" diff --git a/dataproc/CHANGES.md b/dataproc/CHANGES.md index b30a111391bf..ce73a28367c6 100644 --- a/dataproc/CHANGES.md +++ b/dataproc/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [2.10.1](https://github.com/googleapis/google-cloud-go/compare/dataproc/v2.10.0...dataproc/v2.10.1) (2025-01-02) + + +### Bug Fixes + +* **dataproc:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [2.10.0](https://github.com/googleapis/google-cloud-go/compare/dataproc/v2.9.0...dataproc/v2.10.0) (2024-10-23) diff --git a/dataproc/internal/version.go b/dataproc/internal/version.go index d644ccefd205..bc5e4ec1db0b 100644 --- a/dataproc/internal/version.go +++ b/dataproc/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "2.10.0" +const Version = "2.10.1" diff --git a/dataqna/CHANGES.md b/dataqna/CHANGES.md index 15a1e21fc582..f55bc9cf190f 100644 --- a/dataqna/CHANGES.md +++ b/dataqna/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [0.9.3](https://github.com/googleapis/google-cloud-go/compare/dataqna/v0.9.2...dataqna/v0.9.3) (2025-01-02) + + +### Bug Fixes + +* **dataqna:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.9.2](https://github.com/googleapis/google-cloud-go/compare/dataqna/v0.9.1...dataqna/v0.9.2) (2024-10-23) diff --git a/datastream/CHANGES.md b/datastream/CHANGES.md index 4260f3680539..01d184947fe4 100644 --- a/datastream/CHANGES.md +++ b/datastream/CHANGES.md @@ -1,6 +1,13 @@ # Changes +## [1.12.1](https://github.com/googleapis/google-cloud-go/compare/datastream/v1.12.0...datastream/v1.12.1) (2025-01-02) + + +### Bug Fixes + +* **datastream:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.12.0](https://github.com/googleapis/google-cloud-go/compare/datastream/v1.11.2...datastream/v1.12.0) (2024-11-21) diff --git a/deploy/CHANGES.md b/deploy/CHANGES.md index 88362fa57b8a..6b171bc62ff2 100644 --- a/deploy/CHANGES.md +++ b/deploy/CHANGES.md @@ -1,6 +1,13 @@ # Changes +## [1.26.1](https://github.com/googleapis/google-cloud-go/compare/deploy/v1.26.0...deploy/v1.26.1) (2025-01-02) + + +### Bug Fixes + +* **deploy:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.26.0](https://github.com/googleapis/google-cloud-go/compare/deploy/v1.25.1...deploy/v1.26.0) (2024-12-04) diff --git a/deploy/internal/version.go b/deploy/internal/version.go index dc70dd2f630d..1cfdbafc0b85 100644 --- a/deploy/internal/version.go +++ b/deploy/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.26.0" +const Version = "1.26.1" diff --git a/developerconnect/CHANGES.md b/developerconnect/CHANGES.md index a8dc341388a7..4ff8e0d5214f 100644 --- a/developerconnect/CHANGES.md +++ b/developerconnect/CHANGES.md @@ -1,5 +1,12 @@ # Changelog +## [0.3.1](https://github.com/googleapis/google-cloud-go/compare/developerconnect/v0.3.0...developerconnect/v0.3.1) (2025-01-02) + + +### Bug Fixes + +* **developerconnect:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.3.0](https://github.com/googleapis/google-cloud-go/compare/developerconnect/v0.2.2...developerconnect/v0.3.0) (2024-11-19) diff --git a/developerconnect/internal/version.go b/developerconnect/internal/version.go index e5dd60387ff3..8df78f47e4ea 100644 --- a/developerconnect/internal/version.go +++ b/developerconnect/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "0.3.0" +const Version = "0.3.1" diff --git a/dialogflow/CHANGES.md b/dialogflow/CHANGES.md index 0472dac32f95..11d022d8a998 100644 --- a/dialogflow/CHANGES.md +++ b/dialogflow/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.64.1](https://github.com/googleapis/google-cloud-go/compare/dialogflow/v1.64.0...dialogflow/v1.64.1) (2025-01-02) + + +### Bug Fixes + +* **dialogflow:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.64.0](https://github.com/googleapis/google-cloud-go/compare/dialogflow/v1.63.0...dialogflow/v1.64.0) (2024-12-18) diff --git a/dialogflow/internal/version.go b/dialogflow/internal/version.go index 396a10c007fe..15f4f25a63ff 100644 --- a/dialogflow/internal/version.go +++ b/dialogflow/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.64.0" +const Version = "1.64.1" diff --git a/discoveryengine/CHANGES.md b/discoveryengine/CHANGES.md index 6da8f4b18573..dee9927f703a 100644 --- a/discoveryengine/CHANGES.md +++ b/discoveryengine/CHANGES.md @@ -1,6 +1,13 @@ # Changelog +## [1.16.1](https://github.com/googleapis/google-cloud-go/compare/discoveryengine/v1.16.0...discoveryengine/v1.16.1) (2025-01-02) + + +### Bug Fixes + +* **discoveryengine:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.16.0](https://github.com/googleapis/google-cloud-go/compare/discoveryengine/v1.15.0...discoveryengine/v1.16.0) (2024-11-06) diff --git a/discoveryengine/internal/version.go b/discoveryengine/internal/version.go index e9046c79cd2b..c624d08fc862 100644 --- a/discoveryengine/internal/version.go +++ b/discoveryengine/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.16.0" +const Version = "1.16.1" diff --git a/dlp/CHANGES.md b/dlp/CHANGES.md index 510f8a13d51c..ceaedd414983 100644 --- a/dlp/CHANGES.md +++ b/dlp/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.20.1](https://github.com/googleapis/google-cloud-go/compare/dlp/v1.20.0...dlp/v1.20.1) (2025-01-02) + + +### Bug Fixes + +* **dlp:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.20.0](https://github.com/googleapis/google-cloud-go/compare/dlp/v1.19.0...dlp/v1.20.0) (2024-10-23) diff --git a/dlp/internal/version.go b/dlp/internal/version.go index 0b0f0e914120..e939b9f5e080 100644 --- a/dlp/internal/version.go +++ b/dlp/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.20.0" +const Version = "1.20.1" diff --git a/documentai/CHANGES.md b/documentai/CHANGES.md index ed3442c507e1..f22cd1c2c304 100644 --- a/documentai/CHANGES.md +++ b/documentai/CHANGES.md @@ -1,6 +1,13 @@ # Changes +## [1.35.1](https://github.com/googleapis/google-cloud-go/compare/documentai/v1.35.0...documentai/v1.35.1) (2025-01-02) + + +### Bug Fixes + +* **documentai:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.35.0](https://github.com/googleapis/google-cloud-go/compare/documentai/v1.34.0...documentai/v1.35.0) (2024-10-23) diff --git a/documentai/internal/version.go b/documentai/internal/version.go index b846f144d253..eca9b294aa1a 100644 --- a/documentai/internal/version.go +++ b/documentai/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.35.0" +const Version = "1.35.1" diff --git a/domains/CHANGES.md b/domains/CHANGES.md index 2814cdda8142..239420ee23e2 100644 --- a/domains/CHANGES.md +++ b/domains/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [0.10.3](https://github.com/googleapis/google-cloud-go/compare/domains/v0.10.2...domains/v0.10.3) (2025-01-02) + + +### Bug Fixes + +* **domains:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.10.2](https://github.com/googleapis/google-cloud-go/compare/domains/v0.10.1...domains/v0.10.2) (2024-10-23) diff --git a/edgecontainer/CHANGES.md b/edgecontainer/CHANGES.md index eaab62e7c9c4..888da55ac411 100644 --- a/edgecontainer/CHANGES.md +++ b/edgecontainer/CHANGES.md @@ -1,6 +1,13 @@ # Changelog +## [1.4.1](https://github.com/googleapis/google-cloud-go/compare/edgecontainer/v1.4.0...edgecontainer/v1.4.1) (2025-01-02) + + +### Bug Fixes + +* **edgecontainer:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.4.0](https://github.com/googleapis/google-cloud-go/compare/edgecontainer/v1.3.2...edgecontainer/v1.4.0) (2024-11-06) diff --git a/edgecontainer/internal/version.go b/edgecontainer/internal/version.go index 9e5f10ef61b3..da481a39b3ae 100644 --- a/edgecontainer/internal/version.go +++ b/edgecontainer/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.4.0" +const Version = "1.4.1" diff --git a/edgenetwork/CHANGES.md b/edgenetwork/CHANGES.md index a11b345927c0..056447d4463f 100644 --- a/edgenetwork/CHANGES.md +++ b/edgenetwork/CHANGES.md @@ -2,6 +2,13 @@ +## [1.2.3](https://github.com/googleapis/google-cloud-go/compare/edgenetwork/v1.2.2...edgenetwork/v1.2.3) (2025-01-02) + + +### Bug Fixes + +* **edgenetwork:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.2.2](https://github.com/googleapis/google-cloud-go/compare/edgenetwork/v1.2.1...edgenetwork/v1.2.2) (2024-10-23) diff --git a/edgenetwork/internal/version.go b/edgenetwork/internal/version.go index 0efd895730e6..49cdd5f2aa4a 100644 --- a/edgenetwork/internal/version.go +++ b/edgenetwork/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.2.2" +const Version = "1.2.3" diff --git a/essentialcontacts/CHANGES.md b/essentialcontacts/CHANGES.md index bfcc054694ea..3e5fadd0b67d 100644 --- a/essentialcontacts/CHANGES.md +++ b/essentialcontacts/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.7.3](https://github.com/googleapis/google-cloud-go/compare/essentialcontacts/v1.7.2...essentialcontacts/v1.7.3) (2025-01-02) + + +### Bug Fixes + +* **essentialcontacts:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.7.2](https://github.com/googleapis/google-cloud-go/compare/essentialcontacts/v1.7.1...essentialcontacts/v1.7.2) (2024-10-23) diff --git a/eventarc/CHANGES.md b/eventarc/CHANGES.md index 68ee69a8ecea..882398745f57 100644 --- a/eventarc/CHANGES.md +++ b/eventarc/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.15.1](https://github.com/googleapis/google-cloud-go/compare/eventarc/v1.15.0...eventarc/v1.15.1) (2025-01-02) + + +### Bug Fixes + +* **eventarc:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.15.0](https://github.com/googleapis/google-cloud-go/compare/eventarc/v1.14.2...eventarc/v1.15.0) (2024-11-06) diff --git a/filestore/CHANGES.md b/filestore/CHANGES.md index e43bb60f781e..4faf3aeb5b94 100644 --- a/filestore/CHANGES.md +++ b/filestore/CHANGES.md @@ -1,6 +1,13 @@ # Changes +## [1.9.3](https://github.com/googleapis/google-cloud-go/compare/filestore/v1.9.2...filestore/v1.9.3) (2025-01-02) + + +### Bug Fixes + +* **filestore:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.9.2](https://github.com/googleapis/google-cloud-go/compare/filestore/v1.9.1...filestore/v1.9.2) (2024-10-23) diff --git a/filestore/internal/version.go b/filestore/internal/version.go index 0d65872417b6..c754de783b4e 100644 --- a/filestore/internal/version.go +++ b/filestore/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.9.2" +const Version = "1.9.3" diff --git a/functions/CHANGES.md b/functions/CHANGES.md index 804de6b1a7de..438cce8066cf 100644 --- a/functions/CHANGES.md +++ b/functions/CHANGES.md @@ -1,6 +1,13 @@ # Changes +## [1.19.3](https://github.com/googleapis/google-cloud-go/compare/functions/v1.19.2...functions/v1.19.3) (2025-01-02) + + +### Bug Fixes + +* **functions:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.19.2](https://github.com/googleapis/google-cloud-go/compare/functions/v1.19.1...functions/v1.19.2) (2024-10-23) diff --git a/functions/internal/version.go b/functions/internal/version.go index 50a4f1c453a7..7513e24cc7b0 100644 --- a/functions/internal/version.go +++ b/functions/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.19.2" +const Version = "1.19.3" diff --git a/gkebackup/CHANGES.md b/gkebackup/CHANGES.md index 8af995a28a19..6273714af2a9 100644 --- a/gkebackup/CHANGES.md +++ b/gkebackup/CHANGES.md @@ -2,6 +2,13 @@ +## [1.6.3](https://github.com/googleapis/google-cloud-go/compare/gkebackup/v1.6.2...gkebackup/v1.6.3) (2025-01-02) + + +### Bug Fixes + +* **gkebackup:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.6.2](https://github.com/googleapis/google-cloud-go/compare/gkebackup/v1.6.1...gkebackup/v1.6.2) (2024-10-23) diff --git a/gkebackup/internal/version.go b/gkebackup/internal/version.go index 5ffba3b78ab9..0ed5167d22da 100644 --- a/gkebackup/internal/version.go +++ b/gkebackup/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.6.2" +const Version = "1.6.3" diff --git a/gkeconnect/CHANGES.md b/gkeconnect/CHANGES.md index afb29620886a..08b5a0c47e3c 100644 --- a/gkeconnect/CHANGES.md +++ b/gkeconnect/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [0.12.1](https://github.com/googleapis/google-cloud-go/compare/gkeconnect/v0.12.0...gkeconnect/v0.12.1) (2025-01-02) + + +### Bug Fixes + +* **gkeconnect:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.12.0](https://github.com/googleapis/google-cloud-go/compare/gkeconnect/v0.11.2...gkeconnect/v0.12.0) (2024-11-14) diff --git a/gkehub/CHANGES.md b/gkehub/CHANGES.md index db0597a2b23b..335143f31b23 100644 --- a/gkehub/CHANGES.md +++ b/gkehub/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [0.15.3](https://github.com/googleapis/google-cloud-go/compare/gkehub/v0.15.2...gkehub/v0.15.3) (2025-01-02) + + +### Bug Fixes + +* **gkehub:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.15.2](https://github.com/googleapis/google-cloud-go/compare/gkehub/v0.15.1...gkehub/v0.15.2) (2024-10-23) diff --git a/gkemulticloud/CHANGES.md b/gkemulticloud/CHANGES.md index 8b6aa0c31a52..085876268a63 100644 --- a/gkemulticloud/CHANGES.md +++ b/gkemulticloud/CHANGES.md @@ -1,6 +1,24 @@ # Changelog +## [1.5.0](https://github.com/googleapis/google-cloud-go/compare/gkemulticloud/v1.4.1...gkemulticloud/v1.5.0) (2025-01-02) + + +### Features + +* **gkemulticloud:** Added support for optionally disabling built-in GKE metrics ([8ebcc6d](https://github.com/googleapis/google-cloud-go/commit/8ebcc6d276fc881c3914b5a7af3265a04e718e45)) +* **gkemulticloud:** Added tag bindings support for Attached Clusters ([8ebcc6d](https://github.com/googleapis/google-cloud-go/commit/8ebcc6d276fc881c3914b5a7af3265a04e718e45)) + + +### Bug Fixes + +* **gkemulticloud:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + + +### Documentation + +* **gkemulticloud:** Updated comments of existing fields ([8ebcc6d](https://github.com/googleapis/google-cloud-go/commit/8ebcc6d276fc881c3914b5a7af3265a04e718e45)) + ## [1.4.1](https://github.com/googleapis/google-cloud-go/compare/gkemulticloud/v1.4.0...gkemulticloud/v1.4.1) (2024-10-23) diff --git a/gkemulticloud/internal/version.go b/gkemulticloud/internal/version.go index da481a39b3ae..d339bd9a354e 100644 --- a/gkemulticloud/internal/version.go +++ b/gkemulticloud/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.4.1" +const Version = "1.5.0" diff --git a/grafeas/CHANGES.md b/grafeas/CHANGES.md index 0902532b1a13..ace232fcc9f6 100644 --- a/grafeas/CHANGES.md +++ b/grafeas/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [0.3.13](https://github.com/googleapis/google-cloud-go/compare/grafeas/v0.3.12...grafeas/v0.3.13) (2025-01-02) + + +### Bug Fixes + +* **grafeas:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.3.12](https://github.com/googleapis/google-cloud-go/compare/grafeas/v0.3.11...grafeas/v0.3.12) (2024-10-23) diff --git a/gsuiteaddons/CHANGES.md b/gsuiteaddons/CHANGES.md index 24a8d95d0e6c..399602bf9c3d 100644 --- a/gsuiteaddons/CHANGES.md +++ b/gsuiteaddons/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.7.3](https://github.com/googleapis/google-cloud-go/compare/gsuiteaddons/v1.7.2...gsuiteaddons/v1.7.3) (2025-01-02) + + +### Bug Fixes + +* **gsuiteaddons:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.7.2](https://github.com/googleapis/google-cloud-go/compare/gsuiteaddons/v1.7.1...gsuiteaddons/v1.7.2) (2024-10-23) diff --git a/iam/CHANGES.md b/iam/CHANGES.md index 7eb2192a4e91..6bfd910506ed 100644 --- a/iam/CHANGES.md +++ b/iam/CHANGES.md @@ -1,6 +1,13 @@ # Changes +## [1.3.1](https://github.com/googleapis/google-cloud-go/compare/iam/v1.3.0...iam/v1.3.1) (2025-01-02) + + +### Bug Fixes + +* **iam:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.3.0](https://github.com/googleapis/google-cloud-go/compare/iam/v1.2.2...iam/v1.3.0) (2024-12-04) diff --git a/iap/CHANGES.md b/iap/CHANGES.md index ca4fe51dd50f..fb73dc2079ba 100644 --- a/iap/CHANGES.md +++ b/iap/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.10.3](https://github.com/googleapis/google-cloud-go/compare/iap/v1.10.2...iap/v1.10.3) (2025-01-02) + + +### Bug Fixes + +* **iap:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.10.2](https://github.com/googleapis/google-cloud-go/compare/iap/v1.10.1...iap/v1.10.2) (2024-10-23) diff --git a/identitytoolkit/CHANGES.md b/identitytoolkit/CHANGES.md index e7fd861f1851..ebacb4b5b732 100644 --- a/identitytoolkit/CHANGES.md +++ b/identitytoolkit/CHANGES.md @@ -1,5 +1,12 @@ # Changelog +## [0.2.3](https://github.com/googleapis/google-cloud-go/compare/identitytoolkit/v0.2.2...identitytoolkit/v0.2.3) (2025-01-02) + + +### Bug Fixes + +* **identitytoolkit:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.2.2](https://github.com/googleapis/google-cloud-go/compare/identitytoolkit/v0.2.1...identitytoolkit/v0.2.2) (2024-10-23) diff --git a/identitytoolkit/internal/version.go b/identitytoolkit/internal/version.go index 8d343af28cdf..37101c109e28 100644 --- a/identitytoolkit/internal/version.go +++ b/identitytoolkit/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "0.2.2" +const Version = "0.2.3" diff --git a/ids/CHANGES.md b/ids/CHANGES.md index 66adef634a99..e25a2adf85cf 100644 --- a/ids/CHANGES.md +++ b/ids/CHANGES.md @@ -1,6 +1,13 @@ # Changes +## [1.5.3](https://github.com/googleapis/google-cloud-go/compare/ids/v1.5.2...ids/v1.5.3) (2025-01-02) + + +### Bug Fixes + +* **ids:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.5.2](https://github.com/googleapis/google-cloud-go/compare/ids/v1.5.1...ids/v1.5.2) (2024-10-23) diff --git a/iot/CHANGES.md b/iot/CHANGES.md index 3ea21c78bfd1..552c6f3c6b10 100644 --- a/iot/CHANGES.md +++ b/iot/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.8.3](https://github.com/googleapis/google-cloud-go/compare/iot/v1.8.2...iot/v1.8.3) (2025-01-02) + + +### Bug Fixes + +* **iot:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.8.2](https://github.com/googleapis/google-cloud-go/compare/iot/v1.8.1...iot/v1.8.2) (2024-10-23) diff --git a/kms/CHANGES.md b/kms/CHANGES.md index b8ab433da902..a8278089e4a5 100644 --- a/kms/CHANGES.md +++ b/kms/CHANGES.md @@ -1,6 +1,13 @@ # Changes +## [1.20.4](https://github.com/googleapis/google-cloud-go/compare/kms/v1.20.3...kms/v1.20.4) (2025-01-02) + + +### Bug Fixes + +* **kms:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.20.3](https://github.com/googleapis/google-cloud-go/compare/kms/v1.20.2...kms/v1.20.3) (2024-12-18) diff --git a/kms/internal/version.go b/kms/internal/version.go index a8a51fdaa7a2..b3799f0518e5 100644 --- a/kms/internal/version.go +++ b/kms/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.20.3" +const Version = "1.20.4" diff --git a/language/CHANGES.md b/language/CHANGES.md index 06644bc76fbd..75aa4b815220 100644 --- a/language/CHANGES.md +++ b/language/CHANGES.md @@ -1,6 +1,13 @@ # Changes +## [1.14.3](https://github.com/googleapis/google-cloud-go/compare/language/v1.14.2...language/v1.14.3) (2025-01-02) + + +### Bug Fixes + +* **language:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.14.2](https://github.com/googleapis/google-cloud-go/compare/language/v1.14.1...language/v1.14.2) (2024-10-23) diff --git a/language/internal/version.go b/language/internal/version.go index b11f4c49d533..5cdb009d1b5d 100644 --- a/language/internal/version.go +++ b/language/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.14.2" +const Version = "1.14.3" diff --git a/lifesciences/CHANGES.md b/lifesciences/CHANGES.md index ebfcda9ebc59..da0ed02c0340 100644 --- a/lifesciences/CHANGES.md +++ b/lifesciences/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [0.10.3](https://github.com/googleapis/google-cloud-go/compare/lifesciences/v0.10.2...lifesciences/v0.10.3) (2025-01-02) + + +### Bug Fixes + +* **lifesciences:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.10.2](https://github.com/googleapis/google-cloud-go/compare/lifesciences/v0.10.1...lifesciences/v0.10.2) (2024-10-23) diff --git a/longrunning/CHANGES.md b/longrunning/CHANGES.md index b1b182fe0add..875fb4b399dc 100644 --- a/longrunning/CHANGES.md +++ b/longrunning/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [0.6.4](https://github.com/googleapis/google-cloud-go/compare/longrunning/v0.6.3...longrunning/v0.6.4) (2025-01-02) + + +### Bug Fixes + +* **longrunning:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.6.3](https://github.com/googleapis/google-cloud-go/compare/longrunning/v0.6.2...longrunning/v0.6.3) (2024-11-19) diff --git a/managedidentities/CHANGES.md b/managedidentities/CHANGES.md index 06ce1218f8a1..d1533f03464a 100644 --- a/managedidentities/CHANGES.md +++ b/managedidentities/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.7.3](https://github.com/googleapis/google-cloud-go/compare/managedidentities/v1.7.2...managedidentities/v1.7.3) (2025-01-02) + + +### Bug Fixes + +* **managedidentities:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.7.2](https://github.com/googleapis/google-cloud-go/compare/managedidentities/v1.7.1...managedidentities/v1.7.2) (2024-10-23) diff --git a/managedkafka/CHANGES.md b/managedkafka/CHANGES.md index 59a547965d55..ab71666c9561 100644 --- a/managedkafka/CHANGES.md +++ b/managedkafka/CHANGES.md @@ -1,5 +1,12 @@ # Changelog +## [0.3.1](https://github.com/googleapis/google-cloud-go/compare/managedkafka/v0.3.0...managedkafka/v0.3.1) (2025-01-02) + + +### Bug Fixes + +* **managedkafka:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.3.0](https://github.com/googleapis/google-cloud-go/compare/managedkafka/v0.2.3...managedkafka/v0.3.0) (2024-12-04) diff --git a/managedkafka/internal/version.go b/managedkafka/internal/version.go index e5dd60387ff3..8df78f47e4ea 100644 --- a/managedkafka/internal/version.go +++ b/managedkafka/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "0.3.0" +const Version = "0.3.1" diff --git a/maps/CHANGES.md b/maps/CHANGES.md index 0fc94fa50787..439586b43f52 100644 --- a/maps/CHANGES.md +++ b/maps/CHANGES.md @@ -2,6 +2,13 @@ +## [1.17.1](https://github.com/googleapis/google-cloud-go/compare/maps/v1.17.0...maps/v1.17.1) (2025-01-02) + + +### Bug Fixes + +* **maps:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.17.0](https://github.com/googleapis/google-cloud-go/compare/maps/v1.16.0...maps/v1.17.0) (2024-12-11) diff --git a/maps/internal/version.go b/maps/internal/version.go index f455a24a9233..704ed23e6b29 100644 --- a/maps/internal/version.go +++ b/maps/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.17.0" +const Version = "1.17.1" diff --git a/mediatranslation/CHANGES.md b/mediatranslation/CHANGES.md index 24260267225c..ee5439ff0eb3 100644 --- a/mediatranslation/CHANGES.md +++ b/mediatranslation/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [0.9.3](https://github.com/googleapis/google-cloud-go/compare/mediatranslation/v0.9.2...mediatranslation/v0.9.3) (2025-01-02) + + +### Bug Fixes + +* **mediatranslation:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.9.2](https://github.com/googleapis/google-cloud-go/compare/mediatranslation/v0.9.1...mediatranslation/v0.9.2) (2024-10-23) diff --git a/memcache/CHANGES.md b/memcache/CHANGES.md index 8ff9014fbf27..87b244da24cb 100644 --- a/memcache/CHANGES.md +++ b/memcache/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.11.3](https://github.com/googleapis/google-cloud-go/compare/memcache/v1.11.2...memcache/v1.11.3) (2025-01-02) + + +### Bug Fixes + +* **memcache:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.11.2](https://github.com/googleapis/google-cloud-go/compare/memcache/v1.11.1...memcache/v1.11.2) (2024-10-23) diff --git a/memorystore/CHANGES.md b/memorystore/CHANGES.md index 4eb697481fb3..c286e076dbd0 100644 --- a/memorystore/CHANGES.md +++ b/memorystore/CHANGES.md @@ -1,5 +1,12 @@ # Changelog +## [0.1.1](https://github.com/googleapis/google-cloud-go/compare/memorystore/v0.1.0...memorystore/v0.1.1) (2025-01-02) + + +### Bug Fixes + +* **memorystore:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## 0.1.0 (2024-12-18) diff --git a/memorystore/internal/version.go b/memorystore/internal/version.go index 20ba73abd675..777c90f6b2f3 100644 --- a/memorystore/internal/version.go +++ b/memorystore/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "0.1.0" +const Version = "0.1.1" diff --git a/metastore/CHANGES.md b/metastore/CHANGES.md index d75fed4a79af..b83615c47d41 100644 --- a/metastore/CHANGES.md +++ b/metastore/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.14.3](https://github.com/googleapis/google-cloud-go/compare/metastore/v1.14.2...metastore/v1.14.3) (2025-01-02) + + +### Bug Fixes + +* **metastore:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.14.2](https://github.com/googleapis/google-cloud-go/compare/metastore/v1.14.1...metastore/v1.14.2) (2024-10-23) diff --git a/migrationcenter/CHANGES.md b/migrationcenter/CHANGES.md index 4ed1c11bf294..be0c623288bf 100644 --- a/migrationcenter/CHANGES.md +++ b/migrationcenter/CHANGES.md @@ -1,6 +1,13 @@ # Changelog +## [1.1.3](https://github.com/googleapis/google-cloud-go/compare/migrationcenter/v1.1.2...migrationcenter/v1.1.3) (2025-01-02) + + +### Bug Fixes + +* **migrationcenter:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.1.2](https://github.com/googleapis/google-cloud-go/compare/migrationcenter/v1.1.1...migrationcenter/v1.1.2) (2024-10-23) diff --git a/migrationcenter/internal/version.go b/migrationcenter/internal/version.go index 2eabe9755ac2..37b53333df2f 100644 --- a/migrationcenter/internal/version.go +++ b/migrationcenter/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.1.2" +const Version = "1.1.3" diff --git a/monitoring/CHANGES.md b/monitoring/CHANGES.md index 76b69122256f..2975cf43e345 100644 --- a/monitoring/CHANGES.md +++ b/monitoring/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.22.1](https://github.com/googleapis/google-cloud-go/compare/monitoring/v1.22.0...monitoring/v1.22.1) (2025-01-02) + + +### Bug Fixes + +* **monitoring:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.22.0](https://github.com/googleapis/google-cloud-go/compare/monitoring/v1.21.2...monitoring/v1.22.0) (2024-12-04) diff --git a/monitoring/internal/version.go b/monitoring/internal/version.go index eddfee04b0b3..08bddba74861 100644 --- a/monitoring/internal/version.go +++ b/monitoring/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.22.0" +const Version = "1.22.1" diff --git a/netapp/CHANGES.md b/netapp/CHANGES.md index df477e46cf90..56b945039ecb 100644 --- a/netapp/CHANGES.md +++ b/netapp/CHANGES.md @@ -1,6 +1,13 @@ # Changelog +## [1.5.1](https://github.com/googleapis/google-cloud-go/compare/netapp/v1.5.0...netapp/v1.5.1) (2025-01-02) + + +### Bug Fixes + +* **netapp:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.5.0](https://github.com/googleapis/google-cloud-go/compare/netapp/v1.4.1...netapp/v1.5.0) (2024-12-04) diff --git a/netapp/internal/version.go b/netapp/internal/version.go index f348aca1a0be..4b23b58ae148 100644 --- a/netapp/internal/version.go +++ b/netapp/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.5.0" +const Version = "1.5.1" diff --git a/networkconnectivity/CHANGES.md b/networkconnectivity/CHANGES.md index 7040a09a0d12..b1e986079a02 100644 --- a/networkconnectivity/CHANGES.md +++ b/networkconnectivity/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.16.1](https://github.com/googleapis/google-cloud-go/compare/networkconnectivity/v1.16.0...networkconnectivity/v1.16.1) (2025-01-02) + + +### Bug Fixes + +* **networkconnectivity:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.16.0](https://github.com/googleapis/google-cloud-go/compare/networkconnectivity/v1.15.2...networkconnectivity/v1.16.0) (2024-12-04) diff --git a/networkmanagement/CHANGES.md b/networkmanagement/CHANGES.md index d45a228ec96d..019411a0da74 100644 --- a/networkmanagement/CHANGES.md +++ b/networkmanagement/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.17.1](https://github.com/googleapis/google-cloud-go/compare/networkmanagement/v1.17.0...networkmanagement/v1.17.1) (2025-01-02) + + +### Bug Fixes + +* **networkmanagement:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.17.0](https://github.com/googleapis/google-cloud-go/compare/networkmanagement/v1.16.0...networkmanagement/v1.17.0) (2024-11-19) diff --git a/networkmanagement/internal/version.go b/networkmanagement/internal/version.go index 6607c695d5cb..2d7d8774486c 100644 --- a/networkmanagement/internal/version.go +++ b/networkmanagement/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.17.0" +const Version = "1.17.1" diff --git a/networksecurity/CHANGES.md b/networksecurity/CHANGES.md index 885847e7d7ad..00e7b1b0c13a 100644 --- a/networksecurity/CHANGES.md +++ b/networksecurity/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [0.10.3](https://github.com/googleapis/google-cloud-go/compare/networksecurity/v0.10.2...networksecurity/v0.10.3) (2025-01-02) + + +### Bug Fixes + +* **networksecurity:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.10.2](https://github.com/googleapis/google-cloud-go/compare/networksecurity/v0.10.1...networksecurity/v0.10.2) (2024-10-23) diff --git a/networkservices/CHANGES.md b/networkservices/CHANGES.md index da5b1b1aa390..d1a39825a992 100644 --- a/networkservices/CHANGES.md +++ b/networkservices/CHANGES.md @@ -1,5 +1,12 @@ # Changelog +## [0.2.3](https://github.com/googleapis/google-cloud-go/compare/networkservices/v0.2.2...networkservices/v0.2.3) (2025-01-02) + + +### Bug Fixes + +* **networkservices:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.2.2](https://github.com/googleapis/google-cloud-go/compare/networkservices/v0.2.1...networkservices/v0.2.2) (2024-10-23) diff --git a/networkservices/internal/version.go b/networkservices/internal/version.go index 8d343af28cdf..37101c109e28 100644 --- a/networkservices/internal/version.go +++ b/networkservices/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "0.2.2" +const Version = "0.2.3" diff --git a/notebooks/CHANGES.md b/notebooks/CHANGES.md index f8aa4f645620..18624f9aef10 100644 --- a/notebooks/CHANGES.md +++ b/notebooks/CHANGES.md @@ -1,6 +1,13 @@ # Changes +## [1.12.3](https://github.com/googleapis/google-cloud-go/compare/notebooks/v1.12.2...notebooks/v1.12.3) (2025-01-02) + + +### Bug Fixes + +* **notebooks:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.12.2](https://github.com/googleapis/google-cloud-go/compare/notebooks/v1.12.1...notebooks/v1.12.2) (2024-10-23) diff --git a/optimization/CHANGES.md b/optimization/CHANGES.md index 1a827d481c18..c326d99fbeae 100644 --- a/optimization/CHANGES.md +++ b/optimization/CHANGES.md @@ -1,6 +1,13 @@ # Changes +## [1.7.3](https://github.com/googleapis/google-cloud-go/compare/optimization/v1.7.2...optimization/v1.7.3) (2025-01-02) + + +### Bug Fixes + +* **optimization:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.7.2](https://github.com/googleapis/google-cloud-go/compare/optimization/v1.7.1...optimization/v1.7.2) (2024-10-23) diff --git a/oracledatabase/CHANGES.md b/oracledatabase/CHANGES.md index a87abcfc7e56..c38cf8d6ed4e 100644 --- a/oracledatabase/CHANGES.md +++ b/oracledatabase/CHANGES.md @@ -1,5 +1,12 @@ # Changelog +## [0.1.3](https://github.com/googleapis/google-cloud-go/compare/oracledatabase/v0.1.2...oracledatabase/v0.1.3) (2025-01-02) + + +### Bug Fixes + +* **oracledatabase:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.1.2](https://github.com/googleapis/google-cloud-go/compare/oracledatabase/v0.1.1...oracledatabase/v0.1.2) (2024-12-11) diff --git a/oracledatabase/internal/version.go b/oracledatabase/internal/version.go index 7196f28b8f6e..14256f5b3c99 100644 --- a/oracledatabase/internal/version.go +++ b/oracledatabase/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "0.1.2" +const Version = "0.1.3" diff --git a/orchestration/CHANGES.md b/orchestration/CHANGES.md index 00cd0fe3b382..ca55215ce187 100644 --- a/orchestration/CHANGES.md +++ b/orchestration/CHANGES.md @@ -1,6 +1,13 @@ # Changes +## [1.11.3](https://github.com/googleapis/google-cloud-go/compare/orchestration/v1.11.2...orchestration/v1.11.3) (2025-01-02) + + +### Bug Fixes + +* **orchestration:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.11.2](https://github.com/googleapis/google-cloud-go/compare/orchestration/v1.11.1...orchestration/v1.11.2) (2024-12-11) diff --git a/orchestration/internal/version.go b/orchestration/internal/version.go index 5d1622b719a9..b8e5ff2d38ed 100644 --- a/orchestration/internal/version.go +++ b/orchestration/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.11.2" +const Version = "1.11.3" diff --git a/orgpolicy/CHANGES.md b/orgpolicy/CHANGES.md index 0dd7fada4b37..3f0904d70e12 100644 --- a/orgpolicy/CHANGES.md +++ b/orgpolicy/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.14.2](https://github.com/googleapis/google-cloud-go/compare/orgpolicy/v1.14.1...orgpolicy/v1.14.2) (2025-01-02) + + +### Bug Fixes + +* **orgpolicy:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.14.1](https://github.com/googleapis/google-cloud-go/compare/orgpolicy/v1.14.0...orgpolicy/v1.14.1) (2024-10-23) diff --git a/orgpolicy/internal/version.go b/orgpolicy/internal/version.go index 1d4c00b5e04b..b11f4c49d533 100644 --- a/orgpolicy/internal/version.go +++ b/orgpolicy/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.14.1" +const Version = "1.14.2" diff --git a/osconfig/CHANGES.md b/osconfig/CHANGES.md index a20f13e85d92..71c9dc8a22fa 100644 --- a/osconfig/CHANGES.md +++ b/osconfig/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.14.3](https://github.com/googleapis/google-cloud-go/compare/osconfig/v1.14.2...osconfig/v1.14.3) (2025-01-02) + + +### Bug Fixes + +* **osconfig:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.14.2](https://github.com/googleapis/google-cloud-go/compare/osconfig/v1.14.1...osconfig/v1.14.2) (2024-10-23) diff --git a/osconfig/internal/version.go b/osconfig/internal/version.go index b11f4c49d533..5cdb009d1b5d 100644 --- a/osconfig/internal/version.go +++ b/osconfig/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.14.2" +const Version = "1.14.3" diff --git a/oslogin/CHANGES.md b/oslogin/CHANGES.md index 30d2037aab97..43ce3e8b9fed 100644 --- a/oslogin/CHANGES.md +++ b/oslogin/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.14.3](https://github.com/googleapis/google-cloud-go/compare/oslogin/v1.14.2...oslogin/v1.14.3) (2025-01-02) + + +### Bug Fixes + +* **oslogin:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.14.2](https://github.com/googleapis/google-cloud-go/compare/oslogin/v1.14.1...oslogin/v1.14.2) (2024-10-23) diff --git a/oslogin/internal/version.go b/oslogin/internal/version.go index b11f4c49d533..5cdb009d1b5d 100644 --- a/oslogin/internal/version.go +++ b/oslogin/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.14.2" +const Version = "1.14.3" diff --git a/parallelstore/CHANGES.md b/parallelstore/CHANGES.md index 4b8303028aa4..b19064e208e3 100644 --- a/parallelstore/CHANGES.md +++ b/parallelstore/CHANGES.md @@ -1,5 +1,19 @@ # Changelog +## [0.9.1](https://github.com/googleapis/google-cloud-go/compare/parallelstore/v0.9.0...parallelstore/v0.9.1) (2025-01-02) + + +### Bug Fixes + +* **parallelstore:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + + +### Documentation + +* **parallelstore:** A comment for field `requested_cancellation` in message `.google.cloud.parallelstore.v1beta.ExportDataMetadata` is changed ([e2796a8](https://github.com/googleapis/google-cloud-go/commit/e2796a8c1460211fc2f4e78f37e15e8e2b6e8179)) +* **parallelstore:** A comment for field `requested_cancellation` in message `.google.cloud.parallelstore.v1beta.ImportDataMetadata` is changed ([e2796a8](https://github.com/googleapis/google-cloud-go/commit/e2796a8c1460211fc2f4e78f37e15e8e2b6e8179)) +* **parallelstore:** A comment for field `requested_cancellation` in message `.google.cloud.parallelstore.v1beta.OperationMetadata` is changed ([e2796a8](https://github.com/googleapis/google-cloud-go/commit/e2796a8c1460211fc2f4e78f37e15e8e2b6e8179)) + ## [0.9.0](https://github.com/googleapis/google-cloud-go/compare/parallelstore/v0.8.0...parallelstore/v0.9.0) (2024-12-11) diff --git a/parallelstore/internal/version.go b/parallelstore/internal/version.go index 34e4a80edf09..2d3b14c67e41 100644 --- a/parallelstore/internal/version.go +++ b/parallelstore/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "0.9.0" +const Version = "0.9.1" diff --git a/phishingprotection/CHANGES.md b/phishingprotection/CHANGES.md index 749fab3671ed..43ca700957c6 100644 --- a/phishingprotection/CHANGES.md +++ b/phishingprotection/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [0.9.3](https://github.com/googleapis/google-cloud-go/compare/phishingprotection/v0.9.2...phishingprotection/v0.9.3) (2025-01-02) + + +### Bug Fixes + +* **phishingprotection:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.9.2](https://github.com/googleapis/google-cloud-go/compare/phishingprotection/v0.9.1...phishingprotection/v0.9.2) (2024-10-23) diff --git a/policysimulator/CHANGES.md b/policysimulator/CHANGES.md index af09c2f37b72..28c66327c60d 100644 --- a/policysimulator/CHANGES.md +++ b/policysimulator/CHANGES.md @@ -1,5 +1,12 @@ # Changelog +## [0.3.3](https://github.com/googleapis/google-cloud-go/compare/policysimulator/v0.3.2...policysimulator/v0.3.3) (2025-01-02) + + +### Bug Fixes + +* **policysimulator:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.3.2](https://github.com/googleapis/google-cloud-go/compare/policysimulator/v0.3.1...policysimulator/v0.3.2) (2024-10-23) diff --git a/policytroubleshooter/CHANGES.md b/policytroubleshooter/CHANGES.md index b9ee15f5a9d0..33f5c03d9f1a 100644 --- a/policytroubleshooter/CHANGES.md +++ b/policytroubleshooter/CHANGES.md @@ -2,6 +2,13 @@ +## [1.11.3](https://github.com/googleapis/google-cloud-go/compare/policytroubleshooter/v1.11.2...policytroubleshooter/v1.11.3) (2025-01-02) + + +### Bug Fixes + +* **policytroubleshooter:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.11.2](https://github.com/googleapis/google-cloud-go/compare/policytroubleshooter/v1.11.1...policytroubleshooter/v1.11.2) (2024-10-23) diff --git a/privatecatalog/CHANGES.md b/privatecatalog/CHANGES.md index 45d9da90a4e2..09c9a83ca357 100644 --- a/privatecatalog/CHANGES.md +++ b/privatecatalog/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [0.10.3](https://github.com/googleapis/google-cloud-go/compare/privatecatalog/v0.10.2...privatecatalog/v0.10.3) (2025-01-02) + + +### Bug Fixes + +* **privatecatalog:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.10.2](https://github.com/googleapis/google-cloud-go/compare/privatecatalog/v0.10.1...privatecatalog/v0.10.2) (2024-10-23) diff --git a/privilegedaccessmanager/CHANGES.md b/privilegedaccessmanager/CHANGES.md index 4c994919359a..5c34f47c1ac6 100644 --- a/privilegedaccessmanager/CHANGES.md +++ b/privilegedaccessmanager/CHANGES.md @@ -1,5 +1,12 @@ # Changelog +## [0.2.3](https://github.com/googleapis/google-cloud-go/compare/privilegedaccessmanager/v0.2.2...privilegedaccessmanager/v0.2.3) (2025-01-02) + + +### Bug Fixes + +* **privilegedaccessmanager:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.2.2](https://github.com/googleapis/google-cloud-go/compare/privilegedaccessmanager/v0.2.1...privilegedaccessmanager/v0.2.2) (2024-10-23) diff --git a/privilegedaccessmanager/internal/version.go b/privilegedaccessmanager/internal/version.go index 8d343af28cdf..37101c109e28 100644 --- a/privilegedaccessmanager/internal/version.go +++ b/privilegedaccessmanager/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "0.2.2" +const Version = "0.2.3" diff --git a/rapidmigrationassessment/CHANGES.md b/rapidmigrationassessment/CHANGES.md index 3f60c66b64c0..0c7f814336e5 100644 --- a/rapidmigrationassessment/CHANGES.md +++ b/rapidmigrationassessment/CHANGES.md @@ -1,6 +1,13 @@ # Changelog +## [1.1.3](https://github.com/googleapis/google-cloud-go/compare/rapidmigrationassessment/v1.1.2...rapidmigrationassessment/v1.1.3) (2025-01-02) + + +### Bug Fixes + +* **rapidmigrationassessment:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.1.2](https://github.com/googleapis/google-cloud-go/compare/rapidmigrationassessment/v1.1.1...rapidmigrationassessment/v1.1.2) (2024-10-23) diff --git a/recaptchaenterprise/CHANGES.md b/recaptchaenterprise/CHANGES.md index 00af82c7125f..26b39f75e284 100644 --- a/recaptchaenterprise/CHANGES.md +++ b/recaptchaenterprise/CHANGES.md @@ -1,6 +1,13 @@ # Changes +## [2.19.2](https://github.com/googleapis/google-cloud-go/compare/recaptchaenterprise/v2.19.1...recaptchaenterprise/v2.19.2) (2025-01-02) + + +### Bug Fixes + +* **recaptchaenterprise:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [2.19.1](https://github.com/googleapis/google-cloud-go/compare/recaptchaenterprise/v2.19.0...recaptchaenterprise/v2.19.1) (2024-12-04) diff --git a/recaptchaenterprise/internal/version.go b/recaptchaenterprise/internal/version.go index 52cbac858d0c..fe68321d2fbd 100644 --- a/recaptchaenterprise/internal/version.go +++ b/recaptchaenterprise/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "2.19.1" +const Version = "2.19.2" diff --git a/recommendationengine/CHANGES.md b/recommendationengine/CHANGES.md index c93152b66f98..8f62c653b4fa 100644 --- a/recommendationengine/CHANGES.md +++ b/recommendationengine/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [0.9.3](https://github.com/googleapis/google-cloud-go/compare/recommendationengine/v0.9.2...recommendationengine/v0.9.3) (2025-01-02) + + +### Bug Fixes + +* **recommendationengine:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.9.2](https://github.com/googleapis/google-cloud-go/compare/recommendationengine/v0.9.1...recommendationengine/v0.9.2) (2024-10-23) diff --git a/recommender/CHANGES.md b/recommender/CHANGES.md index b59a5a12f79a..c7ac5b047103 100644 --- a/recommender/CHANGES.md +++ b/recommender/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.13.3](https://github.com/googleapis/google-cloud-go/compare/recommender/v1.13.2...recommender/v1.13.3) (2025-01-02) + + +### Bug Fixes + +* **recommender:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.13.2](https://github.com/googleapis/google-cloud-go/compare/recommender/v1.13.1...recommender/v1.13.2) (2024-10-23) diff --git a/recommender/internal/version.go b/recommender/internal/version.go index 4724c61f4372..4b5aa753078d 100644 --- a/recommender/internal/version.go +++ b/recommender/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.13.2" +const Version = "1.13.3" diff --git a/redis/CHANGES.md b/redis/CHANGES.md index 1b1217a54f10..c04b731dd484 100644 --- a/redis/CHANGES.md +++ b/redis/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.17.3](https://github.com/googleapis/google-cloud-go/compare/redis/v1.17.2...redis/v1.17.3) (2025-01-02) + + +### Bug Fixes + +* **redis:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.17.2](https://github.com/googleapis/google-cloud-go/compare/redis/v1.17.1...redis/v1.17.2) (2024-10-23) diff --git a/redis/internal/version.go b/redis/internal/version.go index 9f74557a123c..5cbb3e596f58 100644 --- a/redis/internal/version.go +++ b/redis/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.17.2" +const Version = "1.17.3" diff --git a/resourcemanager/CHANGES.md b/resourcemanager/CHANGES.md index 03fed39cacd6..d528123cc57a 100644 --- a/resourcemanager/CHANGES.md +++ b/resourcemanager/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.10.3](https://github.com/googleapis/google-cloud-go/compare/resourcemanager/v1.10.2...resourcemanager/v1.10.3) (2025-01-02) + + +### Bug Fixes + +* **resourcemanager:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.10.2](https://github.com/googleapis/google-cloud-go/compare/resourcemanager/v1.10.1...resourcemanager/v1.10.2) (2024-10-23) diff --git a/resourcesettings/CHANGES.md b/resourcesettings/CHANGES.md index 465e4298a0e0..b36ae21f6e2c 100644 --- a/resourcesettings/CHANGES.md +++ b/resourcesettings/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.8.3](https://github.com/googleapis/google-cloud-go/compare/resourcesettings/v1.8.2...resourcesettings/v1.8.3) (2025-01-02) + + +### Bug Fixes + +* **resourcesettings:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.8.2](https://github.com/googleapis/google-cloud-go/compare/resourcesettings/v1.8.1...resourcesettings/v1.8.2) (2024-10-23) diff --git a/resourcesettings/internal/version.go b/resourcesettings/internal/version.go index 46acea693a2f..472c8977f2fe 100644 --- a/resourcesettings/internal/version.go +++ b/resourcesettings/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.8.2" +const Version = "1.8.3" diff --git a/retail/CHANGES.md b/retail/CHANGES.md index df26b37551ab..35efb0202150 100644 --- a/retail/CHANGES.md +++ b/retail/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.19.2](https://github.com/googleapis/google-cloud-go/compare/retail/v1.19.1...retail/v1.19.2) (2025-01-02) + + +### Bug Fixes + +* **retail:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.19.1](https://github.com/googleapis/google-cloud-go/compare/retail/v1.19.0...retail/v1.19.1) (2024-10-23) diff --git a/retail/internal/version.go b/retail/internal/version.go index a5b020992b84..50a4f1c453a7 100644 --- a/retail/internal/version.go +++ b/retail/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.19.1" +const Version = "1.19.2" diff --git a/run/CHANGES.md b/run/CHANGES.md index cf8eacfa07f2..799d64eb8021 100644 --- a/run/CHANGES.md +++ b/run/CHANGES.md @@ -1,6 +1,13 @@ # Changelog +## [1.8.1](https://github.com/googleapis/google-cloud-go/compare/run/v1.8.0...run/v1.8.1) (2025-01-02) + + +### Bug Fixes + +* **run:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.8.0](https://github.com/googleapis/google-cloud-go/compare/run/v1.7.0...run/v1.8.0) (2024-11-19) diff --git a/scheduler/CHANGES.md b/scheduler/CHANGES.md index 69111ece50e6..cc223281cc8d 100644 --- a/scheduler/CHANGES.md +++ b/scheduler/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.11.3](https://github.com/googleapis/google-cloud-go/compare/scheduler/v1.11.2...scheduler/v1.11.3) (2025-01-02) + + +### Bug Fixes + +* **scheduler:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.11.2](https://github.com/googleapis/google-cloud-go/compare/scheduler/v1.11.1...scheduler/v1.11.2) (2024-10-23) diff --git a/secretmanager/CHANGES.md b/secretmanager/CHANGES.md index 7c738159e62b..9a423160dec3 100644 --- a/secretmanager/CHANGES.md +++ b/secretmanager/CHANGES.md @@ -2,6 +2,13 @@ +## [1.14.3](https://github.com/googleapis/google-cloud-go/compare/secretmanager/v1.14.2...secretmanager/v1.14.3) (2025-01-02) + + +### Bug Fixes + +* **secretmanager:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.14.2](https://github.com/googleapis/google-cloud-go/compare/secretmanager/v1.14.1...secretmanager/v1.14.2) (2024-10-23) diff --git a/secretmanager/internal/version.go b/secretmanager/internal/version.go index b11f4c49d533..5cdb009d1b5d 100644 --- a/secretmanager/internal/version.go +++ b/secretmanager/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.14.2" +const Version = "1.14.3" diff --git a/securesourcemanager/CHANGES.md b/securesourcemanager/CHANGES.md index da7bc7de25d9..51637563c0e3 100644 --- a/securesourcemanager/CHANGES.md +++ b/securesourcemanager/CHANGES.md @@ -2,6 +2,13 @@ +## [1.3.1](https://github.com/googleapis/google-cloud-go/compare/securesourcemanager/v1.3.0...securesourcemanager/v1.3.1) (2025-01-02) + + +### Bug Fixes + +* **securesourcemanager:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.3.0](https://github.com/googleapis/google-cloud-go/compare/securesourcemanager/v1.2.1...securesourcemanager/v1.3.0) (2024-10-23) diff --git a/securesourcemanager/internal/version.go b/securesourcemanager/internal/version.go index 84843770cb79..ee1916635665 100644 --- a/securesourcemanager/internal/version.go +++ b/securesourcemanager/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.3.0" +const Version = "1.3.1" diff --git a/security/CHANGES.md b/security/CHANGES.md index 05976e075fb3..3211f66f834a 100644 --- a/security/CHANGES.md +++ b/security/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.18.3](https://github.com/googleapis/google-cloud-go/compare/security/v1.18.2...security/v1.18.3) (2025-01-02) + + +### Bug Fixes + +* **security:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.18.2](https://github.com/googleapis/google-cloud-go/compare/security/v1.18.1...security/v1.18.2) (2024-10-23) diff --git a/security/internal/version.go b/security/internal/version.go index 197f7f8d335a..3e0a8ebf3fea 100644 --- a/security/internal/version.go +++ b/security/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.18.2" +const Version = "1.18.3" diff --git a/securitycenter/CHANGES.md b/securitycenter/CHANGES.md index 96f55bb8fb96..8c05cc43e1b7 100644 --- a/securitycenter/CHANGES.md +++ b/securitycenter/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.35.3](https://github.com/googleapis/google-cloud-go/compare/securitycenter/v1.35.2...securitycenter/v1.35.3) (2025-01-02) + + +### Bug Fixes + +* **securitycenter:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.35.2](https://github.com/googleapis/google-cloud-go/compare/securitycenter/v1.35.1...securitycenter/v1.35.2) (2024-10-23) diff --git a/securitycenter/internal/version.go b/securitycenter/internal/version.go index 7203a2c987a2..2b305569898a 100644 --- a/securitycenter/internal/version.go +++ b/securitycenter/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.35.2" +const Version = "1.35.3" diff --git a/securitycentermanagement/CHANGES.md b/securitycentermanagement/CHANGES.md index f4455d96f090..7be61ca82813 100644 --- a/securitycentermanagement/CHANGES.md +++ b/securitycentermanagement/CHANGES.md @@ -2,6 +2,13 @@ +## [1.1.3](https://github.com/googleapis/google-cloud-go/compare/securitycentermanagement/v1.1.2...securitycentermanagement/v1.1.3) (2025-01-02) + + +### Bug Fixes + +* **securitycentermanagement:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.1.2](https://github.com/googleapis/google-cloud-go/compare/securitycentermanagement/v1.1.1...securitycentermanagement/v1.1.2) (2024-10-23) diff --git a/securitycentermanagement/internal/version.go b/securitycentermanagement/internal/version.go index 2eabe9755ac2..37b53333df2f 100644 --- a/securitycentermanagement/internal/version.go +++ b/securitycentermanagement/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.1.2" +const Version = "1.1.3" diff --git a/securityposture/CHANGES.md b/securityposture/CHANGES.md index 10290f3884bf..fc1b3a499770 100644 --- a/securityposture/CHANGES.md +++ b/securityposture/CHANGES.md @@ -1,5 +1,12 @@ # Changelog +## [0.2.3](https://github.com/googleapis/google-cloud-go/compare/securityposture/v0.2.2...securityposture/v0.2.3) (2025-01-02) + + +### Bug Fixes + +* **securityposture:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.2.2](https://github.com/googleapis/google-cloud-go/compare/securityposture/v0.2.1...securityposture/v0.2.2) (2024-10-23) diff --git a/securityposture/internal/version.go b/securityposture/internal/version.go index 8d343af28cdf..37101c109e28 100644 --- a/securityposture/internal/version.go +++ b/securityposture/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "0.2.2" +const Version = "0.2.3" diff --git a/servicecontrol/CHANGES.md b/servicecontrol/CHANGES.md index be23fa3d0635..02c71d5b19ec 100644 --- a/servicecontrol/CHANGES.md +++ b/servicecontrol/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.14.3](https://github.com/googleapis/google-cloud-go/compare/servicecontrol/v1.14.2...servicecontrol/v1.14.3) (2025-01-02) + + +### Bug Fixes + +* **servicecontrol:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.14.2](https://github.com/googleapis/google-cloud-go/compare/servicecontrol/v1.14.1...servicecontrol/v1.14.2) (2024-10-23) diff --git a/servicecontrol/internal/version.go b/servicecontrol/internal/version.go index b11f4c49d533..5cdb009d1b5d 100644 --- a/servicecontrol/internal/version.go +++ b/servicecontrol/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.14.2" +const Version = "1.14.3" diff --git a/servicedirectory/CHANGES.md b/servicedirectory/CHANGES.md index 30b275c57b25..80e8fe43004c 100644 --- a/servicedirectory/CHANGES.md +++ b/servicedirectory/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.12.3](https://github.com/googleapis/google-cloud-go/compare/servicedirectory/v1.12.2...servicedirectory/v1.12.3) (2025-01-02) + + +### Bug Fixes + +* **servicedirectory:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.12.2](https://github.com/googleapis/google-cloud-go/compare/servicedirectory/v1.12.1...servicedirectory/v1.12.2) (2024-10-23) diff --git a/servicehealth/CHANGES.md b/servicehealth/CHANGES.md index 840ab9faf6b7..4cee42798a35 100644 --- a/servicehealth/CHANGES.md +++ b/servicehealth/CHANGES.md @@ -1,6 +1,18 @@ # Changelog +## [1.2.1](https://github.com/googleapis/google-cloud-go/compare/servicehealth/v1.2.0...servicehealth/v1.2.1) (2025-01-02) + + +### Bug Fixes + +* **servicehealth:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + + +### Documentation + +* **servicehealth:** Update documentation for various messages ([8ebcc6d](https://github.com/googleapis/google-cloud-go/commit/8ebcc6d276fc881c3914b5a7af3265a04e718e45)) + ## [1.2.0](https://github.com/googleapis/google-cloud-go/compare/servicehealth/v1.1.3...servicehealth/v1.2.0) (2024-12-04) diff --git a/servicehealth/internal/version.go b/servicehealth/internal/version.go index edbfc72a8946..a479f896e666 100644 --- a/servicehealth/internal/version.go +++ b/servicehealth/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.2.0" +const Version = "1.2.1" diff --git a/servicemanagement/CHANGES.md b/servicemanagement/CHANGES.md index 254b1451286f..5e3cca0e11ad 100644 --- a/servicemanagement/CHANGES.md +++ b/servicemanagement/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.10.3](https://github.com/googleapis/google-cloud-go/compare/servicemanagement/v1.10.2...servicemanagement/v1.10.3) (2025-01-02) + + +### Bug Fixes + +* **servicemanagement:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.10.2](https://github.com/googleapis/google-cloud-go/compare/servicemanagement/v1.10.1...servicemanagement/v1.10.2) (2024-10-23) diff --git a/serviceusage/CHANGES.md b/serviceusage/CHANGES.md index 6bd40a1fc970..9b20ba9bb347 100644 --- a/serviceusage/CHANGES.md +++ b/serviceusage/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.9.3](https://github.com/googleapis/google-cloud-go/compare/serviceusage/v1.9.2...serviceusage/v1.9.3) (2025-01-02) + + +### Bug Fixes + +* **serviceusage:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.9.2](https://github.com/googleapis/google-cloud-go/compare/serviceusage/v1.9.1...serviceusage/v1.9.2) (2024-10-23) diff --git a/shell/CHANGES.md b/shell/CHANGES.md index d5a8a45d0f2f..8ce8e7a2f547 100644 --- a/shell/CHANGES.md +++ b/shell/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.8.3](https://github.com/googleapis/google-cloud-go/compare/shell/v1.8.2...shell/v1.8.3) (2025-01-02) + + +### Bug Fixes + +* **shell:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.8.2](https://github.com/googleapis/google-cloud-go/compare/shell/v1.8.1...shell/v1.8.2) (2024-10-23) diff --git a/shopping/CHANGES.md b/shopping/CHANGES.md index 735757850932..78da617511cd 100644 --- a/shopping/CHANGES.md +++ b/shopping/CHANGES.md @@ -1,5 +1,34 @@ # Changelog +## [0.15.0](https://github.com/googleapis/google-cloud-go/compare/shopping/v0.14.0...shopping/v0.15.0) (2025-01-02) + + +### Features + +* **shopping/css:** UpdateCssProduct is added to CssProductInput proto ([8ebcc6d](https://github.com/googleapis/google-cloud-go/commit/8ebcc6d276fc881c3914b5a7af3265a04e718e45)) + + +### Bug Fixes + +* **shopping:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + + +### Documentation + +* **shopping/css:** A comment for field `applicable_countries` in message `.google.shopping.css.v1.CssProductStatus` is changed ([8ebcc6d](https://github.com/googleapis/google-cloud-go/commit/8ebcc6d276fc881c3914b5a7af3265a04e718e45)) +* **shopping/css:** A comment for field `approved_countries` in message `.google.shopping.css.v1.CssProductStatus` is changed ([8ebcc6d](https://github.com/googleapis/google-cloud-go/commit/8ebcc6d276fc881c3914b5a7af3265a04e718e45)) +* **shopping/css:** A comment for field `disapproved_countries` in message `.google.shopping.css.v1.CssProductStatus` is changed ([8ebcc6d](https://github.com/googleapis/google-cloud-go/commit/8ebcc6d276fc881c3914b5a7af3265a04e718e45)) +* **shopping/css:** A comment for field `feed_id` in message`.google.shopping.css.v1.InsertCssProductInputRequest` is changed ([8ebcc6d](https://github.com/googleapis/google-cloud-go/commit/8ebcc6d276fc881c3914b5a7af3265a04e718e45)) +* **shopping/css:** A comment for field `headline_offer_price` in message `.google.shopping.css.v1.Attributes` is changed ([8ebcc6d](https://github.com/googleapis/google-cloud-go/commit/8ebcc6d276fc881c3914b5a7af3265a04e718e45)) +* **shopping/css:** A comment for field `headline_offer_shipping_price` in message `.google.shopping.css.v1.Attributes` is changed ([8ebcc6d](https://github.com/googleapis/google-cloud-go/commit/8ebcc6d276fc881c3914b5a7af3265a04e718e45)) +* **shopping/css:** A comment for field `high_price` in message `.google.shopping.css.v1.Attributes` is changed ([8ebcc6d](https://github.com/googleapis/google-cloud-go/commit/8ebcc6d276fc881c3914b5a7af3265a04e718e45)) +* **shopping/css:** A comment for field `low_price` in message `.google.shopping.css.v1.Attributes` is changed ([8ebcc6d](https://github.com/googleapis/google-cloud-go/commit/8ebcc6d276fc881c3914b5a7af3265a04e718e45)) +* **shopping/css:** A comment for field `number_of_offers` in message `.google.shopping.css.v1.Attributes` is changed ([8ebcc6d](https://github.com/googleapis/google-cloud-go/commit/8ebcc6d276fc881c3914b5a7af3265a04e718e45)) +* **shopping/css:** A comment for field `page_size` in message `.google.shopping.css.v1.ListChildAccountsRequest` is changed ([8ebcc6d](https://github.com/googleapis/google-cloud-go/commit/8ebcc6d276fc881c3914b5a7af3265a04e718e45)) +* **shopping/css:** A comment for field `pending_countries` in message `.google.shopping.css.v1.CssProductStatus` is changed ([8ebcc6d](https://github.com/googleapis/google-cloud-go/commit/8ebcc6d276fc881c3914b5a7af3265a04e718e45)) +* **shopping/css:** A comment for field `servability` in message `.google.shopping.css.v1.CssProductStatus` is changed ([8ebcc6d](https://github.com/googleapis/google-cloud-go/commit/8ebcc6d276fc881c3914b5a7af3265a04e718e45)) +* **shopping/css:** A comment for message `CssProduct` is changed ([8ebcc6d](https://github.com/googleapis/google-cloud-go/commit/8ebcc6d276fc881c3914b5a7af3265a04e718e45)) + ## [0.14.0](https://github.com/googleapis/google-cloud-go/compare/shopping/v0.13.0...shopping/v0.14.0) (2024-12-18) diff --git a/shopping/internal/version.go b/shopping/internal/version.go index 0c85fb77ad63..1e429fbf7e1e 100644 --- a/shopping/internal/version.go +++ b/shopping/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "0.14.0" +const Version = "0.15.0" diff --git a/speech/CHANGES.md b/speech/CHANGES.md index 1f00d25c2540..e29dda4c974f 100644 --- a/speech/CHANGES.md +++ b/speech/CHANGES.md @@ -1,5 +1,22 @@ # Changes +## [1.26.0](https://github.com/googleapis/google-cloud-go/compare/speech/v1.25.2...speech/v1.26.0) (2025-01-02) + + +### Features + +* **speech:** Expand the set of supported explicit audio encodings ([8ebcc6d](https://github.com/googleapis/google-cloud-go/commit/8ebcc6d276fc881c3914b5a7af3265a04e718e45)) + + +### Bug Fixes + +* **speech:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + + +### Documentation + +* **speech:** Updated ExplicitDecodingConfig documentation to reflect changes related to newly supported encodings ([8ebcc6d](https://github.com/googleapis/google-cloud-go/commit/8ebcc6d276fc881c3914b5a7af3265a04e718e45)) + ## [1.25.2](https://github.com/googleapis/google-cloud-go/compare/speech/v1.25.1...speech/v1.25.2) (2024-10-23) diff --git a/speech/internal/version.go b/speech/internal/version.go index beed6aa5d395..dc70dd2f630d 100644 --- a/speech/internal/version.go +++ b/speech/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.25.2" +const Version = "1.26.0" diff --git a/storageinsights/CHANGES.md b/storageinsights/CHANGES.md index 298179dceccc..577af117b512 100644 --- a/storageinsights/CHANGES.md +++ b/storageinsights/CHANGES.md @@ -1,6 +1,13 @@ # Changelog +## [1.1.3](https://github.com/googleapis/google-cloud-go/compare/storageinsights/v1.1.2...storageinsights/v1.1.3) (2025-01-02) + + +### Bug Fixes + +* **storageinsights:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.1.2](https://github.com/googleapis/google-cloud-go/compare/storageinsights/v1.1.1...storageinsights/v1.1.2) (2024-10-23) diff --git a/storagetransfer/CHANGES.md b/storagetransfer/CHANGES.md index e2e33d21a2df..ad74a9964b3c 100644 --- a/storagetransfer/CHANGES.md +++ b/storagetransfer/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.12.1](https://github.com/googleapis/google-cloud-go/compare/storagetransfer/v1.12.0...storagetransfer/v1.12.1) (2025-01-02) + + +### Bug Fixes + +* **storagetransfer:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.12.0](https://github.com/googleapis/google-cloud-go/compare/storagetransfer/v1.11.2...storagetransfer/v1.12.0) (2024-12-18) diff --git a/streetview/CHANGES.md b/streetview/CHANGES.md index 98270a1ee0da..ee61f8045a55 100644 --- a/streetview/CHANGES.md +++ b/streetview/CHANGES.md @@ -1,5 +1,12 @@ # Changelog +## [0.2.3](https://github.com/googleapis/google-cloud-go/compare/streetview/v0.2.2...streetview/v0.2.3) (2025-01-02) + + +### Bug Fixes + +* **streetview:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.2.2](https://github.com/googleapis/google-cloud-go/compare/streetview/v0.2.1...streetview/v0.2.2) (2024-10-23) diff --git a/streetview/internal/version.go b/streetview/internal/version.go index 8d343af28cdf..37101c109e28 100644 --- a/streetview/internal/version.go +++ b/streetview/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "0.2.2" +const Version = "0.2.3" diff --git a/support/CHANGES.md b/support/CHANGES.md index e6911b1f9c3e..11c59639f3ee 100644 --- a/support/CHANGES.md +++ b/support/CHANGES.md @@ -1,6 +1,13 @@ # Changelog +## [1.1.3](https://github.com/googleapis/google-cloud-go/compare/support/v1.1.2...support/v1.1.3) (2025-01-02) + + +### Bug Fixes + +* **support:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.1.2](https://github.com/googleapis/google-cloud-go/compare/support/v1.1.1...support/v1.1.2) (2024-10-23) diff --git a/talent/CHANGES.md b/talent/CHANGES.md index b08e795b72da..63109af64cf8 100644 --- a/talent/CHANGES.md +++ b/talent/CHANGES.md @@ -1,6 +1,13 @@ # Changes +## [1.7.3](https://github.com/googleapis/google-cloud-go/compare/talent/v1.7.2...talent/v1.7.3) (2025-01-02) + + +### Bug Fixes + +* **talent:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.7.2](https://github.com/googleapis/google-cloud-go/compare/talent/v1.7.1...talent/v1.7.2) (2024-10-23) diff --git a/telcoautomation/CHANGES.md b/telcoautomation/CHANGES.md index 10d5c0e48c44..c7265c484891 100644 --- a/telcoautomation/CHANGES.md +++ b/telcoautomation/CHANGES.md @@ -2,6 +2,13 @@ +## [1.1.3](https://github.com/googleapis/google-cloud-go/compare/telcoautomation/v1.1.2...telcoautomation/v1.1.3) (2025-01-02) + + +### Bug Fixes + +* **telcoautomation:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.1.2](https://github.com/googleapis/google-cloud-go/compare/telcoautomation/v1.1.1...telcoautomation/v1.1.2) (2024-10-23) diff --git a/telcoautomation/internal/version.go b/telcoautomation/internal/version.go index 2eabe9755ac2..37b53333df2f 100644 --- a/telcoautomation/internal/version.go +++ b/telcoautomation/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.1.2" +const Version = "1.1.3" diff --git a/texttospeech/CHANGES.md b/texttospeech/CHANGES.md index 865979261392..c04de458333d 100644 --- a/texttospeech/CHANGES.md +++ b/texttospeech/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.10.1](https://github.com/googleapis/google-cloud-go/compare/texttospeech/v1.10.0...texttospeech/v1.10.1) (2025-01-02) + + +### Bug Fixes + +* **texttospeech:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.10.0](https://github.com/googleapis/google-cloud-go/compare/texttospeech/v1.9.0...texttospeech/v1.10.0) (2024-11-06) diff --git a/tpu/CHANGES.md b/tpu/CHANGES.md index 4a0ea3c11f4b..6475dbfafc89 100644 --- a/tpu/CHANGES.md +++ b/tpu/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.7.3](https://github.com/googleapis/google-cloud-go/compare/tpu/v1.7.2...tpu/v1.7.3) (2025-01-02) + + +### Bug Fixes + +* **tpu:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.7.2](https://github.com/googleapis/google-cloud-go/compare/tpu/v1.7.1...tpu/v1.7.2) (2024-10-23) diff --git a/trace/CHANGES.md b/trace/CHANGES.md index 9eb25542338e..10813cf43919 100644 --- a/trace/CHANGES.md +++ b/trace/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.11.3](https://github.com/googleapis/google-cloud-go/compare/trace/v1.11.2...trace/v1.11.3) (2025-01-02) + + +### Bug Fixes + +* **trace:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.11.2](https://github.com/googleapis/google-cloud-go/compare/trace/v1.11.1...trace/v1.11.2) (2024-10-23) diff --git a/translate/CHANGES.md b/translate/CHANGES.md index e248fa068798..7fa4d25cd745 100644 --- a/translate/CHANGES.md +++ b/translate/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.12.3](https://github.com/googleapis/google-cloud-go/compare/translate/v1.12.2...translate/v1.12.3) (2025-01-02) + + +### Bug Fixes + +* **translate:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.12.2](https://github.com/googleapis/google-cloud-go/compare/translate/v1.12.1...translate/v1.12.2) (2024-10-23) diff --git a/translate/internal/version.go b/translate/internal/version.go index 9bdd55160135..2bf78ba84042 100644 --- a/translate/internal/version.go +++ b/translate/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.12.2" +const Version = "1.12.3" diff --git a/video/CHANGES.md b/video/CHANGES.md index 2d6e3e2808b8..96f85793740b 100644 --- a/video/CHANGES.md +++ b/video/CHANGES.md @@ -1,6 +1,13 @@ # Changes +## [1.23.3](https://github.com/googleapis/google-cloud-go/compare/video/v1.23.2...video/v1.23.3) (2025-01-02) + + +### Bug Fixes + +* **video:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.23.2](https://github.com/googleapis/google-cloud-go/compare/video/v1.23.1...video/v1.23.2) (2024-10-23) diff --git a/video/internal/version.go b/video/internal/version.go index 5692fd4adee6..540ad16ac491 100644 --- a/video/internal/version.go +++ b/video/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.23.2" +const Version = "1.23.3" diff --git a/videointelligence/CHANGES.md b/videointelligence/CHANGES.md index 4933ede4b790..4b946b63859c 100644 --- a/videointelligence/CHANGES.md +++ b/videointelligence/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.12.3](https://github.com/googleapis/google-cloud-go/compare/videointelligence/v1.12.2...videointelligence/v1.12.3) (2025-01-02) + + +### Bug Fixes + +* **videointelligence:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.12.2](https://github.com/googleapis/google-cloud-go/compare/videointelligence/v1.12.1...videointelligence/v1.12.2) (2024-10-23) diff --git a/vision/CHANGES.md b/vision/CHANGES.md index 62a9532283dd..9adffa07140d 100644 --- a/vision/CHANGES.md +++ b/vision/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [2.9.3](https://github.com/googleapis/google-cloud-go/compare/vision/v2.9.2...vision/v2.9.3) (2025-01-02) + + +### Bug Fixes + +* **vision:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [2.9.2](https://github.com/googleapis/google-cloud-go/compare/vision/v2.9.1...vision/v2.9.2) (2024-10-23) diff --git a/vision/internal/version.go b/vision/internal/version.go index 0e8665c948ae..22ed9884c6d5 100644 --- a/vision/internal/version.go +++ b/vision/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "2.9.2" +const Version = "2.9.3" diff --git a/visionai/CHANGES.md b/visionai/CHANGES.md index 6b981563174d..c2f09ef7d1bd 100644 --- a/visionai/CHANGES.md +++ b/visionai/CHANGES.md @@ -1,5 +1,12 @@ # Changelog +## [0.4.3](https://github.com/googleapis/google-cloud-go/compare/visionai/v0.4.2...visionai/v0.4.3) (2025-01-02) + + +### Bug Fixes + +* **visionai:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [0.4.2](https://github.com/googleapis/google-cloud-go/compare/visionai/v0.4.1...visionai/v0.4.2) (2024-10-23) diff --git a/visionai/internal/version.go b/visionai/internal/version.go index 228a129bc30c..9740022c5ac3 100644 --- a/visionai/internal/version.go +++ b/visionai/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "0.4.2" +const Version = "0.4.3" diff --git a/vmmigration/CHANGES.md b/vmmigration/CHANGES.md index 45a2a98b4d47..908f4121e193 100644 --- a/vmmigration/CHANGES.md +++ b/vmmigration/CHANGES.md @@ -1,6 +1,13 @@ # Changes +## [1.8.3](https://github.com/googleapis/google-cloud-go/compare/vmmigration/v1.8.2...vmmigration/v1.8.3) (2025-01-02) + + +### Bug Fixes + +* **vmmigration:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.8.2](https://github.com/googleapis/google-cloud-go/compare/vmmigration/v1.8.1...vmmigration/v1.8.2) (2024-10-23) diff --git a/vmwareengine/CHANGES.md b/vmwareengine/CHANGES.md index 4c3a7eda53b2..29445875b04c 100644 --- a/vmwareengine/CHANGES.md +++ b/vmwareengine/CHANGES.md @@ -1,6 +1,13 @@ # Changelog +## [1.3.3](https://github.com/googleapis/google-cloud-go/compare/vmwareengine/v1.3.2...vmwareengine/v1.3.3) (2025-01-02) + + +### Bug Fixes + +* **vmwareengine:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.3.2](https://github.com/googleapis/google-cloud-go/compare/vmwareengine/v1.3.1...vmwareengine/v1.3.2) (2024-10-23) diff --git a/vmwareengine/internal/version.go b/vmwareengine/internal/version.go index f53fbf7a3002..95fd3865393d 100644 --- a/vmwareengine/internal/version.go +++ b/vmwareengine/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.3.2" +const Version = "1.3.3" diff --git a/vpcaccess/CHANGES.md b/vpcaccess/CHANGES.md index 9756748138ae..ca8e7c3a670a 100644 --- a/vpcaccess/CHANGES.md +++ b/vpcaccess/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.8.3](https://github.com/googleapis/google-cloud-go/compare/vpcaccess/v1.8.2...vpcaccess/v1.8.3) (2025-01-02) + + +### Bug Fixes + +* **vpcaccess:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.8.2](https://github.com/googleapis/google-cloud-go/compare/vpcaccess/v1.8.1...vpcaccess/v1.8.2) (2024-10-23) diff --git a/webrisk/CHANGES.md b/webrisk/CHANGES.md index 47511b789173..431b34439c6d 100644 --- a/webrisk/CHANGES.md +++ b/webrisk/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.10.3](https://github.com/googleapis/google-cloud-go/compare/webrisk/v1.10.2...webrisk/v1.10.3) (2025-01-02) + + +### Bug Fixes + +* **webrisk:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.10.2](https://github.com/googleapis/google-cloud-go/compare/webrisk/v1.10.1...webrisk/v1.10.2) (2024-10-23) diff --git a/websecurityscanner/CHANGES.md b/websecurityscanner/CHANGES.md index 1c5de4c4d6bd..f36d64681505 100644 --- a/websecurityscanner/CHANGES.md +++ b/websecurityscanner/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.7.3](https://github.com/googleapis/google-cloud-go/compare/websecurityscanner/v1.7.2...websecurityscanner/v1.7.3) (2025-01-02) + + +### Bug Fixes + +* **websecurityscanner:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.7.2](https://github.com/googleapis/google-cloud-go/compare/websecurityscanner/v1.7.1...websecurityscanner/v1.7.2) (2024-10-23) diff --git a/workflows/CHANGES.md b/workflows/CHANGES.md index 3aca3ef6341f..1c87a7fa92b4 100644 --- a/workflows/CHANGES.md +++ b/workflows/CHANGES.md @@ -1,5 +1,12 @@ # Changes +## [1.13.3](https://github.com/googleapis/google-cloud-go/compare/workflows/v1.13.2...workflows/v1.13.3) (2025-01-02) + + +### Bug Fixes + +* **workflows:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.13.2](https://github.com/googleapis/google-cloud-go/compare/workflows/v1.13.1...workflows/v1.13.2) (2024-10-23) diff --git a/workstations/CHANGES.md b/workstations/CHANGES.md index 0c7aada28bca..ec03832ad825 100644 --- a/workstations/CHANGES.md +++ b/workstations/CHANGES.md @@ -2,6 +2,13 @@ +## [1.1.3](https://github.com/googleapis/google-cloud-go/compare/workstations/v1.1.2...workstations/v1.1.3) (2025-01-02) + + +### Bug Fixes + +* **workstations:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) + ## [1.1.2](https://github.com/googleapis/google-cloud-go/compare/workstations/v1.1.1...workstations/v1.1.2) (2024-10-23) diff --git a/workstations/internal/version.go b/workstations/internal/version.go index 2eabe9755ac2..37b53333df2f 100644 --- a/workstations/internal/version.go +++ b/workstations/internal/version.go @@ -17,4 +17,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.1.2" +const Version = "1.1.3" From 2320c35ad9a7244c992bfe528e8d49fdc4089369 Mon Sep 17 00:00:00 2001 From: Baha Aiman Date: Thu, 2 Jan 2025 12:16:36 -0800 Subject: [PATCH 13/16] feat(firestore): Add String method for Update struct (#11355) --- firestore/docref.go | 16 ++++++++++++++++ 1 file changed, 16 insertions(+) diff --git a/firestore/docref.go b/firestore/docref.go index 97302868b10e..95cedf38592c 100644 --- a/firestore/docref.go +++ b/firestore/docref.go @@ -509,6 +509,13 @@ type transform struct { err error } +func (t transform) String() string { + if t.t == nil { + return "" + } + return t.t.String() +} + // FieldTransformIncrement returns a special value that can be used with Set, Create, or // Update that tells the server to transform the field's current value // by the given value. @@ -664,6 +671,15 @@ type Update struct { Value interface{} } +// String returns string representation of firestore.Update +func (u Update) String() string { + t, ok := u.Value.(transform) + if !ok { + return fmt.Sprintf("Path: %s FieldPath: %s Value: %s", u.Path, u.FieldPath, u.Value) + } + return fmt.Sprintf("Path: %s FieldPath: %s Value: %s", u.Path, u.FieldPath, t.String()) +} + // An fpv is a pair of validated FieldPath and value. type fpv struct { fieldPath FieldPath From 03a579095fc75a42feb57a34a08208d43dcb9aaf Mon Sep 17 00:00:00 2001 From: "release-please[bot]" <55107282+release-please[bot]@users.noreply.github.com> Date: Thu, 2 Jan 2025 13:17:52 -0800 Subject: [PATCH 14/16] chore(main): release firestore 1.18.0 (#10853) Co-authored-by: release-please[bot] <55107282+release-please[bot]@users.noreply.github.com> --- .release-please-manifest-individual.json | 2 +- firestore/CHANGES.md | 19 ++++++++++++++++++- firestore/internal/version.go | 2 +- 3 files changed, 20 insertions(+), 3 deletions(-) diff --git a/.release-please-manifest-individual.json b/.release-please-manifest-individual.json index f7c0ab189278..c92075d20bc9 100644 --- a/.release-please-manifest-individual.json +++ b/.release-please-manifest-individual.json @@ -5,7 +5,7 @@ "bigtable": "1.33.0", "datastore": "1.20.0", "errorreporting": "0.3.2", - "firestore": "1.17.0", + "firestore": "1.18.0", "logging": "1.13.0", "profiler": "0.4.2", "pubsub": "1.45.3", diff --git a/firestore/CHANGES.md b/firestore/CHANGES.md index 0aa328e0e1ae..482e65ce1dc0 100644 --- a/firestore/CHANGES.md +++ b/firestore/CHANGES.md @@ -1,5 +1,23 @@ # Changes +## [1.18.0](https://github.com/googleapis/google-cloud-go/compare/firestore/v1.17.0...firestore/v1.18.0) (2025-01-02) + + +### Features + +* **firestore:** Add String method for Update struct ([#11355](https://github.com/googleapis/google-cloud-go/issues/11355)) ([2320c35](https://github.com/googleapis/google-cloud-go/commit/2320c35ad9a7244c992bfe528e8d49fdc4089369)) +* **firestore:** Add WithCommitResponseTo TransactionOption ([#6967](https://github.com/googleapis/google-cloud-go/issues/6967)) ([eb25266](https://github.com/googleapis/google-cloud-go/commit/eb252663ad0bdabbd5de1767b42a69fd2aee54b2)) +* **firestore:** Surfacing the error returned from the service in Bulkwriter ([#10826](https://github.com/googleapis/google-cloud-go/issues/10826)) ([9ae039a](https://github.com/googleapis/google-cloud-go/commit/9ae039a38856133a2bde4c3bd70155d17538c974)) + + +### Bug Fixes + +* **firestore:** Add UTF-8 validation ([#10881](https://github.com/googleapis/google-cloud-go/issues/10881)) ([9199843](https://github.com/googleapis/google-cloud-go/commit/9199843947bc3a0fa415dba50ba2221850e0fbad)) +* **firestore:** Allow using != with nil ([#11112](https://github.com/googleapis/google-cloud-go/issues/11112)) ([5b59819](https://github.com/googleapis/google-cloud-go/commit/5b59819e2d603ef55c4cf056b70af6a08d335373)) +* **firestore:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) +* **firestore:** Update google.golang.org/api to v0.203.0 ([8bb87d5](https://github.com/googleapis/google-cloud-go/commit/8bb87d56af1cba736e0fe243979723e747e5e11e)) +* **firestore:** WARNING: On approximately Dec 1, 2024, an update to Protobuf will change service registration function signatures to use an interface instead of a concrete type in generated .pb.go files. This change is expected to affect very few if any users of this client library. For more information, see https://togithub.com/googleapis/google-cloud-go/issues/11020. ([8bb87d5](https://github.com/googleapis/google-cloud-go/commit/8bb87d56af1cba736e0fe243979723e747e5e11e)) + ## [1.17.0](https://github.com/googleapis/google-cloud-go/compare/firestore/v1.16.0...firestore/v1.17.0) (2024-09-11) @@ -249,4 +267,3 @@ This is the first tag to carve out firestore as its own module. See: https://github.com/golang/go/wiki/Modules#is-it-possible-to-add-a-module-to-a-multi-module-repository. - diff --git a/firestore/internal/version.go b/firestore/internal/version.go index 6607c695d5cb..ddddbd21f21f 100644 --- a/firestore/internal/version.go +++ b/firestore/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.17.0" +const Version = "1.18.0" From 9d60b40e9ce47aba2f027b42bfdbfed43339df6d Mon Sep 17 00:00:00 2001 From: "gcf-owl-bot[bot]" <78513119+gcf-owl-bot[bot]@users.noreply.github.com> Date: Thu, 2 Jan 2025 23:06:28 +0000 Subject: [PATCH 15/16] chore: update gapic-generator-go to 0.50.0 (#11362) - [ ] Regenerate this pull request now. PiperOrigin-RevId: 711471949 Source-Link: https://togithub.com/googleapis/googleapis/commit/837b4193fa5803767bd493b969243da90d75aab7 Source-Link: https://togithub.com/googleapis/googleapis-gen/commit/c7bbba2e3bbd7c1005defc14c25a8270aca2e28c Copy-Tag: eyJwIjoiLmdpdGh1Yi8uT3dsQm90LnlhbWwiLCJoIjoiYzdiYmJhMmUzYmJkN2MxMDA1ZGVmYzE0YzI1YTgyNzBhY2EyZTI4YyJ9 BEGIN_NESTED_COMMIT docs(datacatalog): A comment for field `parent` in message `.google.cloud.datacatalog.v1beta1.CreateTagRequest` is changed PiperOrigin-RevId: 711468302 Source-Link: https://togithub.com/googleapis/googleapis/commit/b6066108b07eba1fbbd071b31f511f937293a058 Source-Link: https://togithub.com/googleapis/googleapis-gen/commit/57963722d46e50aebc56001c87db813f272c1545 Copy-Tag: eyJwIjoiLmdpdGh1Yi8uT3dsQm90LnlhbWwiLCJoIjoiNTc5NjM3MjJkNDZlNTBhZWJjNTYwMDFjODdkYjgxM2YyNzJjMTU0NSJ9 END_NESTED_COMMIT BEGIN_NESTED_COMMIT feat(talent): A new enum `RelevanceThreshold` is added feat(talent): A new field `relevance_threshold` is added to message `.google.cloud.talent.v4beta1.SearchJobsRequest` PiperOrigin-RevId: 711468273 Source-Link: https://togithub.com/googleapis/googleapis/commit/528ea46081bccba0dcb89abd79362d3decfa37a9 Source-Link: https://togithub.com/googleapis/googleapis-gen/commit/7adb146f93505c0ba254f72a4f5dfc0243726c07 Copy-Tag: eyJwIjoiLmdpdGh1Yi8uT3dsQm90LnlhbWwiLCJoIjoiN2FkYjE0NmY5MzUwNWMwYmEyNTRmNzJhNGY1ZGZjMDI0MzcyNmMwNyJ9 END_NESTED_COMMIT BEGIN_NESTED_COMMIT docs(oracledatabase): the CloudVmClusterProperties.system_version field is no longer labeled as output only PiperOrigin-RevId: 711457154 Source-Link: https://togithub.com/googleapis/googleapis/commit/477125c188c7823d347a2cacdb168de3d71863e0 Source-Link: https://togithub.com/googleapis/googleapis-gen/commit/ecb0b8e88b07bc3f45a0b8ae4d3e3f49a951044c Copy-Tag: eyJwIjoiLmdpdGh1Yi8uT3dsQm90LnlhbWwiLCJoIjoiZWNiMGI4ZTg4YjA3YmMzZjQ1YTBiOGFlNGQzZTNmNDlhOTUxMDQ0YyJ9 END_NESTED_COMMIT --- .../apiv1/access_approval_client.go | 2 +- ...cess_approval_client_example_go123_test.go | 2 +- .../access_approval_client_example_test.go | 2 +- accessapproval/apiv1/auxiliary.go | 2 +- accessapproval/apiv1/auxiliary_go123.go | 2 +- accessapproval/apiv1/doc.go | 2 +- accessapproval/apiv1/helpers.go | 2 +- .../apiv1/access_context_manager_client.go | 2 +- ...ntext_manager_client_example_go123_test.go | 2 +- ...ess_context_manager_client_example_test.go | 2 +- accesscontextmanager/apiv1/auxiliary.go | 2 +- accesscontextmanager/apiv1/auxiliary_go123.go | 2 +- accesscontextmanager/apiv1/doc.go | 2 +- accesscontextmanager/apiv1/helpers.go | 2 +- .../apiv1/advisory_notifications_client.go | 2 +- ...notifications_client_example_go123_test.go | 2 +- ...isory_notifications_client_example_test.go | 2 +- advisorynotifications/apiv1/auxiliary.go | 2 +- .../apiv1/auxiliary_go123.go | 2 +- advisorynotifications/apiv1/doc.go | 2 +- advisorynotifications/apiv1/helpers.go | 2 +- ai/generativelanguage/apiv1/auxiliary.go | 2 +- .../apiv1/auxiliary_go123.go | 2 +- ai/generativelanguage/apiv1/doc.go | 2 +- .../apiv1/generative_client.go | 2 +- .../generative_client_example_go123_test.go | 2 +- .../apiv1/generative_client_example_test.go | 2 +- ai/generativelanguage/apiv1/helpers.go | 2 +- ai/generativelanguage/apiv1/model_client.go | 2 +- .../apiv1/model_client_example_go123_test.go | 2 +- .../apiv1/model_client_example_test.go | 2 +- ai/generativelanguage/apiv1beta/auxiliary.go | 2 +- .../apiv1beta/auxiliary_go123.go | 2 +- .../apiv1beta/cache_client.go | 2 +- .../cache_client_example_go123_test.go | 2 +- .../apiv1beta/cache_client_example_test.go | 2 +- .../apiv1beta/discuss_client.go | 2 +- .../discuss_client_example_go123_test.go | 2 +- .../apiv1beta/discuss_client_example_test.go | 2 +- ai/generativelanguage/apiv1beta/doc.go | 2 +- .../apiv1beta/file_client.go | 2 +- .../file_client_example_go123_test.go | 2 +- .../apiv1beta/file_client_example_test.go | 2 +- .../apiv1beta/generative_client.go | 2 +- .../generative_client_example_go123_test.go | 2 +- .../generative_client_example_test.go | 2 +- ai/generativelanguage/apiv1beta/helpers.go | 2 +- .../apiv1beta/model_client.go | 2 +- .../model_client_example_go123_test.go | 2 +- .../apiv1beta/model_client_example_test.go | 2 +- .../apiv1beta/permission_client.go | 2 +- .../permission_client_example_go123_test.go | 2 +- .../permission_client_example_test.go | 2 +- .../apiv1beta/prediction_client.go | 2 +- .../prediction_client_example_go123_test.go | 2 +- .../prediction_client_example_test.go | 2 +- .../apiv1beta/retriever_client.go | 2 +- .../retriever_client_example_go123_test.go | 2 +- .../retriever_client_example_test.go | 2 +- .../apiv1beta/text_client.go | 2 +- .../text_client_example_go123_test.go | 2 +- .../apiv1beta/text_client_example_test.go | 2 +- ai/generativelanguage/apiv1beta2/auxiliary.go | 2 +- .../apiv1beta2/auxiliary_go123.go | 2 +- .../apiv1beta2/discuss_client.go | 2 +- .../discuss_client_example_go123_test.go | 2 +- .../apiv1beta2/discuss_client_example_test.go | 2 +- ai/generativelanguage/apiv1beta2/doc.go | 2 +- ai/generativelanguage/apiv1beta2/helpers.go | 2 +- .../apiv1beta2/model_client.go | 2 +- .../model_client_example_go123_test.go | 2 +- .../apiv1beta2/model_client_example_test.go | 2 +- .../apiv1beta2/text_client.go | 2 +- .../text_client_example_go123_test.go | 2 +- .../apiv1beta2/text_client_example_test.go | 2 +- aiplatform/apiv1/auxiliary.go | 2 +- aiplatform/apiv1/auxiliary_go123.go | 2 +- aiplatform/apiv1/dataset_client.go | 2 +- .../dataset_client_example_go123_test.go | 2 +- .../apiv1/dataset_client_example_test.go | 2 +- .../apiv1/deployment_resource_pool_client.go | 2 +- ...resource_pool_client_example_go123_test.go | 2 +- ...yment_resource_pool_client_example_test.go | 2 +- aiplatform/apiv1/doc.go | 2 +- aiplatform/apiv1/endpoint_client.go | 2 +- .../endpoint_client_example_go123_test.go | 2 +- .../apiv1/endpoint_client_example_test.go | 2 +- aiplatform/apiv1/evaluation_client.go | 2 +- .../evaluation_client_example_go123_test.go | 2 +- .../apiv1/evaluation_client_example_test.go | 2 +- .../feature_online_store_admin_client.go | 2 +- ...e_store_admin_client_example_go123_test.go | 2 +- ..._online_store_admin_client_example_test.go | 2 +- .../apiv1/feature_online_store_client.go | 2 +- ..._online_store_client_example_go123_test.go | 2 +- ...eature_online_store_client_example_test.go | 2 +- aiplatform/apiv1/feature_registry_client.go | 2 +- ...ture_registry_client_example_go123_test.go | 2 +- .../feature_registry_client_example_test.go | 2 +- aiplatform/apiv1/featurestore_client.go | 2 +- .../featurestore_client_example_go123_test.go | 2 +- .../apiv1/featurestore_client_example_test.go | 2 +- .../featurestore_online_serving_client.go | 2 +- ...nline_serving_client_example_go123_test.go | 2 +- ...tore_online_serving_client_example_test.go | 2 +- aiplatform/apiv1/gen_ai_tuning_client.go | 2 +- ...gen_ai_tuning_client_example_go123_test.go | 2 +- .../gen_ai_tuning_client_example_test.go | 2 +- aiplatform/apiv1/helpers.go | 2 +- aiplatform/apiv1/index_client.go | 2 +- .../apiv1/index_client_example_go123_test.go | 2 +- aiplatform/apiv1/index_client_example_test.go | 2 +- aiplatform/apiv1/index_endpoint_client.go | 2 +- ...ndex_endpoint_client_example_go123_test.go | 2 +- .../index_endpoint_client_example_test.go | 2 +- aiplatform/apiv1/job_client.go | 2 +- .../apiv1/job_client_example_go123_test.go | 2 +- aiplatform/apiv1/job_client_example_test.go | 2 +- aiplatform/apiv1/llm_utility_client.go | 2 +- .../llm_utility_client_example_go123_test.go | 2 +- .../apiv1/llm_utility_client_example_test.go | 2 +- aiplatform/apiv1/match_client.go | 2 +- .../apiv1/match_client_example_go123_test.go | 2 +- aiplatform/apiv1/match_client_example_test.go | 2 +- aiplatform/apiv1/metadata_client.go | 2 +- .../metadata_client_example_go123_test.go | 2 +- .../apiv1/metadata_client_example_test.go | 2 +- aiplatform/apiv1/migration_client.go | 2 +- .../migration_client_example_go123_test.go | 2 +- .../apiv1/migration_client_example_test.go | 2 +- aiplatform/apiv1/model_client.go | 2 +- .../apiv1/model_client_example_go123_test.go | 2 +- aiplatform/apiv1/model_client_example_test.go | 2 +- aiplatform/apiv1/model_garden_client.go | 2 +- .../model_garden_client_example_go123_test.go | 2 +- .../apiv1/model_garden_client_example_test.go | 2 +- aiplatform/apiv1/notebook_client.go | 2 +- .../notebook_client_example_go123_test.go | 2 +- .../apiv1/notebook_client_example_test.go | 2 +- .../apiv1/persistent_resource_client.go | 2 +- ...tent_resource_client_example_go123_test.go | 2 +- ...persistent_resource_client_example_test.go | 2 +- aiplatform/apiv1/pipeline_client.go | 2 +- .../pipeline_client_example_go123_test.go | 2 +- .../apiv1/pipeline_client_example_test.go | 2 +- aiplatform/apiv1/prediction_client.go | 2 +- .../prediction_client_example_go123_test.go | 2 +- .../apiv1/prediction_client_example_test.go | 2 +- aiplatform/apiv1/schedule_client.go | 2 +- .../schedule_client_example_go123_test.go | 2 +- .../apiv1/schedule_client_example_test.go | 2 +- aiplatform/apiv1/specialist_pool_client.go | 2 +- ...ecialist_pool_client_example_go123_test.go | 2 +- .../specialist_pool_client_example_test.go | 2 +- aiplatform/apiv1/tensorboard_client.go | 2 +- .../tensorboard_client_example_go123_test.go | 2 +- .../apiv1/tensorboard_client_example_test.go | 2 +- aiplatform/apiv1/vertex_rag_client.go | 2 +- .../vertex_rag_client_example_go123_test.go | 2 +- .../apiv1/vertex_rag_client_example_test.go | 2 +- aiplatform/apiv1/vertex_rag_data_client.go | 2 +- ...rtex_rag_data_client_example_go123_test.go | 2 +- .../vertex_rag_data_client_example_test.go | 2 +- aiplatform/apiv1/vizier_client.go | 2 +- .../apiv1/vizier_client_example_go123_test.go | 2 +- .../apiv1/vizier_client_example_test.go | 2 +- aiplatform/apiv1beta1/auxiliary.go | 2 +- aiplatform/apiv1beta1/auxiliary_go123.go | 2 +- aiplatform/apiv1beta1/dataset_client.go | 2 +- .../dataset_client_example_go123_test.go | 2 +- .../apiv1beta1/dataset_client_example_test.go | 2 +- .../deployment_resource_pool_client.go | 2 +- ...resource_pool_client_example_go123_test.go | 2 +- ...yment_resource_pool_client_example_test.go | 2 +- aiplatform/apiv1beta1/doc.go | 2 +- aiplatform/apiv1beta1/endpoint_client.go | 2 +- .../endpoint_client_example_go123_test.go | 2 +- .../endpoint_client_example_test.go | 2 +- aiplatform/apiv1beta1/evaluation_client.go | 2 +- .../evaluation_client_example_go123_test.go | 2 +- .../evaluation_client_example_test.go | 2 +- .../apiv1beta1/extension_execution_client.go | 2 +- ...ion_execution_client_example_go123_test.go | 2 +- ...extension_execution_client_example_test.go | 2 +- .../apiv1beta1/extension_registry_client.go | 2 +- ...sion_registry_client_example_go123_test.go | 2 +- .../extension_registry_client_example_test.go | 2 +- .../feature_online_store_admin_client.go | 2 +- ...e_store_admin_client_example_go123_test.go | 2 +- ..._online_store_admin_client_example_test.go | 2 +- .../apiv1beta1/feature_online_store_client.go | 2 +- ..._online_store_client_example_go123_test.go | 2 +- ...eature_online_store_client_example_test.go | 2 +- .../apiv1beta1/feature_registry_client.go | 2 +- ...ture_registry_client_example_go123_test.go | 2 +- .../feature_registry_client_example_test.go | 2 +- aiplatform/apiv1beta1/featurestore_client.go | 2 +- .../featurestore_client_example_go123_test.go | 2 +- .../featurestore_client_example_test.go | 2 +- .../featurestore_online_serving_client.go | 2 +- ...nline_serving_client_example_go123_test.go | 2 +- ...tore_online_serving_client_example_test.go | 2 +- aiplatform/apiv1beta1/gen_ai_cache_client.go | 2 +- .../gen_ai_cache_client_example_go123_test.go | 2 +- .../gen_ai_cache_client_example_test.go | 2 +- aiplatform/apiv1beta1/gen_ai_tuning_client.go | 2 +- ...gen_ai_tuning_client_example_go123_test.go | 2 +- .../gen_ai_tuning_client_example_test.go | 2 +- aiplatform/apiv1beta1/helpers.go | 2 +- aiplatform/apiv1beta1/index_client.go | 2 +- .../index_client_example_go123_test.go | 2 +- .../apiv1beta1/index_client_example_test.go | 2 +- .../apiv1beta1/index_endpoint_client.go | 2 +- ...ndex_endpoint_client_example_go123_test.go | 2 +- .../index_endpoint_client_example_test.go | 2 +- aiplatform/apiv1beta1/job_client.go | 2 +- .../job_client_example_go123_test.go | 2 +- .../apiv1beta1/job_client_example_test.go | 2 +- aiplatform/apiv1beta1/llm_utility_client.go | 2 +- .../llm_utility_client_example_go123_test.go | 2 +- .../llm_utility_client_example_test.go | 2 +- aiplatform/apiv1beta1/match_client.go | 2 +- .../match_client_example_go123_test.go | 2 +- .../apiv1beta1/match_client_example_test.go | 2 +- aiplatform/apiv1beta1/metadata_client.go | 2 +- .../metadata_client_example_go123_test.go | 2 +- .../metadata_client_example_test.go | 2 +- aiplatform/apiv1beta1/migration_client.go | 2 +- .../migration_client_example_go123_test.go | 2 +- .../migration_client_example_test.go | 2 +- aiplatform/apiv1beta1/model_client.go | 2 +- .../model_client_example_go123_test.go | 2 +- .../apiv1beta1/model_client_example_test.go | 2 +- aiplatform/apiv1beta1/model_garden_client.go | 2 +- .../model_garden_client_example_go123_test.go | 2 +- .../model_garden_client_example_test.go | 2 +- .../apiv1beta1/model_monitoring_client.go | 2 +- ...el_monitoring_client_example_go123_test.go | 2 +- .../model_monitoring_client_example_test.go | 2 +- aiplatform/apiv1beta1/notebook_client.go | 2 +- .../notebook_client_example_go123_test.go | 2 +- .../notebook_client_example_test.go | 2 +- .../apiv1beta1/persistent_resource_client.go | 2 +- ...tent_resource_client_example_go123_test.go | 2 +- ...persistent_resource_client_example_test.go | 2 +- aiplatform/apiv1beta1/pipeline_client.go | 2 +- .../pipeline_client_example_go123_test.go | 2 +- .../pipeline_client_example_test.go | 2 +- aiplatform/apiv1beta1/prediction_client.go | 2 +- .../prediction_client_example_go123_test.go | 2 +- .../prediction_client_example_test.go | 2 +- .../apiv1beta1/reasoning_engine_client.go | 2 +- ...soning_engine_client_example_go123_test.go | 2 +- .../reasoning_engine_client_example_test.go | 2 +- .../reasoning_engine_execution_client.go | 2 +- ...ine_execution_client_example_go123_test.go | 2 +- ...ng_engine_execution_client_example_test.go | 2 +- aiplatform/apiv1beta1/schedule_client.go | 2 +- .../schedule_client_example_go123_test.go | 2 +- .../schedule_client_example_test.go | 2 +- .../apiv1beta1/specialist_pool_client.go | 2 +- ...ecialist_pool_client_example_go123_test.go | 2 +- .../specialist_pool_client_example_test.go | 2 +- aiplatform/apiv1beta1/tensorboard_client.go | 2 +- .../tensorboard_client_example_go123_test.go | 2 +- .../tensorboard_client_example_test.go | 2 +- aiplatform/apiv1beta1/vertex_rag_client.go | 2 +- .../vertex_rag_client_example_go123_test.go | 2 +- .../vertex_rag_client_example_test.go | 2 +- .../apiv1beta1/vertex_rag_data_client.go | 2 +- ...rtex_rag_data_client_example_go123_test.go | 2 +- .../vertex_rag_data_client_example_test.go | 2 +- aiplatform/apiv1beta1/vizier_client.go | 2 +- .../vizier_client_example_go123_test.go | 2 +- .../apiv1beta1/vizier_client_example_test.go | 2 +- alloydb/apiv1/alloydb_admin_client.go | 2 +- ...alloydb_admin_client_example_go123_test.go | 2 +- .../alloydb_admin_client_example_test.go | 2 +- alloydb/apiv1/auxiliary.go | 2 +- alloydb/apiv1/auxiliary_go123.go | 2 +- alloydb/apiv1/doc.go | 2 +- alloydb/apiv1/helpers.go | 2 +- alloydb/apiv1alpha/alloydb_admin_client.go | 2 +- ...alloydb_admin_client_example_go123_test.go | 2 +- .../alloydb_admin_client_example_test.go | 2 +- alloydb/apiv1alpha/auxiliary.go | 2 +- alloydb/apiv1alpha/auxiliary_go123.go | 2 +- alloydb/apiv1alpha/doc.go | 2 +- alloydb/apiv1alpha/helpers.go | 2 +- alloydb/apiv1beta/alloydb_admin_client.go | 2 +- ...alloydb_admin_client_example_go123_test.go | 2 +- .../alloydb_admin_client_example_test.go | 2 +- alloydb/apiv1beta/auxiliary.go | 2 +- alloydb/apiv1beta/auxiliary_go123.go | 2 +- alloydb/apiv1beta/doc.go | 2 +- alloydb/apiv1beta/helpers.go | 2 +- .../apiv1alpha/analytics_admin_client.go | 2 +- ...alytics_admin_client_example_go123_test.go | 2 +- .../analytics_admin_client_example_test.go | 2 +- analytics/admin/apiv1alpha/auxiliary.go | 2 +- analytics/admin/apiv1alpha/auxiliary_go123.go | 2 +- analytics/admin/apiv1alpha/doc.go | 2 +- analytics/admin/apiv1alpha/helpers.go | 2 +- apigateway/apiv1/api_gateway_client.go | 2 +- .../api_gateway_client_example_go123_test.go | 2 +- .../apiv1/api_gateway_client_example_test.go | 2 +- apigateway/apiv1/auxiliary.go | 2 +- apigateway/apiv1/auxiliary_go123.go | 2 +- apigateway/apiv1/doc.go | 2 +- apigateway/apiv1/helpers.go | 2 +- apigeeconnect/apiv1/auxiliary.go | 2 +- apigeeconnect/apiv1/auxiliary_go123.go | 2 +- apigeeconnect/apiv1/connection_client.go | 2 +- .../connection_client_example_go123_test.go | 2 +- .../apiv1/connection_client_example_test.go | 2 +- apigeeconnect/apiv1/doc.go | 2 +- apigeeconnect/apiv1/helpers.go | 2 +- apigeeconnect/apiv1/tether_client.go | 2 +- .../apiv1/tether_client_example_go123_test.go | 2 +- .../apiv1/tether_client_example_test.go | 2 +- apigeeregistry/apiv1/auxiliary.go | 2 +- apigeeregistry/apiv1/auxiliary_go123.go | 2 +- apigeeregistry/apiv1/doc.go | 2 +- apigeeregistry/apiv1/helpers.go | 2 +- apigeeregistry/apiv1/provisioning_client.go | 2 +- .../provisioning_client_example_go123_test.go | 2 +- .../apiv1/provisioning_client_example_test.go | 2 +- apigeeregistry/apiv1/registry_client.go | 2 +- .../registry_client_example_go123_test.go | 2 +- .../apiv1/registry_client_example_test.go | 2 +- apihub/apiv1/api_hub_client.go | 2 +- .../api_hub_client_example_go123_test.go | 2 +- apihub/apiv1/api_hub_client_example_test.go | 2 +- apihub/apiv1/api_hub_dependencies_client.go | 2 +- ..._dependencies_client_example_go123_test.go | 2 +- ...pi_hub_dependencies_client_example_test.go | 2 +- apihub/apiv1/api_hub_plugin_client.go | 2 +- ...pi_hub_plugin_client_example_go123_test.go | 2 +- .../api_hub_plugin_client_example_test.go | 2 +- apihub/apiv1/auxiliary.go | 2 +- apihub/apiv1/auxiliary_go123.go | 2 +- apihub/apiv1/doc.go | 2 +- apihub/apiv1/helpers.go | 2 +- .../apiv1/host_project_registration_client.go | 2 +- ..._registration_client_example_go123_test.go | 2 +- ...roject_registration_client_example_test.go | 2 +- apihub/apiv1/linting_client.go | 2 +- .../linting_client_example_go123_test.go | 2 +- apihub/apiv1/linting_client_example_test.go | 2 +- apihub/apiv1/provisioning_client.go | 2 +- .../provisioning_client_example_go123_test.go | 2 +- .../apiv1/provisioning_client_example_test.go | 2 +- .../runtime_project_attachment_client.go | 2 +- ...ct_attachment_client_example_go123_test.go | 2 +- ..._project_attachment_client_example_test.go | 2 +- apikeys/apiv2/api_keys_client.go | 2 +- .../api_keys_client_example_go123_test.go | 2 +- apikeys/apiv2/api_keys_client_example_test.go | 2 +- apikeys/apiv2/auxiliary.go | 2 +- apikeys/apiv2/auxiliary_go123.go | 2 +- apikeys/apiv2/doc.go | 2 +- apikeys/apiv2/helpers.go | 2 +- appengine/apiv1/applications_client.go | 2 +- .../applications_client_example_go123_test.go | 2 +- .../apiv1/applications_client_example_test.go | 2 +- .../apiv1/authorized_certificates_client.go | 2 +- ..._certificates_client_example_go123_test.go | 2 +- ...orized_certificates_client_example_test.go | 2 +- appengine/apiv1/authorized_domains_client.go | 2 +- ...rized_domains_client_example_go123_test.go | 2 +- .../authorized_domains_client_example_test.go | 2 +- appengine/apiv1/auxiliary.go | 2 +- appengine/apiv1/auxiliary_go123.go | 2 +- appengine/apiv1/doc.go | 2 +- appengine/apiv1/domain_mappings_client.go | 2 +- ...main_mappings_client_example_go123_test.go | 2 +- .../domain_mappings_client_example_test.go | 2 +- appengine/apiv1/firewall_client.go | 2 +- .../firewall_client_example_go123_test.go | 2 +- .../apiv1/firewall_client_example_test.go | 2 +- appengine/apiv1/helpers.go | 2 +- appengine/apiv1/instances_client.go | 2 +- .../instances_client_example_go123_test.go | 2 +- .../apiv1/instances_client_example_test.go | 2 +- appengine/apiv1/services_client.go | 2 +- .../services_client_example_go123_test.go | 2 +- .../apiv1/services_client_example_test.go | 2 +- appengine/apiv1/versions_client.go | 2 +- .../versions_client_example_go123_test.go | 2 +- .../apiv1/versions_client_example_test.go | 2 +- apphub/apiv1/app_hub_client.go | 2 +- .../app_hub_client_example_go123_test.go | 2 +- apphub/apiv1/app_hub_client_example_test.go | 2 +- apphub/apiv1/auxiliary.go | 2 +- apphub/apiv1/auxiliary_go123.go | 2 +- apphub/apiv1/doc.go | 2 +- apphub/apiv1/helpers.go | 2 +- apps/events/subscriptions/apiv1/auxiliary.go | 2 +- .../subscriptions/apiv1/auxiliary_go123.go | 2 +- apps/events/subscriptions/apiv1/doc.go | 2 +- apps/events/subscriptions/apiv1/helpers.go | 2 +- .../apiv1/subscriptions_client.go | 2 +- ...subscriptions_client_example_go123_test.go | 2 +- .../subscriptions_client_example_test.go | 2 +- apps/meet/apiv2/auxiliary.go | 2 +- apps/meet/apiv2/auxiliary_go123.go | 2 +- apps/meet/apiv2/conference_records_client.go | 2 +- ...rence_records_client_example_go123_test.go | 2 +- .../conference_records_client_example_test.go | 2 +- apps/meet/apiv2/doc.go | 2 +- apps/meet/apiv2/helpers.go | 2 +- apps/meet/apiv2/spaces_client.go | 2 +- .../apiv2/spaces_client_example_go123_test.go | 2 +- apps/meet/apiv2/spaces_client_example_test.go | 2 +- apps/meet/apiv2beta/auxiliary.go | 2 +- apps/meet/apiv2beta/auxiliary_go123.go | 2 +- .../apiv2beta/conference_records_client.go | 2 +- ...rence_records_client_example_go123_test.go | 2 +- .../conference_records_client_example_test.go | 2 +- apps/meet/apiv2beta/doc.go | 2 +- apps/meet/apiv2beta/helpers.go | 2 +- apps/meet/apiv2beta/spaces_client.go | 2 +- .../spaces_client_example_go123_test.go | 2 +- .../apiv2beta/spaces_client_example_test.go | 2 +- area120/tables/apiv1alpha1/auxiliary.go | 2 +- area120/tables/apiv1alpha1/auxiliary_go123.go | 2 +- area120/tables/apiv1alpha1/doc.go | 2 +- area120/tables/apiv1alpha1/helpers.go | 2 +- area120/tables/apiv1alpha1/tables_client.go | 2 +- .../tables_client_example_go123_test.go | 2 +- .../apiv1alpha1/tables_client_example_test.go | 2 +- .../apiv1/artifact_registry_client.go | 2 +- ...fact_registry_client_example_go123_test.go | 2 +- .../artifact_registry_client_example_test.go | 2 +- artifactregistry/apiv1/auxiliary.go | 2 +- artifactregistry/apiv1/auxiliary_go123.go | 2 +- artifactregistry/apiv1/doc.go | 2 +- artifactregistry/apiv1/helpers.go | 2 +- .../apiv1beta2/artifact_registry_client.go | 2 +- ...fact_registry_client_example_go123_test.go | 2 +- .../artifact_registry_client_example_test.go | 2 +- artifactregistry/apiv1beta2/auxiliary.go | 2 +- .../apiv1beta2/auxiliary_go123.go | 2 +- artifactregistry/apiv1beta2/doc.go | 2 +- artifactregistry/apiv1beta2/helpers.go | 2 +- asset/apiv1/asset_client.go | 2 +- .../apiv1/asset_client_example_go123_test.go | 2 +- asset/apiv1/asset_client_example_test.go | 2 +- asset/apiv1/auxiliary.go | 2 +- asset/apiv1/auxiliary_go123.go | 2 +- asset/apiv1/doc.go | 2 +- asset/apiv1/helpers.go | 2 +- asset/apiv1p2beta1/asset_client.go | 2 +- .../asset_client_example_go123_test.go | 2 +- .../apiv1p2beta1/asset_client_example_test.go | 2 +- asset/apiv1p2beta1/auxiliary.go | 2 +- asset/apiv1p2beta1/auxiliary_go123.go | 2 +- asset/apiv1p2beta1/doc.go | 2 +- asset/apiv1p2beta1/helpers.go | 2 +- asset/apiv1p5beta1/asset_client.go | 2 +- .../asset_client_example_go123_test.go | 2 +- .../apiv1p5beta1/asset_client_example_test.go | 2 +- asset/apiv1p5beta1/auxiliary.go | 2 +- asset/apiv1p5beta1/auxiliary_go123.go | 2 +- asset/apiv1p5beta1/doc.go | 2 +- asset/apiv1p5beta1/helpers.go | 2 +- .../apiv1/assured_workloads_client.go | 2 +- ...red_workloads_client_example_go123_test.go | 2 +- .../assured_workloads_client_example_test.go | 2 +- assuredworkloads/apiv1/auxiliary.go | 2 +- assuredworkloads/apiv1/auxiliary_go123.go | 2 +- assuredworkloads/apiv1/doc.go | 2 +- assuredworkloads/apiv1/helpers.go | 2 +- .../apiv1beta1/assured_workloads_client.go | 2 +- ...red_workloads_client_example_go123_test.go | 2 +- .../assured_workloads_client_example_test.go | 2 +- assuredworkloads/apiv1beta1/auxiliary.go | 2 +- .../apiv1beta1/auxiliary_go123.go | 2 +- assuredworkloads/apiv1beta1/doc.go | 2 +- assuredworkloads/apiv1beta1/helpers.go | 2 +- automl/apiv1/auto_ml_client.go | 2 +- .../auto_ml_client_example_go123_test.go | 2 +- automl/apiv1/auto_ml_client_example_test.go | 2 +- automl/apiv1/auxiliary.go | 2 +- automl/apiv1/auxiliary_go123.go | 2 +- automl/apiv1/doc.go | 2 +- automl/apiv1/helpers.go | 2 +- automl/apiv1/prediction_client.go | 2 +- .../prediction_client_example_go123_test.go | 2 +- .../apiv1/prediction_client_example_test.go | 2 +- automl/apiv1beta1/auto_ml_client.go | 2 +- .../auto_ml_client_example_go123_test.go | 2 +- .../apiv1beta1/auto_ml_client_example_test.go | 2 +- automl/apiv1beta1/auxiliary.go | 2 +- automl/apiv1beta1/auxiliary_go123.go | 2 +- automl/apiv1beta1/doc.go | 2 +- automl/apiv1beta1/helpers.go | 2 +- automl/apiv1beta1/prediction_client.go | 2 +- .../prediction_client_example_go123_test.go | 2 +- .../prediction_client_example_test.go | 2 +- backupdr/apiv1/auxiliary.go | 2 +- backupdr/apiv1/auxiliary_go123.go | 2 +- backupdr/apiv1/backupdr_client.go | 2 +- .../backupdr_client_example_go123_test.go | 2 +- .../apiv1/backupdr_client_example_test.go | 2 +- backupdr/apiv1/doc.go | 2 +- backupdr/apiv1/helpers.go | 2 +- baremetalsolution/apiv2/auxiliary.go | 2 +- baremetalsolution/apiv2/auxiliary_go123.go | 2 +- .../apiv2/bare_metal_solution_client.go | 2 +- ...etal_solution_client_example_go123_test.go | 2 +- ...bare_metal_solution_client_example_test.go | 2 +- baremetalsolution/apiv2/doc.go | 2 +- baremetalsolution/apiv2/helpers.go | 2 +- batch/apiv1/auxiliary.go | 2 +- batch/apiv1/auxiliary_go123.go | 2 +- batch/apiv1/batch_client.go | 2 +- .../apiv1/batch_client_example_go123_test.go | 2 +- batch/apiv1/batch_client_example_test.go | 2 +- batch/apiv1/doc.go | 2 +- batch/apiv1/helpers.go | 2 +- .../apiv1/app_connections_client.go | 2 +- ...p_connections_client_example_go123_test.go | 2 +- .../app_connections_client_example_test.go | 2 +- beyondcorp/appconnections/apiv1/auxiliary.go | 2 +- .../appconnections/apiv1/auxiliary_go123.go | 2 +- beyondcorp/appconnections/apiv1/doc.go | 2 +- beyondcorp/appconnections/apiv1/helpers.go | 2 +- .../apiv1/app_connectors_client.go | 2 +- ...pp_connectors_client_example_go123_test.go | 2 +- .../app_connectors_client_example_test.go | 2 +- beyondcorp/appconnectors/apiv1/auxiliary.go | 2 +- .../appconnectors/apiv1/auxiliary_go123.go | 2 +- beyondcorp/appconnectors/apiv1/doc.go | 2 +- beyondcorp/appconnectors/apiv1/helpers.go | 2 +- .../appgateways/apiv1/app_gateways_client.go | 2 +- .../app_gateways_client_example_go123_test.go | 2 +- .../apiv1/app_gateways_client_example_test.go | 2 +- beyondcorp/appgateways/apiv1/auxiliary.go | 2 +- .../appgateways/apiv1/auxiliary_go123.go | 2 +- beyondcorp/appgateways/apiv1/doc.go | 2 +- beyondcorp/appgateways/apiv1/helpers.go | 2 +- .../apiv1/auxiliary.go | 2 +- .../apiv1/auxiliary_go123.go | 2 +- .../apiv1/client_connector_services_client.go | 2 +- ...ctor_services_client_example_go123_test.go | 2 +- ..._connector_services_client_example_test.go | 2 +- .../clientconnectorservices/apiv1/doc.go | 2 +- .../clientconnectorservices/apiv1/helpers.go | 2 +- beyondcorp/clientgateways/apiv1/auxiliary.go | 2 +- .../clientgateways/apiv1/auxiliary_go123.go | 2 +- .../apiv1/client_gateways_client.go | 2 +- ...ient_gateways_client_example_go123_test.go | 2 +- .../client_gateways_client_example_test.go | 2 +- beyondcorp/clientgateways/apiv1/doc.go | 2 +- beyondcorp/clientgateways/apiv1/helpers.go | 2 +- .../apiv1/analytics_hub_client.go | 2 +- ...analytics_hub_client_example_go123_test.go | 2 +- .../analytics_hub_client_example_test.go | 2 +- bigquery/analyticshub/apiv1/auxiliary.go | 2 +- .../analyticshub/apiv1/auxiliary_go123.go | 2 +- bigquery/analyticshub/apiv1/doc.go | 2 +- bigquery/analyticshub/apiv1/helpers.go | 2 +- bigquery/biglake/apiv1/auxiliary.go | 2 +- bigquery/biglake/apiv1/auxiliary_go123.go | 2 +- bigquery/biglake/apiv1/doc.go | 2 +- bigquery/biglake/apiv1/helpers.go | 2 +- bigquery/biglake/apiv1/metastore_client.go | 2 +- .../metastore_client_example_go123_test.go | 2 +- .../apiv1/metastore_client_example_test.go | 2 +- bigquery/biglake/apiv1alpha1/auxiliary.go | 2 +- .../biglake/apiv1alpha1/auxiliary_go123.go | 2 +- bigquery/biglake/apiv1alpha1/doc.go | 2 +- bigquery/biglake/apiv1alpha1/helpers.go | 2 +- .../biglake/apiv1alpha1/metastore_client.go | 2 +- .../metastore_client_example_go123_test.go | 2 +- .../metastore_client_example_test.go | 2 +- bigquery/connection/apiv1/auxiliary.go | 2 +- bigquery/connection/apiv1/auxiliary_go123.go | 2 +- .../connection/apiv1/connection_client.go | 2 +- .../connection_client_example_go123_test.go | 2 +- .../apiv1/connection_client_example_test.go | 2 +- bigquery/connection/apiv1/doc.go | 2 +- bigquery/connection/apiv1/helpers.go | 2 +- bigquery/connection/apiv1beta1/auxiliary.go | 2 +- .../connection/apiv1beta1/auxiliary_go123.go | 2 +- .../apiv1beta1/connection_client.go | 2 +- .../connection_client_example_go123_test.go | 2 +- .../connection_client_example_test.go | 2 +- bigquery/connection/apiv1beta1/doc.go | 2 +- bigquery/connection/apiv1beta1/helpers.go | 2 +- .../apiv1beta1/analytics_hub_client.go | 2 +- ...analytics_hub_client_example_go123_test.go | 2 +- .../analytics_hub_client_example_test.go | 2 +- bigquery/dataexchange/apiv1beta1/auxiliary.go | 2 +- .../apiv1beta1/auxiliary_go123.go | 2 +- bigquery/dataexchange/apiv1beta1/doc.go | 2 +- bigquery/dataexchange/apiv1beta1/helpers.go | 2 +- bigquery/datapolicies/apiv1/auxiliary.go | 2 +- .../datapolicies/apiv1/auxiliary_go123.go | 2 +- .../datapolicies/apiv1/data_policy_client.go | 2 +- .../data_policy_client_example_go123_test.go | 2 +- .../apiv1/data_policy_client_example_test.go | 2 +- bigquery/datapolicies/apiv1/doc.go | 2 +- bigquery/datapolicies/apiv1/helpers.go | 2 +- bigquery/datapolicies/apiv1beta1/auxiliary.go | 2 +- .../apiv1beta1/auxiliary_go123.go | 2 +- .../apiv1beta1/data_policy_client.go | 2 +- .../data_policy_client_example_go123_test.go | 2 +- .../data_policy_client_example_test.go | 2 +- bigquery/datapolicies/apiv1beta1/doc.go | 2 +- bigquery/datapolicies/apiv1beta1/helpers.go | 2 +- bigquery/datatransfer/apiv1/auxiliary.go | 2 +- .../datatransfer/apiv1/auxiliary_go123.go | 2 +- .../apiv1/data_transfer_client.go | 2 +- ...data_transfer_client_example_go123_test.go | 2 +- .../data_transfer_client_example_test.go | 2 +- bigquery/datatransfer/apiv1/doc.go | 2 +- bigquery/datatransfer/apiv1/helpers.go | 2 +- bigquery/migration/apiv2/auxiliary.go | 2 +- bigquery/migration/apiv2/auxiliary_go123.go | 2 +- bigquery/migration/apiv2/doc.go | 2 +- bigquery/migration/apiv2/helpers.go | 2 +- bigquery/migration/apiv2/migration_client.go | 2 +- .../migration_client_example_go123_test.go | 2 +- .../apiv2/migration_client_example_test.go | 2 +- bigquery/migration/apiv2alpha/auxiliary.go | 2 +- .../migration/apiv2alpha/auxiliary_go123.go | 2 +- bigquery/migration/apiv2alpha/doc.go | 2 +- bigquery/migration/apiv2alpha/helpers.go | 2 +- .../migration/apiv2alpha/migration_client.go | 2 +- .../migration_client_example_go123_test.go | 2 +- .../migration_client_example_test.go | 2 +- .../apiv2alpha/sql_translation_client.go | 2 +- ...l_translation_client_example_go123_test.go | 2 +- .../sql_translation_client_example_test.go | 2 +- bigquery/reservation/apiv1/auxiliary.go | 2 +- bigquery/reservation/apiv1/auxiliary_go123.go | 2 +- bigquery/reservation/apiv1/doc.go | 2 +- bigquery/reservation/apiv1/helpers.go | 2 +- .../reservation/apiv1/reservation_client.go | 2 +- .../reservation_client_example_go123_test.go | 2 +- .../apiv1/reservation_client_example_test.go | 2 +- bigquery/storage/apiv1/auxiliary.go | 2 +- bigquery/storage/apiv1/auxiliary_go123.go | 2 +- .../storage/apiv1/big_query_read_client.go | 2 +- ...ig_query_read_client_example_go123_test.go | 2 +- .../big_query_read_client_example_test.go | 2 +- .../storage/apiv1/big_query_write_client.go | 2 +- ...g_query_write_client_example_go123_test.go | 2 +- .../big_query_write_client_example_test.go | 2 +- bigquery/storage/apiv1/doc.go | 2 +- bigquery/storage/apiv1/helpers.go | 2 +- bigquery/storage/apiv1alpha/auxiliary.go | 2 +- .../storage/apiv1alpha/auxiliary_go123.go | 2 +- bigquery/storage/apiv1alpha/doc.go | 2 +- bigquery/storage/apiv1alpha/helpers.go | 2 +- .../apiv1alpha/metastore_partition_client.go | 2 +- ...ore_partition_client_example_go123_test.go | 2 +- ...metastore_partition_client_example_test.go | 2 +- bigquery/storage/apiv1beta1/auxiliary.go | 2 +- .../storage/apiv1beta1/auxiliary_go123.go | 2 +- .../apiv1beta1/big_query_storage_client.go | 2 +- ...query_storage_client_example_go123_test.go | 2 +- .../big_query_storage_client_example_test.go | 2 +- bigquery/storage/apiv1beta1/doc.go | 2 +- bigquery/storage/apiv1beta1/helpers.go | 2 +- bigquery/storage/apiv1beta2/auxiliary.go | 2 +- .../storage/apiv1beta2/auxiliary_go123.go | 2 +- .../apiv1beta2/big_query_read_client.go | 2 +- ...ig_query_read_client_example_go123_test.go | 2 +- .../big_query_read_client_example_test.go | 2 +- .../apiv1beta2/big_query_write_client.go | 2 +- ...g_query_write_client_example_go123_test.go | 2 +- .../big_query_write_client_example_test.go | 2 +- bigquery/storage/apiv1beta2/doc.go | 2 +- bigquery/storage/apiv1beta2/helpers.go | 2 +- billing/apiv1/auxiliary.go | 2 +- billing/apiv1/auxiliary_go123.go | 2 +- billing/apiv1/cloud_billing_client.go | 2 +- ...cloud_billing_client_example_go123_test.go | 2 +- .../cloud_billing_client_example_test.go | 2 +- billing/apiv1/cloud_catalog_client.go | 2 +- ...cloud_catalog_client_example_go123_test.go | 2 +- .../cloud_catalog_client_example_test.go | 2 +- billing/apiv1/doc.go | 2 +- billing/apiv1/helpers.go | 2 +- billing/budgets/apiv1/auxiliary.go | 2 +- billing/budgets/apiv1/auxiliary_go123.go | 2 +- billing/budgets/apiv1/budget_client.go | 2 +- .../apiv1/budget_client_example_go123_test.go | 2 +- .../apiv1/budget_client_example_test.go | 2 +- billing/budgets/apiv1/doc.go | 2 +- billing/budgets/apiv1/helpers.go | 2 +- billing/budgets/apiv1beta1/auxiliary.go | 2 +- billing/budgets/apiv1beta1/auxiliary_go123.go | 2 +- billing/budgets/apiv1beta1/budget_client.go | 2 +- .../budget_client_example_go123_test.go | 2 +- .../apiv1beta1/budget_client_example_test.go | 2 +- billing/budgets/apiv1beta1/doc.go | 2 +- billing/budgets/apiv1beta1/helpers.go | 2 +- binaryauthorization/apiv1/auxiliary.go | 2 +- binaryauthorization/apiv1/auxiliary_go123.go | 2 +- .../apiv1/binauthz_management_client.go | 2 +- ...hz_management_client_example_go123_test.go | 2 +- ...binauthz_management_client_example_test.go | 2 +- binaryauthorization/apiv1/doc.go | 2 +- binaryauthorization/apiv1/helpers.go | 2 +- .../apiv1/system_policy_client.go | 2 +- ...system_policy_client_example_go123_test.go | 2 +- .../system_policy_client_example_test.go | 2 +- .../apiv1/validation_helper_client.go | 2 +- ...dation_helper_client_example_go123_test.go | 2 +- .../validation_helper_client_example_test.go | 2 +- binaryauthorization/apiv1beta1/auxiliary.go | 2 +- .../apiv1beta1/auxiliary_go123.go | 2 +- ...uthz_management_service_v1_beta1_client.go | 2 +- ...vice_v1_beta1_client_example_go123_test.go | 2 +- ...nt_service_v1_beta1_client_example_test.go | 2 +- binaryauthorization/apiv1beta1/doc.go | 2 +- binaryauthorization/apiv1beta1/helpers.go | 2 +- .../system_policy_v1_beta1_client.go | 2 +- ...licy_v1_beta1_client_example_go123_test.go | 2 +- ...tem_policy_v1_beta1_client_example_test.go | 2 +- certificatemanager/apiv1/auxiliary.go | 2 +- certificatemanager/apiv1/auxiliary_go123.go | 2 +- .../apiv1/certificate_manager_client.go | 2 +- ...icate_manager_client_example_go123_test.go | 2 +- ...certificate_manager_client_example_test.go | 2 +- certificatemanager/apiv1/doc.go | 2 +- certificatemanager/apiv1/helpers.go | 2 +- channel/apiv1/auxiliary.go | 2 +- channel/apiv1/auxiliary_go123.go | 2 +- channel/apiv1/cloud_channel_client.go | 2 +- ...cloud_channel_client_example_go123_test.go | 2 +- .../cloud_channel_client_example_test.go | 2 +- channel/apiv1/cloud_channel_reports_client.go | 2 +- ...annel_reports_client_example_go123_test.go | 2 +- ...oud_channel_reports_client_example_test.go | 2 +- channel/apiv1/doc.go | 2 +- channel/apiv1/helpers.go | 2 +- chat/apiv1/auxiliary.go | 2 +- chat/apiv1/auxiliary_go123.go | 2 +- chat/apiv1/chat_client.go | 2 +- chat/apiv1/chat_client_example_go123_test.go | 2 +- chat/apiv1/chat_client_example_test.go | 2 +- chat/apiv1/doc.go | 2 +- chat/apiv1/helpers.go | 2 +- cloudbuild/apiv1/v2/auxiliary.go | 2 +- cloudbuild/apiv1/v2/auxiliary_go123.go | 2 +- cloudbuild/apiv1/v2/cloud_build_client.go | 2 +- .../cloud_build_client_example_go123_test.go | 2 +- .../v2/cloud_build_client_example_test.go | 2 +- cloudbuild/apiv1/v2/doc.go | 2 +- cloudbuild/apiv1/v2/helpers.go | 2 +- cloudbuild/apiv2/auxiliary.go | 2 +- cloudbuild/apiv2/auxiliary_go123.go | 2 +- cloudbuild/apiv2/doc.go | 2 +- cloudbuild/apiv2/helpers.go | 2 +- cloudbuild/apiv2/repository_manager_client.go | 2 +- ...itory_manager_client_example_go123_test.go | 2 +- .../repository_manager_client_example_test.go | 2 +- cloudcontrolspartner/apiv1/auxiliary.go | 2 +- cloudcontrolspartner/apiv1/auxiliary_go123.go | 2 +- .../cloud_controls_partner_core_client.go | 2 +- ..._partner_core_client_example_go123_test.go | 2 +- ...ntrols_partner_core_client_example_test.go | 2 +- ...loud_controls_partner_monitoring_client.go | 2 +- ...er_monitoring_client_example_go123_test.go | 2 +- ..._partner_monitoring_client_example_test.go | 2 +- cloudcontrolspartner/apiv1/doc.go | 2 +- cloudcontrolspartner/apiv1/helpers.go | 2 +- cloudcontrolspartner/apiv1beta/auxiliary.go | 2 +- .../apiv1beta/auxiliary_go123.go | 2 +- .../cloud_controls_partner_core_client.go | 2 +- ..._partner_core_client_example_go123_test.go | 2 +- ...ntrols_partner_core_client_example_test.go | 2 +- ...loud_controls_partner_monitoring_client.go | 2 +- ...er_monitoring_client_example_go123_test.go | 2 +- ..._partner_monitoring_client_example_test.go | 2 +- cloudcontrolspartner/apiv1beta/doc.go | 2 +- cloudcontrolspartner/apiv1beta/helpers.go | 2 +- clouddms/apiv1/auxiliary.go | 2 +- clouddms/apiv1/auxiliary_go123.go | 2 +- clouddms/apiv1/data_migration_client.go | 2 +- ...ata_migration_client_example_go123_test.go | 2 +- .../data_migration_client_example_test.go | 2 +- clouddms/apiv1/doc.go | 2 +- clouddms/apiv1/helpers.go | 2 +- cloudprofiler/apiv2/auxiliary.go | 2 +- cloudprofiler/apiv2/auxiliary_go123.go | 2 +- cloudprofiler/apiv2/doc.go | 2 +- cloudprofiler/apiv2/export_client.go | 2 +- .../apiv2/export_client_example_go123_test.go | 2 +- .../apiv2/export_client_example_test.go | 2 +- cloudprofiler/apiv2/helpers.go | 2 +- cloudprofiler/apiv2/profiler_client.go | 2 +- .../profiler_client_example_go123_test.go | 2 +- .../apiv2/profiler_client_example_test.go | 2 +- cloudquotas/apiv1/auxiliary.go | 2 +- cloudquotas/apiv1/auxiliary_go123.go | 2 +- cloudquotas/apiv1/cloud_quotas_client.go | 2 +- .../cloud_quotas_client_example_go123_test.go | 2 +- .../apiv1/cloud_quotas_client_example_test.go | 2 +- cloudquotas/apiv1/doc.go | 2 +- cloudquotas/apiv1/helpers.go | 2 +- cloudtasks/apiv2/auxiliary.go | 2 +- cloudtasks/apiv2/auxiliary_go123.go | 2 +- cloudtasks/apiv2/cloud_tasks_client.go | 2 +- .../cloud_tasks_client_example_go123_test.go | 2 +- .../apiv2/cloud_tasks_client_example_test.go | 2 +- cloudtasks/apiv2/doc.go | 2 +- cloudtasks/apiv2/helpers.go | 2 +- cloudtasks/apiv2beta2/auxiliary.go | 2 +- cloudtasks/apiv2beta2/auxiliary_go123.go | 2 +- cloudtasks/apiv2beta2/cloud_tasks_client.go | 2 +- .../cloud_tasks_client_example_go123_test.go | 2 +- .../cloud_tasks_client_example_test.go | 2 +- cloudtasks/apiv2beta2/doc.go | 2 +- cloudtasks/apiv2beta2/helpers.go | 2 +- cloudtasks/apiv2beta3/auxiliary.go | 2 +- cloudtasks/apiv2beta3/auxiliary_go123.go | 2 +- cloudtasks/apiv2beta3/cloud_tasks_client.go | 2 +- .../cloud_tasks_client_example_go123_test.go | 2 +- .../cloud_tasks_client_example_test.go | 2 +- cloudtasks/apiv2beta3/doc.go | 2 +- cloudtasks/apiv2beta3/helpers.go | 2 +- .../consumer/procurement/apiv1/auxiliary.go | 2 +- .../procurement/apiv1/auxiliary_go123.go | 2 +- .../apiv1/consumer_procurement_client.go | 2 +- ...r_procurement_client_example_go123_test.go | 2 +- ...onsumer_procurement_client_example_test.go | 2 +- commerce/consumer/procurement/apiv1/doc.go | 2 +- .../consumer/procurement/apiv1/helpers.go | 2 +- .../apiv1/license_management_client.go | 2 +- ...se_management_client_example_go123_test.go | 2 +- .../license_management_client_example_test.go | 2 +- compute/apiv1/accelerator_types_client.go | 2 +- ...lerator_types_client_example_go123_test.go | 2 +- .../accelerator_types_client_example_test.go | 2 +- compute/apiv1/addresses_client.go | 2 +- .../addresses_client_example_go123_test.go | 2 +- .../apiv1/addresses_client_example_test.go | 2 +- compute/apiv1/autoscalers_client.go | 2 +- .../autoscalers_client_example_go123_test.go | 2 +- .../apiv1/autoscalers_client_example_test.go | 2 +- compute/apiv1/auxiliary.go | 2 +- compute/apiv1/auxiliary_go123.go | 2 +- compute/apiv1/backend_buckets_client.go | 2 +- ...ckend_buckets_client_example_go123_test.go | 2 +- .../backend_buckets_client_example_test.go | 2 +- compute/apiv1/backend_services_client.go | 2 +- ...kend_services_client_example_go123_test.go | 2 +- .../backend_services_client_example_test.go | 2 +- compute/apiv1/disk_types_client.go | 2 +- .../disk_types_client_example_go123_test.go | 2 +- .../apiv1/disk_types_client_example_test.go | 2 +- compute/apiv1/disks_client.go | 2 +- .../apiv1/disks_client_example_go123_test.go | 2 +- compute/apiv1/disks_client_example_test.go | 2 +- compute/apiv1/doc.go | 2 +- compute/apiv1/external_vpn_gateways_client.go | 2 +- ..._vpn_gateways_client_example_go123_test.go | 2 +- ...ternal_vpn_gateways_client_example_test.go | 2 +- compute/apiv1/firewall_policies_client.go | 2 +- ...wall_policies_client_example_go123_test.go | 2 +- .../firewall_policies_client_example_test.go | 2 +- compute/apiv1/firewalls_client.go | 2 +- .../firewalls_client_example_go123_test.go | 2 +- .../apiv1/firewalls_client_example_test.go | 2 +- compute/apiv1/forwarding_rules_client.go | 2 +- ...warding_rules_client_example_go123_test.go | 2 +- .../forwarding_rules_client_example_test.go | 2 +- compute/apiv1/global_addresses_client.go | 2 +- ...bal_addresses_client_example_go123_test.go | 2 +- .../global_addresses_client_example_test.go | 2 +- .../apiv1/global_forwarding_rules_client.go | 2 +- ...warding_rules_client_example_go123_test.go | 2 +- ...al_forwarding_rules_client_example_test.go | 2 +- .../global_network_endpoint_groups_client.go | 2 +- ...dpoint_groups_client_example_go123_test.go | 2 +- ...ork_endpoint_groups_client_example_test.go | 2 +- compute/apiv1/global_operations_client.go | 2 +- ...al_operations_client_example_go123_test.go | 2 +- .../global_operations_client_example_test.go | 2 +- .../global_organization_operations_client.go | 2 +- ...on_operations_client_example_go123_test.go | 2 +- ...nization_operations_client_example_test.go | 2 +- ...global_public_delegated_prefixes_client.go | 2 +- ...ated_prefixes_client_example_go123_test.go | 2 +- ..._delegated_prefixes_client_example_test.go | 2 +- compute/apiv1/health_checks_client.go | 2 +- ...health_checks_client_example_go123_test.go | 2 +- .../health_checks_client_example_test.go | 2 +- compute/apiv1/helpers.go | 2 +- compute/apiv1/image_family_views_client.go | 2 +- ..._family_views_client_example_go123_test.go | 2 +- .../image_family_views_client_example_test.go | 2 +- compute/apiv1/images_client.go | 2 +- .../apiv1/images_client_example_go123_test.go | 2 +- compute/apiv1/images_client_example_test.go | 2 +- ...ce_group_manager_resize_requests_client.go | 2 +- ...size_requests_client_example_go123_test.go | 2 +- ...ger_resize_requests_client_example_test.go | 2 +- .../apiv1/instance_group_managers_client.go | 2 +- ...roup_managers_client_example_go123_test.go | 2 +- ...ance_group_managers_client_example_test.go | 2 +- compute/apiv1/instance_groups_client.go | 2 +- ...stance_groups_client_example_go123_test.go | 2 +- .../instance_groups_client_example_test.go | 2 +- compute/apiv1/instance_settings_client.go | 2 +- ...ance_settings_client_example_go123_test.go | 2 +- .../instance_settings_client_example_test.go | 2 +- compute/apiv1/instance_templates_client.go | 2 +- ...nce_templates_client_example_go123_test.go | 2 +- .../instance_templates_client_example_test.go | 2 +- compute/apiv1/instances_client.go | 2 +- .../instances_client_example_go123_test.go | 2 +- .../apiv1/instances_client_example_test.go | 2 +- compute/apiv1/instant_snapshots_client.go | 2 +- ...ant_snapshots_client_example_go123_test.go | 2 +- .../instant_snapshots_client_example_test.go | 2 +- .../apiv1/interconnect_attachments_client.go | 2 +- ...t_attachments_client_example_go123_test.go | 2 +- ...connect_attachments_client_example_test.go | 2 +- .../apiv1/interconnect_locations_client.go | 2 +- ...ect_locations_client_example_go123_test.go | 2 +- ...erconnect_locations_client_example_test.go | 2 +- .../interconnect_remote_locations_client.go | 2 +- ...ote_locations_client_example_go123_test.go | 2 +- ...ct_remote_locations_client_example_test.go | 2 +- compute/apiv1/interconnects_client.go | 2 +- ...interconnects_client_example_go123_test.go | 2 +- .../interconnects_client_example_test.go | 2 +- compute/apiv1/license_codes_client.go | 2 +- ...license_codes_client_example_go123_test.go | 2 +- .../license_codes_client_example_test.go | 2 +- compute/apiv1/licenses_client.go | 2 +- .../licenses_client_example_go123_test.go | 2 +- compute/apiv1/licenses_client_example_test.go | 2 +- compute/apiv1/machine_images_client.go | 2 +- ...achine_images_client_example_go123_test.go | 2 +- .../machine_images_client_example_test.go | 2 +- compute/apiv1/machine_types_client.go | 2 +- ...machine_types_client_example_go123_test.go | 2 +- .../machine_types_client_example_test.go | 2 +- compute/apiv1/network_attachments_client.go | 2 +- ...k_attachments_client_example_go123_test.go | 2 +- ...network_attachments_client_example_test.go | 2 +- .../network_edge_security_services_client.go | 2 +- ...rity_services_client_example_go123_test.go | 2 +- ...e_security_services_client_example_test.go | 2 +- .../apiv1/network_endpoint_groups_client.go | 2 +- ...dpoint_groups_client_example_go123_test.go | 2 +- ...ork_endpoint_groups_client_example_test.go | 2 +- .../apiv1/network_firewall_policies_client.go | 2 +- ...wall_policies_client_example_go123_test.go | 2 +- ...k_firewall_policies_client_example_test.go | 2 +- compute/apiv1/network_profiles_client.go | 2 +- ...work_profiles_client_example_go123_test.go | 2 +- .../network_profiles_client_example_test.go | 2 +- compute/apiv1/networks_client.go | 2 +- .../networks_client_example_go123_test.go | 2 +- compute/apiv1/networks_client_example_test.go | 2 +- compute/apiv1/node_groups_client.go | 2 +- .../node_groups_client_example_go123_test.go | 2 +- .../apiv1/node_groups_client_example_test.go | 2 +- compute/apiv1/node_templates_client.go | 2 +- ...ode_templates_client_example_go123_test.go | 2 +- .../node_templates_client_example_test.go | 2 +- compute/apiv1/node_types_client.go | 2 +- .../node_types_client_example_go123_test.go | 2 +- .../apiv1/node_types_client_example_test.go | 2 +- compute/apiv1/operations.go | 2 +- compute/apiv1/packet_mirrorings_client.go | 2 +- ...et_mirrorings_client_example_go123_test.go | 2 +- .../packet_mirrorings_client_example_test.go | 2 +- compute/apiv1/projects_client.go | 2 +- .../projects_client_example_go123_test.go | 2 +- compute/apiv1/projects_client_example_test.go | 2 +- .../public_advertised_prefixes_client.go | 2 +- ...ised_prefixes_client_example_go123_test.go | 2 +- ...advertised_prefixes_client_example_test.go | 2 +- .../apiv1/public_delegated_prefixes_client.go | 2 +- ...ated_prefixes_client_example_go123_test.go | 2 +- ..._delegated_prefixes_client_example_test.go | 2 +- compute/apiv1/region_autoscalers_client.go | 2 +- ...n_autoscalers_client_example_go123_test.go | 2 +- .../region_autoscalers_client_example_test.go | 2 +- .../apiv1/region_backend_services_client.go | 2 +- ...kend_services_client_example_go123_test.go | 2 +- ...on_backend_services_client_example_test.go | 2 +- compute/apiv1/region_commitments_client.go | 2 +- ...n_commitments_client_example_go123_test.go | 2 +- .../region_commitments_client_example_test.go | 2 +- compute/apiv1/region_disk_types_client.go | 2 +- ...on_disk_types_client_example_go123_test.go | 2 +- .../region_disk_types_client_example_test.go | 2 +- compute/apiv1/region_disks_client.go | 2 +- .../region_disks_client_example_go123_test.go | 2 +- .../apiv1/region_disks_client_example_test.go | 2 +- .../region_health_check_services_client.go | 2 +- ...heck_services_client_example_go123_test.go | 2 +- ...alth_check_services_client_example_test.go | 2 +- compute/apiv1/region_health_checks_client.go | 2 +- ...health_checks_client_example_go123_test.go | 2 +- ...egion_health_checks_client_example_test.go | 2 +- .../region_instance_group_managers_client.go | 2 +- ...roup_managers_client_example_go123_test.go | 2 +- ...ance_group_managers_client_example_test.go | 2 +- .../apiv1/region_instance_groups_client.go | 2 +- ...stance_groups_client_example_go123_test.go | 2 +- ...ion_instance_groups_client_example_test.go | 2 +- .../apiv1/region_instance_templates_client.go | 2 +- ...nce_templates_client_example_go123_test.go | 2 +- ..._instance_templates_client_example_test.go | 2 +- compute/apiv1/region_instances_client.go | 2 +- ...ion_instances_client_example_go123_test.go | 2 +- .../region_instances_client_example_test.go | 2 +- .../apiv1/region_instant_snapshots_client.go | 2 +- ...ant_snapshots_client_example_go123_test.go | 2 +- ...n_instant_snapshots_client_example_test.go | 2 +- .../region_network_endpoint_groups_client.go | 2 +- ...dpoint_groups_client_example_go123_test.go | 2 +- ...ork_endpoint_groups_client_example_test.go | 2 +- ...region_network_firewall_policies_client.go | 2 +- ...wall_policies_client_example_go123_test.go | 2 +- ...k_firewall_policies_client_example_test.go | 2 +- .../region_notification_endpoints_client.go | 2 +- ...ion_endpoints_client_example_go123_test.go | 2 +- ...ification_endpoints_client_example_test.go | 2 +- compute/apiv1/region_operations_client.go | 2 +- ...on_operations_client_example_go123_test.go | 2 +- .../region_operations_client_example_test.go | 2 +- .../apiv1/region_security_policies_client.go | 2 +- ...rity_policies_client_example_go123_test.go | 2 +- ...n_security_policies_client_example_test.go | 2 +- .../apiv1/region_ssl_certificates_client.go | 2 +- ..._certificates_client_example_go123_test.go | 2 +- ...on_ssl_certificates_client_example_test.go | 2 +- compute/apiv1/region_ssl_policies_client.go | 2 +- ..._ssl_policies_client_example_go123_test.go | 2 +- ...region_ssl_policies_client_example_test.go | 2 +- .../region_target_http_proxies_client.go | 2 +- ..._http_proxies_client_example_go123_test.go | 2 +- ...target_http_proxies_client_example_test.go | 2 +- .../region_target_https_proxies_client.go | 2 +- ...https_proxies_client_example_go123_test.go | 2 +- ...arget_https_proxies_client_example_test.go | 2 +- .../apiv1/region_target_tcp_proxies_client.go | 2 +- ...t_tcp_proxies_client_example_go123_test.go | 2 +- ..._target_tcp_proxies_client_example_test.go | 2 +- compute/apiv1/region_url_maps_client.go | 2 +- ...gion_url_maps_client_example_go123_test.go | 2 +- .../region_url_maps_client_example_test.go | 2 +- compute/apiv1/region_zones_client.go | 2 +- .../region_zones_client_example_go123_test.go | 2 +- .../apiv1/region_zones_client_example_test.go | 2 +- compute/apiv1/regions_client.go | 2 +- .../regions_client_example_go123_test.go | 2 +- compute/apiv1/regions_client_example_test.go | 2 +- compute/apiv1/reservations_client.go | 2 +- .../reservations_client_example_go123_test.go | 2 +- .../apiv1/reservations_client_example_test.go | 2 +- compute/apiv1/resource_policies_client.go | 2 +- ...urce_policies_client_example_go123_test.go | 2 +- .../resource_policies_client_example_test.go | 2 +- compute/apiv1/routers_client.go | 2 +- .../routers_client_example_go123_test.go | 2 +- compute/apiv1/routers_client_example_test.go | 2 +- compute/apiv1/routes_client.go | 2 +- .../apiv1/routes_client_example_go123_test.go | 2 +- compute/apiv1/routes_client_example_test.go | 2 +- compute/apiv1/security_policies_client.go | 2 +- ...rity_policies_client_example_go123_test.go | 2 +- .../security_policies_client_example_test.go | 2 +- compute/apiv1/service_attachments_client.go | 2 +- ...e_attachments_client_example_go123_test.go | 2 +- ...service_attachments_client_example_test.go | 2 +- compute/apiv1/snapshot_settings_client.go | 2 +- ...shot_settings_client_example_go123_test.go | 2 +- .../snapshot_settings_client_example_test.go | 2 +- compute/apiv1/snapshots_client.go | 2 +- .../snapshots_client_example_go123_test.go | 2 +- .../apiv1/snapshots_client_example_test.go | 2 +- compute/apiv1/ssl_certificates_client.go | 2 +- ..._certificates_client_example_go123_test.go | 2 +- .../ssl_certificates_client_example_test.go | 2 +- compute/apiv1/ssl_policies_client.go | 2 +- .../ssl_policies_client_example_go123_test.go | 2 +- .../apiv1/ssl_policies_client_example_test.go | 2 +- compute/apiv1/storage_pool_types_client.go | 2 +- ...ge_pool_types_client_example_go123_test.go | 2 +- .../storage_pool_types_client_example_test.go | 2 +- compute/apiv1/storage_pools_client.go | 2 +- ...storage_pools_client_example_go123_test.go | 2 +- .../storage_pools_client_example_test.go | 2 +- compute/apiv1/subnetworks_client.go | 2 +- .../subnetworks_client_example_go123_test.go | 2 +- .../apiv1/subnetworks_client_example_test.go | 2 +- compute/apiv1/target_grpc_proxies_client.go | 2 +- ..._grpc_proxies_client_example_go123_test.go | 2 +- ...target_grpc_proxies_client_example_test.go | 2 +- compute/apiv1/target_http_proxies_client.go | 2 +- ..._http_proxies_client_example_go123_test.go | 2 +- ...target_http_proxies_client_example_test.go | 2 +- compute/apiv1/target_https_proxies_client.go | 2 +- ...https_proxies_client_example_go123_test.go | 2 +- ...arget_https_proxies_client_example_test.go | 2 +- compute/apiv1/target_instances_client.go | 2 +- ...get_instances_client_example_go123_test.go | 2 +- .../target_instances_client_example_test.go | 2 +- compute/apiv1/target_pools_client.go | 2 +- .../target_pools_client_example_go123_test.go | 2 +- .../apiv1/target_pools_client_example_test.go | 2 +- compute/apiv1/target_ssl_proxies_client.go | 2 +- ...t_ssl_proxies_client_example_go123_test.go | 2 +- .../target_ssl_proxies_client_example_test.go | 2 +- compute/apiv1/target_tcp_proxies_client.go | 2 +- ...t_tcp_proxies_client_example_go123_test.go | 2 +- .../target_tcp_proxies_client_example_test.go | 2 +- compute/apiv1/target_vpn_gateways_client.go | 2 +- ..._vpn_gateways_client_example_go123_test.go | 2 +- ...target_vpn_gateways_client_example_test.go | 2 +- compute/apiv1/url_maps_client.go | 2 +- .../url_maps_client_example_go123_test.go | 2 +- compute/apiv1/url_maps_client_example_test.go | 2 +- compute/apiv1/vpn_gateways_client.go | 2 +- .../vpn_gateways_client_example_go123_test.go | 2 +- .../apiv1/vpn_gateways_client_example_test.go | 2 +- compute/apiv1/vpn_tunnels_client.go | 2 +- .../vpn_tunnels_client_example_go123_test.go | 2 +- .../apiv1/vpn_tunnels_client_example_test.go | 2 +- compute/apiv1/zone_operations_client.go | 2 +- ...ne_operations_client_example_go123_test.go | 2 +- .../zone_operations_client_example_test.go | 2 +- compute/apiv1/zones_client.go | 2 +- .../apiv1/zones_client_example_go123_test.go | 2 +- compute/apiv1/zones_client_example_test.go | 2 +- confidentialcomputing/apiv1/auxiliary.go | 2 +- .../apiv1/auxiliary_go123.go | 2 +- .../apiv1/confidential_computing_client.go | 2 +- ...ial_computing_client_example_go123_test.go | 2 +- ...fidential_computing_client_example_test.go | 2 +- confidentialcomputing/apiv1/doc.go | 2 +- confidentialcomputing/apiv1/helpers.go | 2 +- .../apiv1alpha1/auxiliary.go | 2 +- .../apiv1alpha1/auxiliary_go123.go | 2 +- .../confidential_computing_client.go | 2 +- ...ial_computing_client_example_go123_test.go | 2 +- ...fidential_computing_client_example_test.go | 2 +- confidentialcomputing/apiv1alpha1/doc.go | 2 +- confidentialcomputing/apiv1alpha1/helpers.go | 2 +- config/apiv1/auxiliary.go | 2 +- config/apiv1/auxiliary_go123.go | 2 +- config/apiv1/config_client.go | 2 +- .../apiv1/config_client_example_go123_test.go | 2 +- config/apiv1/config_client_example_test.go | 2 +- config/apiv1/doc.go | 2 +- config/apiv1/helpers.go | 2 +- contactcenterinsights/apiv1/auxiliary.go | 2 +- .../apiv1/auxiliary_go123.go | 2 +- .../apiv1/contact_center_insights_client.go | 2 +- ...nter_insights_client_example_go123_test.go | 2 +- ...act_center_insights_client_example_test.go | 2 +- contactcenterinsights/apiv1/doc.go | 2 +- contactcenterinsights/apiv1/helpers.go | 2 +- container/apiv1/auxiliary.go | 2 +- container/apiv1/auxiliary_go123.go | 2 +- container/apiv1/cluster_manager_client.go | 2 +- ...uster_manager_client_example_go123_test.go | 2 +- .../cluster_manager_client_example_test.go | 2 +- container/apiv1/doc.go | 2 +- container/apiv1/helpers.go | 2 +- containeranalysis/apiv1beta1/auxiliary.go | 2 +- .../apiv1beta1/auxiliary_go123.go | 2 +- .../container_analysis_v1_beta1_client.go | 2 +- ...ysis_v1_beta1_client_example_go123_test.go | 2 +- ...r_analysis_v1_beta1_client_example_test.go | 2 +- containeranalysis/apiv1beta1/doc.go | 2 +- .../apiv1beta1/grafeas_v1_beta1_client.go | 2 +- ...feas_v1_beta1_client_example_go123_test.go | 2 +- .../grafeas_v1_beta1_client_example_test.go | 2 +- containeranalysis/apiv1beta1/helpers.go | 2 +- datacatalog/apiv1/auxiliary.go | 2 +- datacatalog/apiv1/auxiliary_go123.go | 2 +- datacatalog/apiv1/data_catalog_client.go | 2 +- .../data_catalog_client_example_go123_test.go | 2 +- .../apiv1/data_catalog_client_example_test.go | 2 +- datacatalog/apiv1/doc.go | 2 +- datacatalog/apiv1/helpers.go | 2 +- .../apiv1/policy_tag_manager_client.go | 2 +- ...y_tag_manager_client_example_go123_test.go | 2 +- .../policy_tag_manager_client_example_test.go | 2 +- ...policy_tag_manager_serialization_client.go | 2 +- ...serialization_client_example_go123_test.go | 2 +- ...nager_serialization_client_example_test.go | 2 +- datacatalog/apiv1beta1/auxiliary.go | 2 +- datacatalog/apiv1beta1/auxiliary_go123.go | 2 +- datacatalog/apiv1beta1/data_catalog_client.go | 2 +- .../data_catalog_client_example_go123_test.go | 2 +- .../data_catalog_client_example_test.go | 2 +- .../datacatalogpb/datacatalog.pb.go | 28 +- .../policytagmanagerserialization.pb.go | 18 +- .../apiv1beta1/datacatalogpb/schema.pb.go | 19 +- .../apiv1beta1/datacatalogpb/search.pb.go | 18 +- .../apiv1beta1/datacatalogpb/table_spec.pb.go | 19 +- .../apiv1beta1/datacatalogpb/tags.pb.go | 18 +- .../apiv1beta1/datacatalogpb/usage.pb.go | 18 +- datacatalog/apiv1beta1/doc.go | 2 +- datacatalog/apiv1beta1/helpers.go | 2 +- .../apiv1beta1/policy_tag_manager_client.go | 2 +- ...y_tag_manager_client_example_go123_test.go | 2 +- .../policy_tag_manager_client_example_test.go | 2 +- ...policy_tag_manager_serialization_client.go | 2 +- ...serialization_client_example_go123_test.go | 2 +- ...nager_serialization_client_example_test.go | 2 +- datacatalog/lineage/apiv1/auxiliary.go | 2 +- datacatalog/lineage/apiv1/auxiliary_go123.go | 2 +- datacatalog/lineage/apiv1/doc.go | 2 +- datacatalog/lineage/apiv1/helpers.go | 2 +- datacatalog/lineage/apiv1/lineage_client.go | 2 +- .../lineage_client_example_go123_test.go | 2 +- .../apiv1/lineage_client_example_test.go | 2 +- dataflow/apiv1beta3/auxiliary.go | 2 +- dataflow/apiv1beta3/auxiliary_go123.go | 2 +- dataflow/apiv1beta3/doc.go | 2 +- dataflow/apiv1beta3/flex_templates_client.go | 2 +- ...lex_templates_client_example_go123_test.go | 2 +- .../flex_templates_client_example_test.go | 2 +- dataflow/apiv1beta3/helpers.go | 2 +- dataflow/apiv1beta3/jobs_v1_beta3_client.go | 2 +- ...jobs_v1_beta3_client_example_go123_test.go | 2 +- .../jobs_v1_beta3_client_example_test.go | 2 +- .../apiv1beta3/messages_v1_beta3_client.go | 2 +- ...ages_v1_beta3_client_example_go123_test.go | 2 +- .../messages_v1_beta3_client_example_test.go | 2 +- .../apiv1beta3/metrics_v1_beta3_client.go | 2 +- ...rics_v1_beta3_client_example_go123_test.go | 2 +- .../metrics_v1_beta3_client_example_test.go | 2 +- .../apiv1beta3/snapshots_v1_beta3_client.go | 2 +- ...hots_v1_beta3_client_example_go123_test.go | 2 +- .../snapshots_v1_beta3_client_example_test.go | 2 +- dataflow/apiv1beta3/templates_client.go | 2 +- .../templates_client_example_go123_test.go | 2 +- .../templates_client_example_test.go | 2 +- dataform/apiv1alpha2/auxiliary.go | 2 +- dataform/apiv1alpha2/auxiliary_go123.go | 2 +- dataform/apiv1alpha2/dataform_client.go | 2 +- .../dataform_client_example_go123_test.go | 2 +- .../dataform_client_example_test.go | 2 +- dataform/apiv1alpha2/doc.go | 2 +- dataform/apiv1alpha2/helpers.go | 2 +- dataform/apiv1beta1/auxiliary.go | 2 +- dataform/apiv1beta1/auxiliary_go123.go | 2 +- dataform/apiv1beta1/dataform_client.go | 2 +- .../dataform_client_example_go123_test.go | 2 +- .../dataform_client_example_test.go | 2 +- dataform/apiv1beta1/doc.go | 2 +- dataform/apiv1beta1/helpers.go | 2 +- datafusion/apiv1/auxiliary.go | 2 +- datafusion/apiv1/auxiliary_go123.go | 2 +- datafusion/apiv1/data_fusion_client.go | 2 +- .../data_fusion_client_example_go123_test.go | 2 +- .../apiv1/data_fusion_client_example_test.go | 2 +- datafusion/apiv1/doc.go | 2 +- datafusion/apiv1/helpers.go | 2 +- datalabeling/apiv1beta1/auxiliary.go | 2 +- datalabeling/apiv1beta1/auxiliary_go123.go | 2 +- .../apiv1beta1/data_labeling_client.go | 2 +- ...data_labeling_client_example_go123_test.go | 2 +- .../data_labeling_client_example_test.go | 2 +- datalabeling/apiv1beta1/doc.go | 2 +- datalabeling/apiv1beta1/helpers.go | 2 +- dataplex/apiv1/auxiliary.go | 2 +- dataplex/apiv1/auxiliary_go123.go | 2 +- dataplex/apiv1/catalog_client.go | 2 +- .../catalog_client_example_go123_test.go | 2 +- dataplex/apiv1/catalog_client_example_test.go | 2 +- dataplex/apiv1/content_client.go | 2 +- .../content_client_example_go123_test.go | 2 +- dataplex/apiv1/content_client_example_test.go | 2 +- dataplex/apiv1/data_scan_client.go | 2 +- .../data_scan_client_example_go123_test.go | 2 +- .../apiv1/data_scan_client_example_test.go | 2 +- dataplex/apiv1/data_taxonomy_client.go | 2 +- ...data_taxonomy_client_example_go123_test.go | 2 +- .../data_taxonomy_client_example_test.go | 2 +- dataplex/apiv1/dataplex_client.go | 2 +- .../dataplex_client_example_go123_test.go | 2 +- .../apiv1/dataplex_client_example_test.go | 2 +- dataplex/apiv1/doc.go | 2 +- dataplex/apiv1/helpers.go | 2 +- dataplex/apiv1/metadata_client.go | 2 +- .../metadata_client_example_go123_test.go | 2 +- .../apiv1/metadata_client_example_test.go | 2 +- dataproc/apiv1/autoscaling_policy_client.go | 2 +- ...caling_policy_client_example_go123_test.go | 2 +- .../autoscaling_policy_client_example_test.go | 2 +- dataproc/apiv1/auxiliary.go | 2 +- dataproc/apiv1/auxiliary_go123.go | 2 +- dataproc/apiv1/batch_controller_client.go | 2 +- ...ch_controller_client_example_go123_test.go | 2 +- .../batch_controller_client_example_test.go | 2 +- dataproc/apiv1/cluster_controller_client.go | 2 +- ...er_controller_client_example_go123_test.go | 2 +- .../cluster_controller_client_example_test.go | 2 +- dataproc/apiv1/doc.go | 2 +- dataproc/apiv1/helpers.go | 2 +- dataproc/apiv1/job_controller_client.go | 2 +- ...ob_controller_client_example_go123_test.go | 2 +- .../job_controller_client_example_test.go | 2 +- .../apiv1/node_group_controller_client.go | 2 +- ...up_controller_client_example_go123_test.go | 2 +- ...de_group_controller_client_example_test.go | 2 +- dataproc/apiv1/session_controller_client.go | 2 +- ...on_controller_client_example_go123_test.go | 2 +- .../session_controller_client_example_test.go | 2 +- .../session_template_controller_client.go | 2 +- ...te_controller_client_example_go123_test.go | 2 +- ...template_controller_client_example_test.go | 2 +- dataproc/apiv1/workflow_template_client.go | 2 +- ...flow_template_client_example_go123_test.go | 2 +- .../workflow_template_client_example_test.go | 2 +- dataqna/apiv1alpha/auto_suggestion_client.go | 2 +- ...to_suggestion_client_example_go123_test.go | 2 +- .../auto_suggestion_client_example_test.go | 2 +- dataqna/apiv1alpha/auxiliary.go | 2 +- dataqna/apiv1alpha/auxiliary_go123.go | 2 +- dataqna/apiv1alpha/doc.go | 2 +- dataqna/apiv1alpha/helpers.go | 2 +- dataqna/apiv1alpha/question_client.go | 2 +- .../question_client_example_go123_test.go | 2 +- .../question_client_example_test.go | 2 +- datastore/admin/apiv1/auxiliary.go | 2 +- datastore/admin/apiv1/auxiliary_go123.go | 2 +- .../admin/apiv1/datastore_admin_client.go | 2 +- ...tastore_admin_client_example_go123_test.go | 2 +- .../datastore_admin_client_example_test.go | 2 +- datastore/admin/apiv1/doc.go | 2 +- datastore/admin/apiv1/helpers.go | 2 +- datastream/apiv1/auxiliary.go | 2 +- datastream/apiv1/auxiliary_go123.go | 2 +- datastream/apiv1/datastream_client.go | 2 +- .../datastream_client_example_go123_test.go | 2 +- .../apiv1/datastream_client_example_test.go | 2 +- datastream/apiv1/doc.go | 2 +- datastream/apiv1/helpers.go | 2 +- datastream/apiv1alpha1/auxiliary.go | 2 +- datastream/apiv1alpha1/auxiliary_go123.go | 2 +- datastream/apiv1alpha1/datastream_client.go | 2 +- .../datastream_client_example_go123_test.go | 2 +- .../datastream_client_example_test.go | 2 +- datastream/apiv1alpha1/doc.go | 2 +- datastream/apiv1alpha1/helpers.go | 2 +- deploy/apiv1/auxiliary.go | 2 +- deploy/apiv1/auxiliary_go123.go | 2 +- deploy/apiv1/cloud_deploy_client.go | 2 +- .../cloud_deploy_client_example_go123_test.go | 2 +- .../apiv1/cloud_deploy_client_example_test.go | 2 +- deploy/apiv1/doc.go | 2 +- deploy/apiv1/helpers.go | 2 +- developerconnect/apiv1/auxiliary.go | 2 +- developerconnect/apiv1/auxiliary_go123.go | 2 +- .../apiv1/developer_connect_client.go | 2 +- ...loper_connect_client_example_go123_test.go | 2 +- .../developer_connect_client_example_test.go | 2 +- developerconnect/apiv1/doc.go | 2 +- developerconnect/apiv1/helpers.go | 2 +- dialogflow/apiv2/agents_client.go | 2 +- .../apiv2/agents_client_example_go123_test.go | 2 +- .../apiv2/agents_client_example_test.go | 2 +- dialogflow/apiv2/answer_records_client.go | 2 +- ...nswer_records_client_example_go123_test.go | 2 +- .../answer_records_client_example_test.go | 2 +- dialogflow/apiv2/auxiliary.go | 2 +- dialogflow/apiv2/auxiliary_go123.go | 2 +- dialogflow/apiv2/contexts_client.go | 2 +- .../contexts_client_example_go123_test.go | 2 +- .../apiv2/contexts_client_example_test.go | 2 +- .../apiv2/conversation_datasets_client.go | 2 +- ...tion_datasets_client_example_go123_test.go | 2 +- ...nversation_datasets_client_example_test.go | 2 +- .../apiv2/conversation_models_client.go | 2 +- ...sation_models_client_example_go123_test.go | 2 +- ...conversation_models_client_example_test.go | 2 +- .../apiv2/conversation_profiles_client.go | 2 +- ...tion_profiles_client_example_go123_test.go | 2 +- ...nversation_profiles_client_example_test.go | 2 +- dialogflow/apiv2/conversations_client.go | 2 +- ...conversations_client_example_go123_test.go | 2 +- .../conversations_client_example_test.go | 2 +- dialogflow/apiv2/doc.go | 2 +- dialogflow/apiv2/documents_client.go | 2 +- .../documents_client_example_go123_test.go | 2 +- .../apiv2/documents_client_example_test.go | 2 +- dialogflow/apiv2/encryption_spec_client.go | 2 +- ...cryption_spec_client_example_go123_test.go | 2 +- .../encryption_spec_client_example_test.go | 2 +- dialogflow/apiv2/entity_types_client.go | 2 +- .../entity_types_client_example_go123_test.go | 2 +- .../apiv2/entity_types_client_example_test.go | 2 +- dialogflow/apiv2/environments_client.go | 2 +- .../environments_client_example_go123_test.go | 2 +- .../apiv2/environments_client_example_test.go | 2 +- dialogflow/apiv2/fulfillments_client.go | 2 +- .../fulfillments_client_example_go123_test.go | 2 +- .../apiv2/fulfillments_client_example_test.go | 2 +- dialogflow/apiv2/generators_client.go | 2 +- .../generators_client_example_go123_test.go | 2 +- .../apiv2/generators_client_example_test.go | 2 +- dialogflow/apiv2/helpers.go | 2 +- dialogflow/apiv2/intents_client.go | 2 +- .../intents_client_example_go123_test.go | 2 +- .../apiv2/intents_client_example_test.go | 2 +- dialogflow/apiv2/knowledge_bases_client.go | 2 +- ...owledge_bases_client_example_go123_test.go | 2 +- .../knowledge_bases_client_example_test.go | 2 +- dialogflow/apiv2/participants_client.go | 2 +- .../participants_client_example_go123_test.go | 2 +- .../apiv2/participants_client_example_test.go | 2 +- .../apiv2/session_entity_types_client.go | 2 +- ..._entity_types_client_example_go123_test.go | 2 +- ...ession_entity_types_client_example_test.go | 2 +- dialogflow/apiv2/sessions_client.go | 2 +- .../sessions_client_example_go123_test.go | 2 +- .../apiv2/sessions_client_example_test.go | 2 +- dialogflow/apiv2/versions_client.go | 2 +- .../versions_client_example_go123_test.go | 2 +- .../apiv2/versions_client_example_test.go | 2 +- dialogflow/apiv2beta1/agents_client.go | 2 +- .../agents_client_example_go123_test.go | 2 +- .../apiv2beta1/agents_client_example_test.go | 2 +- .../apiv2beta1/answer_records_client.go | 2 +- ...nswer_records_client_example_go123_test.go | 2 +- .../answer_records_client_example_test.go | 2 +- dialogflow/apiv2beta1/auxiliary.go | 2 +- dialogflow/apiv2beta1/auxiliary_go123.go | 2 +- dialogflow/apiv2beta1/contexts_client.go | 2 +- .../contexts_client_example_go123_test.go | 2 +- .../contexts_client_example_test.go | 2 +- .../conversation_profiles_client.go | 2 +- ...tion_profiles_client_example_go123_test.go | 2 +- ...nversation_profiles_client_example_test.go | 2 +- dialogflow/apiv2beta1/conversations_client.go | 2 +- ...conversations_client_example_go123_test.go | 2 +- .../conversations_client_example_test.go | 2 +- dialogflow/apiv2beta1/doc.go | 2 +- dialogflow/apiv2beta1/documents_client.go | 2 +- .../documents_client_example_go123_test.go | 2 +- .../documents_client_example_test.go | 2 +- .../apiv2beta1/encryption_spec_client.go | 2 +- ...cryption_spec_client_example_go123_test.go | 2 +- .../encryption_spec_client_example_test.go | 2 +- dialogflow/apiv2beta1/entity_types_client.go | 2 +- .../entity_types_client_example_go123_test.go | 2 +- .../entity_types_client_example_test.go | 2 +- dialogflow/apiv2beta1/environments_client.go | 2 +- .../environments_client_example_go123_test.go | 2 +- .../environments_client_example_test.go | 2 +- dialogflow/apiv2beta1/fulfillments_client.go | 2 +- .../fulfillments_client_example_go123_test.go | 2 +- .../fulfillments_client_example_test.go | 2 +- dialogflow/apiv2beta1/generators_client.go | 2 +- .../generators_client_example_go123_test.go | 2 +- .../generators_client_example_test.go | 2 +- dialogflow/apiv2beta1/helpers.go | 2 +- dialogflow/apiv2beta1/intents_client.go | 2 +- .../intents_client_example_go123_test.go | 2 +- .../apiv2beta1/intents_client_example_test.go | 2 +- .../apiv2beta1/knowledge_bases_client.go | 2 +- ...owledge_bases_client_example_go123_test.go | 2 +- .../knowledge_bases_client_example_test.go | 2 +- dialogflow/apiv2beta1/participants_client.go | 2 +- .../participants_client_example_go123_test.go | 2 +- .../participants_client_example_test.go | 2 +- .../apiv2beta1/session_entity_types_client.go | 2 +- ..._entity_types_client_example_go123_test.go | 2 +- ...ession_entity_types_client_example_test.go | 2 +- dialogflow/apiv2beta1/sessions_client.go | 2 +- .../sessions_client_example_go123_test.go | 2 +- .../sessions_client_example_test.go | 2 +- dialogflow/apiv2beta1/sip_trunks_client.go | 2 +- .../sip_trunks_client_example_go123_test.go | 2 +- .../sip_trunks_client_example_test.go | 2 +- dialogflow/apiv2beta1/versions_client.go | 2 +- .../versions_client_example_go123_test.go | 2 +- .../versions_client_example_test.go | 2 +- dialogflow/cx/apiv3/agents_client.go | 2 +- .../apiv3/agents_client_example_go123_test.go | 2 +- .../cx/apiv3/agents_client_example_test.go | 2 +- dialogflow/cx/apiv3/auxiliary.go | 2 +- dialogflow/cx/apiv3/auxiliary_go123.go | 2 +- dialogflow/cx/apiv3/changelogs_client.go | 2 +- .../changelogs_client_example_go123_test.go | 2 +- .../apiv3/changelogs_client_example_test.go | 2 +- dialogflow/cx/apiv3/deployments_client.go | 2 +- .../deployments_client_example_go123_test.go | 2 +- .../apiv3/deployments_client_example_test.go | 2 +- dialogflow/cx/apiv3/doc.go | 2 +- dialogflow/cx/apiv3/entity_types_client.go | 2 +- .../entity_types_client_example_go123_test.go | 2 +- .../apiv3/entity_types_client_example_test.go | 2 +- dialogflow/cx/apiv3/environments_client.go | 2 +- .../environments_client_example_go123_test.go | 2 +- .../apiv3/environments_client_example_test.go | 2 +- dialogflow/cx/apiv3/experiments_client.go | 2 +- .../experiments_client_example_go123_test.go | 2 +- .../apiv3/experiments_client_example_test.go | 2 +- dialogflow/cx/apiv3/flows_client.go | 2 +- .../apiv3/flows_client_example_go123_test.go | 2 +- .../cx/apiv3/flows_client_example_test.go | 2 +- dialogflow/cx/apiv3/generators_client.go | 2 +- .../generators_client_example_go123_test.go | 2 +- .../apiv3/generators_client_example_test.go | 2 +- dialogflow/cx/apiv3/helpers.go | 2 +- dialogflow/cx/apiv3/intents_client.go | 2 +- .../intents_client_example_go123_test.go | 2 +- .../cx/apiv3/intents_client_example_test.go | 2 +- dialogflow/cx/apiv3/pages_client.go | 2 +- .../apiv3/pages_client_example_go123_test.go | 2 +- .../cx/apiv3/pages_client_example_test.go | 2 +- .../cx/apiv3/security_settings_client.go | 2 +- ...rity_settings_client_example_go123_test.go | 2 +- .../security_settings_client_example_test.go | 2 +- .../cx/apiv3/session_entity_types_client.go | 2 +- ..._entity_types_client_example_go123_test.go | 2 +- ...ession_entity_types_client_example_test.go | 2 +- dialogflow/cx/apiv3/sessions_client.go | 2 +- .../sessions_client_example_go123_test.go | 2 +- .../cx/apiv3/sessions_client_example_test.go | 2 +- dialogflow/cx/apiv3/test_cases_client.go | 2 +- .../test_cases_client_example_go123_test.go | 2 +- .../apiv3/test_cases_client_example_test.go | 2 +- .../apiv3/transition_route_groups_client.go | 2 +- ..._route_groups_client_example_go123_test.go | 2 +- ...sition_route_groups_client_example_test.go | 2 +- dialogflow/cx/apiv3/versions_client.go | 2 +- .../versions_client_example_go123_test.go | 2 +- .../cx/apiv3/versions_client_example_test.go | 2 +- dialogflow/cx/apiv3/webhooks_client.go | 2 +- .../webhooks_client_example_go123_test.go | 2 +- .../cx/apiv3/webhooks_client_example_test.go | 2 +- dialogflow/cx/apiv3beta1/agents_client.go | 2 +- .../agents_client_example_go123_test.go | 2 +- .../apiv3beta1/agents_client_example_test.go | 2 +- dialogflow/cx/apiv3beta1/auxiliary.go | 2 +- dialogflow/cx/apiv3beta1/auxiliary_go123.go | 2 +- dialogflow/cx/apiv3beta1/changelogs_client.go | 2 +- .../changelogs_client_example_go123_test.go | 2 +- .../changelogs_client_example_test.go | 2 +- .../apiv3beta1/conversation_history_client.go | 2 +- ...ation_history_client_example_go123_test.go | 2 +- ...onversation_history_client_example_test.go | 2 +- .../cx/apiv3beta1/deployments_client.go | 2 +- .../deployments_client_example_go123_test.go | 2 +- .../deployments_client_example_test.go | 2 +- dialogflow/cx/apiv3beta1/doc.go | 2 +- .../cx/apiv3beta1/entity_types_client.go | 2 +- .../entity_types_client_example_go123_test.go | 2 +- .../entity_types_client_example_test.go | 2 +- .../cx/apiv3beta1/environments_client.go | 2 +- .../environments_client_example_go123_test.go | 2 +- .../environments_client_example_test.go | 2 +- dialogflow/cx/apiv3beta1/examples_client.go | 2 +- .../examples_client_example_go123_test.go | 2 +- .../examples_client_example_test.go | 2 +- .../cx/apiv3beta1/experiments_client.go | 2 +- .../experiments_client_example_go123_test.go | 2 +- .../experiments_client_example_test.go | 2 +- dialogflow/cx/apiv3beta1/flows_client.go | 2 +- .../flows_client_example_go123_test.go | 2 +- .../apiv3beta1/flows_client_example_test.go | 2 +- dialogflow/cx/apiv3beta1/generators_client.go | 2 +- .../generators_client_example_go123_test.go | 2 +- .../generators_client_example_test.go | 2 +- dialogflow/cx/apiv3beta1/helpers.go | 2 +- dialogflow/cx/apiv3beta1/intents_client.go | 2 +- .../intents_client_example_go123_test.go | 2 +- .../apiv3beta1/intents_client_example_test.go | 2 +- dialogflow/cx/apiv3beta1/pages_client.go | 2 +- .../pages_client_example_go123_test.go | 2 +- .../apiv3beta1/pages_client_example_test.go | 2 +- dialogflow/cx/apiv3beta1/playbooks_client.go | 2 +- .../playbooks_client_example_go123_test.go | 2 +- .../playbooks_client_example_test.go | 2 +- .../cx/apiv3beta1/security_settings_client.go | 2 +- ...rity_settings_client_example_go123_test.go | 2 +- .../security_settings_client_example_test.go | 2 +- .../apiv3beta1/session_entity_types_client.go | 2 +- ..._entity_types_client_example_go123_test.go | 2 +- ...ession_entity_types_client_example_test.go | 2 +- dialogflow/cx/apiv3beta1/sessions_client.go | 2 +- .../sessions_client_example_go123_test.go | 2 +- .../sessions_client_example_test.go | 2 +- dialogflow/cx/apiv3beta1/test_cases_client.go | 2 +- .../test_cases_client_example_go123_test.go | 2 +- .../test_cases_client_example_test.go | 2 +- dialogflow/cx/apiv3beta1/tools_client.go | 2 +- .../tools_client_example_go123_test.go | 2 +- .../apiv3beta1/tools_client_example_test.go | 2 +- .../transition_route_groups_client.go | 2 +- ..._route_groups_client_example_go123_test.go | 2 +- ...sition_route_groups_client_example_test.go | 2 +- dialogflow/cx/apiv3beta1/versions_client.go | 2 +- .../versions_client_example_go123_test.go | 2 +- .../versions_client_example_test.go | 2 +- dialogflow/cx/apiv3beta1/webhooks_client.go | 2 +- .../webhooks_client_example_go123_test.go | 2 +- .../webhooks_client_example_test.go | 2 +- discoveryengine/apiv1/auxiliary.go | 2 +- discoveryengine/apiv1/auxiliary_go123.go | 2 +- discoveryengine/apiv1/completion_client.go | 2 +- .../completion_client_example_go123_test.go | 2 +- .../apiv1/completion_client_example_test.go | 2 +- discoveryengine/apiv1/control_client.go | 2 +- .../control_client_example_go123_test.go | 2 +- .../apiv1/control_client_example_test.go | 2 +- .../apiv1/conversational_search_client.go | 2 +- ...tional_search_client_example_go123_test.go | 2 +- ...nversational_search_client_example_test.go | 2 +- discoveryengine/apiv1/data_store_client.go | 2 +- .../data_store_client_example_go123_test.go | 2 +- .../apiv1/data_store_client_example_test.go | 2 +- discoveryengine/apiv1/doc.go | 2 +- discoveryengine/apiv1/document_client.go | 2 +- .../document_client_example_go123_test.go | 2 +- .../apiv1/document_client_example_test.go | 2 +- discoveryengine/apiv1/engine_client.go | 2 +- .../apiv1/engine_client_example_go123_test.go | 2 +- .../apiv1/engine_client_example_test.go | 2 +- .../apiv1/grounded_generation_client.go | 2 +- ...ed_generation_client_example_go123_test.go | 2 +- ...grounded_generation_client_example_test.go | 2 +- discoveryengine/apiv1/helpers.go | 2 +- discoveryengine/apiv1/project_client.go | 2 +- .../project_client_example_go123_test.go | 2 +- .../apiv1/project_client_example_test.go | 2 +- discoveryengine/apiv1/rank_client.go | 2 +- .../apiv1/rank_client_example_go123_test.go | 2 +- .../apiv1/rank_client_example_test.go | 2 +- .../apiv1/recommendation_client.go | 2 +- ...ecommendation_client_example_go123_test.go | 2 +- .../recommendation_client_example_test.go | 2 +- discoveryengine/apiv1/schema_client.go | 2 +- .../apiv1/schema_client_example_go123_test.go | 2 +- .../apiv1/schema_client_example_test.go | 2 +- discoveryengine/apiv1/search_client.go | 2 +- .../apiv1/search_client_example_go123_test.go | 2 +- .../apiv1/search_client_example_test.go | 2 +- discoveryengine/apiv1/search_tuning_client.go | 2 +- ...search_tuning_client_example_go123_test.go | 2 +- .../search_tuning_client_example_test.go | 2 +- .../apiv1/site_search_engine_client.go | 2 +- ...search_engine_client_example_go123_test.go | 2 +- .../site_search_engine_client_example_test.go | 2 +- discoveryengine/apiv1/user_event_client.go | 2 +- .../user_event_client_example_go123_test.go | 2 +- .../apiv1/user_event_client_example_test.go | 2 +- .../apiv1alpha/acl_config_client.go | 2 +- .../acl_config_client_example_go123_test.go | 2 +- .../acl_config_client_example_test.go | 2 +- discoveryengine/apiv1alpha/auxiliary.go | 2 +- discoveryengine/apiv1alpha/auxiliary_go123.go | 2 +- discoveryengine/apiv1alpha/chunk_client.go | 2 +- .../chunk_client_example_go123_test.go | 2 +- .../apiv1alpha/chunk_client_example_test.go | 2 +- .../apiv1alpha/completion_client.go | 2 +- .../completion_client_example_go123_test.go | 2 +- .../completion_client_example_test.go | 2 +- discoveryengine/apiv1alpha/control_client.go | 2 +- .../control_client_example_go123_test.go | 2 +- .../apiv1alpha/control_client_example_test.go | 2 +- .../conversational_search_client.go | 2 +- ...tional_search_client_example_go123_test.go | 2 +- ...nversational_search_client_example_test.go | 2 +- .../apiv1alpha/data_store_client.go | 2 +- .../data_store_client_example_go123_test.go | 2 +- .../data_store_client_example_test.go | 2 +- discoveryengine/apiv1alpha/doc.go | 2 +- discoveryengine/apiv1alpha/document_client.go | 2 +- .../document_client_example_go123_test.go | 2 +- .../document_client_example_test.go | 2 +- discoveryengine/apiv1alpha/engine_client.go | 2 +- .../engine_client_example_go123_test.go | 2 +- .../apiv1alpha/engine_client_example_test.go | 2 +- .../apiv1alpha/estimate_billing_client.go | 2 +- ...imate_billing_client_example_go123_test.go | 2 +- .../estimate_billing_client_example_test.go | 2 +- .../apiv1alpha/evaluation_client.go | 2 +- .../evaluation_client_example_go123_test.go | 2 +- .../evaluation_client_example_test.go | 2 +- .../apiv1alpha/grounded_generation_client.go | 2 +- ...ed_generation_client_example_go123_test.go | 2 +- ...grounded_generation_client_example_test.go | 2 +- discoveryengine/apiv1alpha/helpers.go | 2 +- discoveryengine/apiv1alpha/project_client.go | 2 +- .../project_client_example_go123_test.go | 2 +- .../apiv1alpha/project_client_example_test.go | 2 +- discoveryengine/apiv1alpha/rank_client.go | 2 +- .../rank_client_example_go123_test.go | 2 +- .../apiv1alpha/rank_client_example_test.go | 2 +- .../apiv1alpha/recommendation_client.go | 2 +- ...ecommendation_client_example_go123_test.go | 2 +- .../recommendation_client_example_test.go | 2 +- .../apiv1alpha/sample_query_client.go | 2 +- .../sample_query_client_example_go123_test.go | 2 +- .../sample_query_client_example_test.go | 2 +- .../apiv1alpha/sample_query_set_client.go | 2 +- ...ple_query_set_client_example_go123_test.go | 2 +- .../sample_query_set_client_example_test.go | 2 +- discoveryengine/apiv1alpha/schema_client.go | 2 +- .../schema_client_example_go123_test.go | 2 +- .../apiv1alpha/schema_client_example_test.go | 2 +- discoveryengine/apiv1alpha/search_client.go | 2 +- .../search_client_example_go123_test.go | 2 +- .../apiv1alpha/search_client_example_test.go | 2 +- .../apiv1alpha/search_tuning_client.go | 2 +- ...search_tuning_client_example_go123_test.go | 2 +- .../search_tuning_client_example_test.go | 2 +- .../apiv1alpha/serving_config_client.go | 2 +- ...erving_config_client_example_go123_test.go | 2 +- .../serving_config_client_example_test.go | 2 +- .../apiv1alpha/site_search_engine_client.go | 2 +- ...search_engine_client_example_go123_test.go | 2 +- .../site_search_engine_client_example_test.go | 2 +- .../apiv1alpha/user_event_client.go | 2 +- .../user_event_client_example_go123_test.go | 2 +- .../user_event_client_example_test.go | 2 +- discoveryengine/apiv1beta/auxiliary.go | 2 +- discoveryengine/apiv1beta/auxiliary_go123.go | 2 +- .../apiv1beta/completion_client.go | 2 +- .../completion_client_example_go123_test.go | 2 +- .../completion_client_example_test.go | 2 +- discoveryengine/apiv1beta/control_client.go | 2 +- .../control_client_example_go123_test.go | 2 +- .../apiv1beta/control_client_example_test.go | 2 +- .../apiv1beta/conversational_search_client.go | 2 +- ...tional_search_client_example_go123_test.go | 2 +- ...nversational_search_client_example_test.go | 2 +- .../apiv1beta/data_store_client.go | 2 +- .../data_store_client_example_go123_test.go | 2 +- .../data_store_client_example_test.go | 2 +- discoveryengine/apiv1beta/doc.go | 2 +- discoveryengine/apiv1beta/document_client.go | 2 +- .../document_client_example_go123_test.go | 2 +- .../apiv1beta/document_client_example_test.go | 2 +- discoveryengine/apiv1beta/engine_client.go | 2 +- .../engine_client_example_go123_test.go | 2 +- .../apiv1beta/engine_client_example_test.go | 2 +- .../apiv1beta/evaluation_client.go | 2 +- .../evaluation_client_example_go123_test.go | 2 +- .../evaluation_client_example_test.go | 2 +- .../apiv1beta/grounded_generation_client.go | 2 +- ...ed_generation_client_example_go123_test.go | 2 +- ...grounded_generation_client_example_test.go | 2 +- discoveryengine/apiv1beta/helpers.go | 2 +- discoveryengine/apiv1beta/project_client.go | 2 +- .../project_client_example_go123_test.go | 2 +- .../apiv1beta/project_client_example_test.go | 2 +- discoveryengine/apiv1beta/rank_client.go | 2 +- .../rank_client_example_go123_test.go | 2 +- .../apiv1beta/rank_client_example_test.go | 2 +- .../apiv1beta/recommendation_client.go | 2 +- ...ecommendation_client_example_go123_test.go | 2 +- .../recommendation_client_example_test.go | 2 +- .../apiv1beta/sample_query_client.go | 2 +- .../sample_query_client_example_go123_test.go | 2 +- .../sample_query_client_example_test.go | 2 +- .../apiv1beta/sample_query_set_client.go | 2 +- ...ple_query_set_client_example_go123_test.go | 2 +- .../sample_query_set_client_example_test.go | 2 +- discoveryengine/apiv1beta/schema_client.go | 2 +- .../schema_client_example_go123_test.go | 2 +- .../apiv1beta/schema_client_example_test.go | 2 +- discoveryengine/apiv1beta/search_client.go | 2 +- .../search_client_example_go123_test.go | 2 +- .../apiv1beta/search_client_example_test.go | 2 +- .../apiv1beta/search_tuning_client.go | 2 +- ...search_tuning_client_example_go123_test.go | 2 +- .../search_tuning_client_example_test.go | 2 +- .../apiv1beta/serving_config_client.go | 2 +- ...erving_config_client_example_go123_test.go | 2 +- .../serving_config_client_example_test.go | 2 +- .../apiv1beta/site_search_engine_client.go | 2 +- ...search_engine_client_example_go123_test.go | 2 +- .../site_search_engine_client_example_test.go | 2 +- .../apiv1beta/user_event_client.go | 2 +- .../user_event_client_example_go123_test.go | 2 +- .../user_event_client_example_test.go | 2 +- dlp/apiv2/auxiliary.go | 2 +- dlp/apiv2/auxiliary_go123.go | 2 +- dlp/apiv2/dlp_client.go | 2 +- dlp/apiv2/dlp_client_example_go123_test.go | 2 +- dlp/apiv2/dlp_client_example_test.go | 2 +- dlp/apiv2/doc.go | 2 +- dlp/apiv2/helpers.go | 2 +- documentai/apiv1/auxiliary.go | 2 +- documentai/apiv1/auxiliary_go123.go | 2 +- documentai/apiv1/doc.go | 2 +- documentai/apiv1/document_processor_client.go | 2 +- ...ent_processor_client_example_go123_test.go | 2 +- .../document_processor_client_example_test.go | 2 +- documentai/apiv1/helpers.go | 2 +- documentai/apiv1beta3/auxiliary.go | 2 +- documentai/apiv1beta3/auxiliary_go123.go | 2 +- documentai/apiv1beta3/doc.go | 2 +- documentai/apiv1beta3/document_client.go | 2 +- .../document_client_example_go123_test.go | 2 +- .../document_client_example_test.go | 2 +- .../apiv1beta3/document_processor_client.go | 2 +- ...ent_processor_client_example_go123_test.go | 2 +- .../document_processor_client_example_test.go | 2 +- documentai/apiv1beta3/helpers.go | 2 +- domains/apiv1beta1/auxiliary.go | 2 +- domains/apiv1beta1/auxiliary_go123.go | 2 +- domains/apiv1beta1/doc.go | 2 +- domains/apiv1beta1/domains_client.go | 2 +- .../domains_client_example_go123_test.go | 2 +- .../apiv1beta1/domains_client_example_test.go | 2 +- domains/apiv1beta1/helpers.go | 2 +- edgecontainer/apiv1/auxiliary.go | 2 +- edgecontainer/apiv1/auxiliary_go123.go | 2 +- edgecontainer/apiv1/doc.go | 2 +- edgecontainer/apiv1/edge_container_client.go | 2 +- ...dge_container_client_example_go123_test.go | 2 +- .../edge_container_client_example_test.go | 2 +- edgecontainer/apiv1/helpers.go | 2 +- edgenetwork/apiv1/auxiliary.go | 2 +- edgenetwork/apiv1/auxiliary_go123.go | 2 +- edgenetwork/apiv1/doc.go | 2 +- edgenetwork/apiv1/edge_network_client.go | 2 +- .../edge_network_client_example_go123_test.go | 2 +- .../apiv1/edge_network_client_example_test.go | 2 +- edgenetwork/apiv1/helpers.go | 2 +- essentialcontacts/apiv1/auxiliary.go | 2 +- essentialcontacts/apiv1/auxiliary_go123.go | 2 +- essentialcontacts/apiv1/doc.go | 2 +- .../apiv1/essential_contacts_client.go | 2 +- ...tial_contacts_client_example_go123_test.go | 2 +- .../essential_contacts_client_example_test.go | 2 +- essentialcontacts/apiv1/helpers.go | 2 +- eventarc/apiv1/auxiliary.go | 2 +- eventarc/apiv1/auxiliary_go123.go | 2 +- eventarc/apiv1/doc.go | 2 +- eventarc/apiv1/eventarc_client.go | 2 +- .../eventarc_client_example_go123_test.go | 2 +- .../apiv1/eventarc_client_example_test.go | 2 +- eventarc/apiv1/helpers.go | 2 +- eventarc/publishing/apiv1/auxiliary.go | 2 +- eventarc/publishing/apiv1/auxiliary_go123.go | 2 +- eventarc/publishing/apiv1/doc.go | 2 +- eventarc/publishing/apiv1/helpers.go | 2 +- eventarc/publishing/apiv1/publisher_client.go | 2 +- .../publisher_client_example_go123_test.go | 2 +- .../apiv1/publisher_client_example_test.go | 2 +- filestore/apiv1/auxiliary.go | 2 +- filestore/apiv1/auxiliary_go123.go | 2 +- .../apiv1/cloud_filestore_manager_client.go | 2 +- ...store_manager_client_example_go123_test.go | 2 +- ...d_filestore_manager_client_example_test.go | 2 +- filestore/apiv1/doc.go | 2 +- filestore/apiv1/helpers.go | 2 +- firestore/apiv1/admin/auxiliary.go | 2 +- firestore/apiv1/admin/auxiliary_go123.go | 2 +- firestore/apiv1/admin/doc.go | 2 +- .../apiv1/admin/firestore_admin_client.go | 2 +- ...restore_admin_client_example_go123_test.go | 2 +- .../firestore_admin_client_example_test.go | 2 +- firestore/apiv1/admin/helpers.go | 2 +- firestore/apiv1/auxiliary.go | 2 +- firestore/apiv1/auxiliary_go123.go | 2 +- firestore/apiv1/doc.go | 2 +- firestore/apiv1/firestore_client.go | 2 +- .../firestore_client_example_go123_test.go | 2 +- .../apiv1/firestore_client_example_test.go | 2 +- firestore/apiv1/helpers.go | 2 +- functions/apiv1/auxiliary.go | 2 +- functions/apiv1/auxiliary_go123.go | 2 +- functions/apiv1/cloud_functions_client.go | 2 +- ...oud_functions_client_example_go123_test.go | 2 +- .../cloud_functions_client_example_test.go | 2 +- functions/apiv1/doc.go | 2 +- functions/apiv1/helpers.go | 2 +- functions/apiv2/auxiliary.go | 2 +- functions/apiv2/auxiliary_go123.go | 2 +- functions/apiv2/doc.go | 2 +- functions/apiv2/function_client.go | 2 +- .../function_client_example_go123_test.go | 2 +- .../apiv2/function_client_example_test.go | 2 +- functions/apiv2/helpers.go | 2 +- functions/apiv2beta/auxiliary.go | 2 +- functions/apiv2beta/auxiliary_go123.go | 2 +- functions/apiv2beta/doc.go | 2 +- functions/apiv2beta/function_client.go | 2 +- .../function_client_example_go123_test.go | 2 +- .../apiv2beta/function_client_example_test.go | 2 +- functions/apiv2beta/helpers.go | 2 +- gkebackup/apiv1/auxiliary.go | 2 +- gkebackup/apiv1/auxiliary_go123.go | 2 +- gkebackup/apiv1/backup_forgke_client.go | 2 +- ...backup_forgke_client_example_go123_test.go | 2 +- .../backup_forgke_client_example_test.go | 2 +- gkebackup/apiv1/doc.go | 2 +- gkebackup/apiv1/helpers.go | 2 +- gkeconnect/gateway/apiv1/auxiliary.go | 2 +- gkeconnect/gateway/apiv1/auxiliary_go123.go | 2 +- gkeconnect/gateway/apiv1/doc.go | 2 +- .../gateway/apiv1/gateway_control_client.go | 2 +- ...teway_control_client_example_go123_test.go | 2 +- .../gateway_control_client_example_test.go | 2 +- gkeconnect/gateway/apiv1/helpers.go | 2 +- gkeconnect/gateway/apiv1beta1/auxiliary.go | 2 +- .../gateway/apiv1beta1/auxiliary_go123.go | 2 +- gkeconnect/gateway/apiv1beta1/doc.go | 2 +- .../apiv1beta1/gateway_control_client.go | 2 +- ...teway_control_client_example_go123_test.go | 2 +- .../gateway_control_client_example_test.go | 2 +- gkeconnect/gateway/apiv1beta1/helpers.go | 2 +- gkehub/apiv1beta1/auxiliary.go | 2 +- gkehub/apiv1beta1/auxiliary_go123.go | 2 +- gkehub/apiv1beta1/doc.go | 2 +- .../apiv1beta1/gke_hub_membership_client.go | 2 +- ...ub_membership_client_example_go123_test.go | 2 +- .../gke_hub_membership_client_example_test.go | 2 +- gkehub/apiv1beta1/helpers.go | 2 +- .../apiv1/attached_clusters_client.go | 2 +- ...ched_clusters_client_example_go123_test.go | 2 +- .../attached_clusters_client_example_test.go | 2 +- gkemulticloud/apiv1/auxiliary.go | 2 +- gkemulticloud/apiv1/auxiliary_go123.go | 2 +- gkemulticloud/apiv1/aws_clusters_client.go | 2 +- .../aws_clusters_client_example_go123_test.go | 2 +- .../apiv1/aws_clusters_client_example_test.go | 2 +- gkemulticloud/apiv1/azure_clusters_client.go | 2 +- ...zure_clusters_client_example_go123_test.go | 2 +- .../azure_clusters_client_example_test.go | 2 +- gkemulticloud/apiv1/doc.go | 2 +- gkemulticloud/apiv1/helpers.go | 2 +- gsuiteaddons/apiv1/auxiliary.go | 2 +- gsuiteaddons/apiv1/auxiliary_go123.go | 2 +- gsuiteaddons/apiv1/doc.go | 2 +- gsuiteaddons/apiv1/g_suite_add_ons_client.go | 2 +- ...suite_add_ons_client_example_go123_test.go | 2 +- .../g_suite_add_ons_client_example_test.go | 2 +- gsuiteaddons/apiv1/helpers.go | 2 +- iam/apiv1/auxiliary.go | 2 +- iam/apiv1/auxiliary_go123.go | 2 +- iam/apiv1/doc.go | 2 +- iam/apiv1/helpers.go | 2 +- iam/apiv1/iam_policy_client.go | 2 +- .../iam_policy_client_example_go123_test.go | 2 +- iam/apiv1/iam_policy_client_example_test.go | 2 +- iam/apiv2/auxiliary.go | 2 +- iam/apiv2/auxiliary_go123.go | 2 +- iam/apiv2/doc.go | 2 +- iam/apiv2/helpers.go | 2 +- iam/apiv2/policies_client.go | 2 +- .../policies_client_example_go123_test.go | 2 +- iam/apiv2/policies_client_example_test.go | 2 +- iam/credentials/apiv1/auxiliary.go | 2 +- iam/credentials/apiv1/auxiliary_go123.go | 2 +- iam/credentials/apiv1/doc.go | 2 +- iam/credentials/apiv1/helpers.go | 2 +- .../apiv1/iam_credentials_client.go | 2 +- ...m_credentials_client_example_go123_test.go | 2 +- .../iam_credentials_client_example_test.go | 2 +- iap/apiv1/auxiliary.go | 2 +- iap/apiv1/auxiliary_go123.go | 2 +- iap/apiv1/doc.go | 2 +- iap/apiv1/helpers.go | 2 +- .../identity_aware_proxy_admin_client.go | 2 +- ...e_proxy_admin_client_example_go123_test.go | 2 +- ...y_aware_proxy_admin_client_example_test.go | 2 +- .../identity_aware_proxyo_auth_client.go | 2 +- ...e_proxyo_auth_client_example_go123_test.go | 2 +- ...y_aware_proxyo_auth_client_example_test.go | 2 +- .../apiv2/account_management_client.go | 2 +- ...nt_management_client_example_go123_test.go | 2 +- .../account_management_client_example_test.go | 2 +- .../apiv2/authentication_client.go | 2 +- ...uthentication_client_example_go123_test.go | 2 +- .../authentication_client_example_test.go | 2 +- identitytoolkit/apiv2/auxiliary.go | 2 +- identitytoolkit/apiv2/auxiliary_go123.go | 2 +- identitytoolkit/apiv2/doc.go | 2 +- identitytoolkit/apiv2/helpers.go | 2 +- ids/apiv1/auxiliary.go | 2 +- ids/apiv1/auxiliary_go123.go | 2 +- ids/apiv1/doc.go | 2 +- ids/apiv1/helpers.go | 2 +- ids/apiv1/ids_client.go | 2 +- ids/apiv1/ids_client_example_go123_test.go | 2 +- ids/apiv1/ids_client_example_test.go | 2 +- .../Client/ApproveApprovalRequest/main.go | 2 +- .../DeleteAccessApprovalSettings/main.go | 2 +- .../Client/DismissApprovalRequest/main.go | 2 +- .../GetAccessApprovalServiceAccount/main.go | 2 +- .../Client/GetAccessApprovalSettings/main.go | 2 +- .../apiv1/Client/GetApprovalRequest/main.go | 2 +- .../Client/InvalidateApprovalRequest/main.go | 2 +- .../apiv1/Client/ListApprovalRequests/main.go | 2 +- .../UpdateAccessApprovalSettings/main.go | 2 +- .../Client/CommitServicePerimeters/main.go | 2 +- .../apiv1/Client/CreateAccessLevel/main.go | 2 +- .../apiv1/Client/CreateAccessPolicy/main.go | 2 +- .../Client/CreateGcpUserAccessBinding/main.go | 2 +- .../Client/CreateServicePerimeter/main.go | 2 +- .../apiv1/Client/DeleteAccessLevel/main.go | 2 +- .../apiv1/Client/DeleteAccessPolicy/main.go | 2 +- .../Client/DeleteGcpUserAccessBinding/main.go | 2 +- .../Client/DeleteServicePerimeter/main.go | 2 +- .../apiv1/Client/GetAccessLevel/main.go | 2 +- .../apiv1/Client/GetAccessPolicy/main.go | 2 +- .../Client/GetGcpUserAccessBinding/main.go | 2 +- .../apiv1/Client/GetIamPolicy/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/GetServicePerimeter/main.go | 2 +- .../apiv1/Client/ListAccessLevels/main.go | 2 +- .../apiv1/Client/ListAccessPolicies/main.go | 2 +- .../Client/ListGcpUserAccessBindings/main.go | 2 +- .../Client/ListServicePerimeters/main.go | 2 +- .../apiv1/Client/ReplaceAccessLevels/main.go | 2 +- .../Client/ReplaceServicePerimeters/main.go | 2 +- .../apiv1/Client/SetIamPolicy/main.go | 2 +- .../apiv1/Client/TestIamPermissions/main.go | 2 +- .../apiv1/Client/UpdateAccessLevel/main.go | 2 +- .../apiv1/Client/UpdateAccessPolicy/main.go | 2 +- .../Client/UpdateGcpUserAccessBinding/main.go | 2 +- .../Client/UpdateServicePerimeter/main.go | 2 +- .../apiv1/Client/GetNotification/main.go | 2 +- .../apiv1/Client/GetSettings/main.go | 2 +- .../apiv1/Client/ListNotifications/main.go | 2 +- .../apiv1/Client/UpdateSettings/main.go | 2 +- ...google.cloud.advisorynotifications.v1.json | 2 +- .../BatchEmbedContents/main.go | 2 +- .../GenerativeClient/CancelOperation/main.go | 2 +- .../GenerativeClient/CountTokens/main.go | 2 +- .../GenerativeClient/EmbedContent/main.go | 2 +- .../GenerativeClient/GenerateContent/main.go | 2 +- .../GenerativeClient/GetOperation/main.go | 2 +- .../GenerativeClient/ListOperations/main.go | 2 +- .../apiv1/ModelClient/CancelOperation/main.go | 2 +- .../apiv1/ModelClient/GetModel/main.go | 2 +- .../apiv1/ModelClient/GetOperation/main.go | 2 +- .../apiv1/ModelClient/ListModels/main.go | 2 +- .../apiv1/ModelClient/ListOperations/main.go | 2 +- .../CacheClient/CreateCachedContent/main.go | 2 +- .../CacheClient/DeleteCachedContent/main.go | 2 +- .../CacheClient/GetCachedContent/main.go | 2 +- .../CacheClient/GetOperation/main.go | 2 +- .../CacheClient/ListCachedContents/main.go | 2 +- .../CacheClient/ListOperations/main.go | 2 +- .../CacheClient/UpdateCachedContent/main.go | 2 +- .../DiscussClient/CountMessageTokens/main.go | 2 +- .../DiscussClient/GenerateMessage/main.go | 2 +- .../DiscussClient/GetOperation/main.go | 2 +- .../DiscussClient/ListOperations/main.go | 2 +- .../apiv1beta/FileClient/CreateFile/main.go | 2 +- .../apiv1beta/FileClient/DeleteFile/main.go | 2 +- .../apiv1beta/FileClient/GetFile/main.go | 2 +- .../apiv1beta/FileClient/GetOperation/main.go | 2 +- .../apiv1beta/FileClient/ListFiles/main.go | 2 +- .../FileClient/ListOperations/main.go | 2 +- .../BatchEmbedContents/main.go | 2 +- .../GenerativeClient/CountTokens/main.go | 2 +- .../GenerativeClient/EmbedContent/main.go | 2 +- .../GenerativeClient/GenerateAnswer/main.go | 2 +- .../GenerativeClient/GenerateContent/main.go | 2 +- .../GenerativeClient/GetOperation/main.go | 2 +- .../GenerativeClient/ListOperations/main.go | 2 +- .../ModelClient/CreateTunedModel/main.go | 2 +- .../ModelClient/DeleteTunedModel/main.go | 2 +- .../apiv1beta/ModelClient/GetModel/main.go | 2 +- .../ModelClient/GetOperation/main.go | 2 +- .../ModelClient/GetTunedModel/main.go | 2 +- .../apiv1beta/ModelClient/ListModels/main.go | 2 +- .../ModelClient/ListOperations/main.go | 2 +- .../ModelClient/ListTunedModels/main.go | 2 +- .../ModelClient/UpdateTunedModel/main.go | 2 +- .../PermissionClient/CreatePermission/main.go | 2 +- .../PermissionClient/DeletePermission/main.go | 2 +- .../PermissionClient/GetOperation/main.go | 2 +- .../PermissionClient/GetPermission/main.go | 2 +- .../PermissionClient/ListOperations/main.go | 2 +- .../PermissionClient/ListPermissions/main.go | 2 +- .../TransferOwnership/main.go | 2 +- .../PermissionClient/UpdatePermission/main.go | 2 +- .../PredictionClient/GetOperation/main.go | 2 +- .../PredictionClient/ListOperations/main.go | 2 +- .../PredictionClient/Predict/main.go | 2 +- .../RetrieverClient/BatchCreateChunks/main.go | 2 +- .../RetrieverClient/BatchDeleteChunks/main.go | 2 +- .../RetrieverClient/BatchUpdateChunks/main.go | 2 +- .../RetrieverClient/CreateChunk/main.go | 2 +- .../RetrieverClient/CreateCorpus/main.go | 2 +- .../RetrieverClient/CreateDocument/main.go | 2 +- .../RetrieverClient/DeleteChunk/main.go | 2 +- .../RetrieverClient/DeleteCorpus/main.go | 2 +- .../RetrieverClient/DeleteDocument/main.go | 2 +- .../RetrieverClient/GetChunk/main.go | 2 +- .../RetrieverClient/GetCorpus/main.go | 2 +- .../RetrieverClient/GetDocument/main.go | 2 +- .../RetrieverClient/GetOperation/main.go | 2 +- .../RetrieverClient/ListChunks/main.go | 2 +- .../RetrieverClient/ListCorpora/main.go | 2 +- .../RetrieverClient/ListDocuments/main.go | 2 +- .../RetrieverClient/ListOperations/main.go | 2 +- .../RetrieverClient/QueryCorpus/main.go | 2 +- .../RetrieverClient/QueryDocument/main.go | 2 +- .../RetrieverClient/UpdateChunk/main.go | 2 +- .../RetrieverClient/UpdateCorpus/main.go | 2 +- .../RetrieverClient/UpdateDocument/main.go | 2 +- .../TextClient/BatchEmbedText/main.go | 2 +- .../TextClient/CountTextTokens/main.go | 2 +- .../apiv1beta/TextClient/EmbedText/main.go | 2 +- .../apiv1beta/TextClient/GenerateText/main.go | 2 +- .../apiv1beta/TextClient/GetOperation/main.go | 2 +- .../TextClient/ListOperations/main.go | 2 +- .../DiscussClient/CountMessageTokens/main.go | 2 +- .../DiscussClient/GenerateMessage/main.go | 2 +- .../apiv1beta2/ModelClient/GetModel/main.go | 2 +- .../apiv1beta2/ModelClient/ListModels/main.go | 2 +- .../apiv1beta2/TextClient/EmbedText/main.go | 2 +- .../TextClient/GenerateText/main.go | 2 +- .../DatasetClient/CancelOperation/main.go | 2 +- .../apiv1/DatasetClient/CreateDataset/main.go | 2 +- .../CreateDatasetVersion/main.go | 2 +- .../apiv1/DatasetClient/DeleteDataset/main.go | 2 +- .../DeleteDatasetVersion/main.go | 2 +- .../DatasetClient/DeleteOperation/main.go | 2 +- .../DatasetClient/DeleteSavedQuery/main.go | 2 +- .../apiv1/DatasetClient/ExportData/main.go | 2 +- .../DatasetClient/GetAnnotationSpec/main.go | 2 +- .../apiv1/DatasetClient/GetDataset/main.go | 2 +- .../DatasetClient/GetDatasetVersion/main.go | 2 +- .../apiv1/DatasetClient/GetIamPolicy/main.go | 2 +- .../apiv1/DatasetClient/GetLocation/main.go | 2 +- .../apiv1/DatasetClient/GetOperation/main.go | 2 +- .../apiv1/DatasetClient/ImportData/main.go | 2 +- .../DatasetClient/ListAnnotations/main.go | 2 +- .../apiv1/DatasetClient/ListDataItems/main.go | 2 +- .../DatasetClient/ListDatasetVersions/main.go | 2 +- .../apiv1/DatasetClient/ListDatasets/main.go | 2 +- .../apiv1/DatasetClient/ListLocations/main.go | 2 +- .../DatasetClient/ListOperations/main.go | 2 +- .../DatasetClient/ListSavedQueries/main.go | 2 +- .../RestoreDatasetVersion/main.go | 2 +- .../DatasetClient/SearchDataItems/main.go | 2 +- .../apiv1/DatasetClient/SetIamPolicy/main.go | 2 +- .../DatasetClient/TestIamPermissions/main.go | 2 +- .../apiv1/DatasetClient/UpdateDataset/main.go | 2 +- .../UpdateDatasetVersion/main.go | 2 +- .../apiv1/DatasetClient/WaitOperation/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateDeploymentResourcePool/main.go | 2 +- .../DeleteDeploymentResourcePool/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../GetDeploymentResourcePool/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListDeploymentResourcePools/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../QueryDeployedModels/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateDeploymentResourcePool/main.go | 2 +- .../WaitOperation/main.go | 2 +- .../EndpointClient/CancelOperation/main.go | 2 +- .../EndpointClient/CreateEndpoint/main.go | 2 +- .../EndpointClient/DeleteEndpoint/main.go | 2 +- .../EndpointClient/DeleteOperation/main.go | 2 +- .../apiv1/EndpointClient/DeployModel/main.go | 2 +- .../apiv1/EndpointClient/GetEndpoint/main.go | 2 +- .../apiv1/EndpointClient/GetIamPolicy/main.go | 2 +- .../apiv1/EndpointClient/GetLocation/main.go | 2 +- .../apiv1/EndpointClient/GetOperation/main.go | 2 +- .../EndpointClient/ListEndpoints/main.go | 2 +- .../EndpointClient/ListLocations/main.go | 2 +- .../EndpointClient/ListOperations/main.go | 2 +- .../MutateDeployedModel/main.go | 2 +- .../apiv1/EndpointClient/SetIamPolicy/main.go | 2 +- .../EndpointClient/TestIamPermissions/main.go | 2 +- .../EndpointClient/UndeployModel/main.go | 2 +- .../EndpointClient/UpdateEndpoint/main.go | 2 +- .../UpdateEndpointLongRunning/main.go | 2 +- .../EndpointClient/WaitOperation/main.go | 2 +- .../EvaluationClient/CancelOperation/main.go | 2 +- .../EvaluationClient/DeleteOperation/main.go | 2 +- .../EvaluateInstances/main.go | 2 +- .../EvaluationClient/GetIamPolicy/main.go | 2 +- .../EvaluationClient/GetLocation/main.go | 2 +- .../EvaluationClient/GetOperation/main.go | 2 +- .../EvaluationClient/ListLocations/main.go | 2 +- .../EvaluationClient/ListOperations/main.go | 2 +- .../EvaluationClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../EvaluationClient/WaitOperation/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateFeatureOnlineStore/main.go | 2 +- .../CreateFeatureView/main.go | 2 +- .../DeleteFeatureOnlineStore/main.go | 2 +- .../DeleteFeatureView/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../GetFeatureOnlineStore/main.go | 2 +- .../GetFeatureView/main.go | 2 +- .../GetFeatureViewSync/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListFeatureOnlineStores/main.go | 2 +- .../ListFeatureViewSyncs/main.go | 2 +- .../ListFeatureViews/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../SyncFeatureView/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateFeatureOnlineStore/main.go | 2 +- .../UpdateFeatureView/main.go | 2 +- .../WaitOperation/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../FetchFeatureValues/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../SearchNearestEntities/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../WaitOperation/main.go | 2 +- .../BatchCreateFeatures/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateFeature/main.go | 2 +- .../CreateFeatureGroup/main.go | 2 +- .../DeleteFeature/main.go | 2 +- .../DeleteFeatureGroup/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../FeatureRegistryClient/GetFeature/main.go | 2 +- .../GetFeatureGroup/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../FeatureRegistryClient/GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListFeatureGroups/main.go | 2 +- .../ListFeatures/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateFeature/main.go | 2 +- .../UpdateFeatureGroup/main.go | 2 +- .../WaitOperation/main.go | 2 +- .../BatchCreateFeatures/main.go | 2 +- .../BatchReadFeatureValues/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateEntityType/main.go | 2 +- .../FeaturestoreClient/CreateFeature/main.go | 2 +- .../CreateFeaturestore/main.go | 2 +- .../DeleteEntityType/main.go | 2 +- .../FeaturestoreClient/DeleteFeature/main.go | 2 +- .../DeleteFeatureValues/main.go | 2 +- .../DeleteFeaturestore/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../ExportFeatureValues/main.go | 2 +- .../FeaturestoreClient/GetEntityType/main.go | 2 +- .../FeaturestoreClient/GetFeature/main.go | 2 +- .../GetFeaturestore/main.go | 2 +- .../FeaturestoreClient/GetIamPolicy/main.go | 2 +- .../FeaturestoreClient/GetLocation/main.go | 2 +- .../FeaturestoreClient/GetOperation/main.go | 2 +- .../ImportFeatureValues/main.go | 2 +- .../ListEntityTypes/main.go | 2 +- .../FeaturestoreClient/ListFeatures/main.go | 2 +- .../ListFeaturestores/main.go | 2 +- .../FeaturestoreClient/ListLocations/main.go | 2 +- .../FeaturestoreClient/ListOperations/main.go | 2 +- .../FeaturestoreClient/SearchFeatures/main.go | 2 +- .../FeaturestoreClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateEntityType/main.go | 2 +- .../FeaturestoreClient/UpdateFeature/main.go | 2 +- .../UpdateFeaturestore/main.go | 2 +- .../FeaturestoreClient/WaitOperation/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ReadFeatureValues/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../WaitOperation/main.go | 2 +- .../WriteFeatureValues/main.go | 2 +- .../GenAiTuningClient/CancelOperation/main.go | 2 +- .../GenAiTuningClient/CancelTuningJob/main.go | 2 +- .../GenAiTuningClient/CreateTuningJob/main.go | 2 +- .../GenAiTuningClient/DeleteOperation/main.go | 2 +- .../GenAiTuningClient/GetIamPolicy/main.go | 2 +- .../GenAiTuningClient/GetLocation/main.go | 2 +- .../GenAiTuningClient/GetOperation/main.go | 2 +- .../GenAiTuningClient/GetTuningJob/main.go | 2 +- .../GenAiTuningClient/ListLocations/main.go | 2 +- .../GenAiTuningClient/ListOperations/main.go | 2 +- .../GenAiTuningClient/ListTuningJobs/main.go | 2 +- .../RebaseTunedModel/main.go | 2 +- .../GenAiTuningClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../GenAiTuningClient/WaitOperation/main.go | 2 +- .../apiv1/IndexClient/CancelOperation/main.go | 2 +- .../apiv1/IndexClient/CreateIndex/main.go | 2 +- .../apiv1/IndexClient/DeleteIndex/main.go | 2 +- .../apiv1/IndexClient/DeleteOperation/main.go | 2 +- .../apiv1/IndexClient/GetIamPolicy/main.go | 2 +- .../apiv1/IndexClient/GetIndex/main.go | 2 +- .../apiv1/IndexClient/GetLocation/main.go | 2 +- .../apiv1/IndexClient/GetOperation/main.go | 2 +- .../apiv1/IndexClient/ListIndexes/main.go | 2 +- .../apiv1/IndexClient/ListLocations/main.go | 2 +- .../apiv1/IndexClient/ListOperations/main.go | 2 +- .../IndexClient/RemoveDatapoints/main.go | 2 +- .../apiv1/IndexClient/SetIamPolicy/main.go | 2 +- .../IndexClient/TestIamPermissions/main.go | 2 +- .../apiv1/IndexClient/UpdateIndex/main.go | 2 +- .../IndexClient/UpsertDatapoints/main.go | 2 +- .../apiv1/IndexClient/WaitOperation/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateIndexEndpoint/main.go | 2 +- .../DeleteIndexEndpoint/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../IndexEndpointClient/DeployIndex/main.go | 2 +- .../IndexEndpointClient/GetIamPolicy/main.go | 2 +- .../GetIndexEndpoint/main.go | 2 +- .../IndexEndpointClient/GetLocation/main.go | 2 +- .../IndexEndpointClient/GetOperation/main.go | 2 +- .../ListIndexEndpoints/main.go | 2 +- .../IndexEndpointClient/ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../MutateDeployedIndex/main.go | 2 +- .../IndexEndpointClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../IndexEndpointClient/UndeployIndex/main.go | 2 +- .../UpdateIndexEndpoint/main.go | 2 +- .../IndexEndpointClient/WaitOperation/main.go | 2 +- .../CancelBatchPredictionJob/main.go | 2 +- .../apiv1/JobClient/CancelCustomJob/main.go | 2 +- .../JobClient/CancelDataLabelingJob/main.go | 2 +- .../CancelHyperparameterTuningJob/main.go | 2 +- .../apiv1/JobClient/CancelNasJob/main.go | 2 +- .../apiv1/JobClient/CancelOperation/main.go | 2 +- .../CreateBatchPredictionJob/main.go | 2 +- .../apiv1/JobClient/CreateCustomJob/main.go | 2 +- .../JobClient/CreateDataLabelingJob/main.go | 2 +- .../CreateHyperparameterTuningJob/main.go | 2 +- .../main.go | 2 +- .../apiv1/JobClient/CreateNasJob/main.go | 2 +- .../DeleteBatchPredictionJob/main.go | 2 +- .../apiv1/JobClient/DeleteCustomJob/main.go | 2 +- .../JobClient/DeleteDataLabelingJob/main.go | 2 +- .../DeleteHyperparameterTuningJob/main.go | 2 +- .../main.go | 2 +- .../apiv1/JobClient/DeleteNasJob/main.go | 2 +- .../apiv1/JobClient/DeleteOperation/main.go | 2 +- .../JobClient/GetBatchPredictionJob/main.go | 2 +- .../apiv1/JobClient/GetCustomJob/main.go | 2 +- .../JobClient/GetDataLabelingJob/main.go | 2 +- .../GetHyperparameterTuningJob/main.go | 2 +- .../apiv1/JobClient/GetIamPolicy/main.go | 2 +- .../apiv1/JobClient/GetLocation/main.go | 2 +- .../GetModelDeploymentMonitoringJob/main.go | 2 +- .../apiv1/JobClient/GetNasJob/main.go | 2 +- .../apiv1/JobClient/GetNasTrialDetail/main.go | 2 +- .../apiv1/JobClient/GetOperation/main.go | 2 +- .../JobClient/ListBatchPredictionJobs/main.go | 2 +- .../apiv1/JobClient/ListCustomJobs/main.go | 2 +- .../JobClient/ListDataLabelingJobs/main.go | 2 +- .../ListHyperparameterTuningJobs/main.go | 2 +- .../apiv1/JobClient/ListLocations/main.go | 2 +- .../ListModelDeploymentMonitoringJobs/main.go | 2 +- .../apiv1/JobClient/ListNasJobs/main.go | 2 +- .../JobClient/ListNasTrialDetails/main.go | 2 +- .../apiv1/JobClient/ListOperations/main.go | 2 +- .../PauseModelDeploymentMonitoringJob/main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../apiv1/JobClient/SetIamPolicy/main.go | 2 +- .../JobClient/TestIamPermissions/main.go | 2 +- .../main.go | 2 +- .../apiv1/JobClient/WaitOperation/main.go | 2 +- .../LlmUtilityClient/CancelOperation/main.go | 2 +- .../LlmUtilityClient/ComputeTokens/main.go | 2 +- .../LlmUtilityClient/CountTokens/main.go | 2 +- .../LlmUtilityClient/DeleteOperation/main.go | 2 +- .../LlmUtilityClient/GetIamPolicy/main.go | 2 +- .../LlmUtilityClient/GetLocation/main.go | 2 +- .../LlmUtilityClient/GetOperation/main.go | 2 +- .../LlmUtilityClient/ListLocations/main.go | 2 +- .../LlmUtilityClient/ListOperations/main.go | 2 +- .../LlmUtilityClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../LlmUtilityClient/WaitOperation/main.go | 2 +- .../apiv1/MatchClient/CancelOperation/main.go | 2 +- .../apiv1/MatchClient/DeleteOperation/main.go | 2 +- .../apiv1/MatchClient/FindNeighbors/main.go | 2 +- .../apiv1/MatchClient/GetIamPolicy/main.go | 2 +- .../apiv1/MatchClient/GetLocation/main.go | 2 +- .../apiv1/MatchClient/GetOperation/main.go | 2 +- .../apiv1/MatchClient/ListLocations/main.go | 2 +- .../apiv1/MatchClient/ListOperations/main.go | 2 +- .../MatchClient/ReadIndexDatapoints/main.go | 2 +- .../apiv1/MatchClient/SetIamPolicy/main.go | 2 +- .../MatchClient/TestIamPermissions/main.go | 2 +- .../apiv1/MatchClient/WaitOperation/main.go | 2 +- .../AddContextArtifactsAndExecutions/main.go | 2 +- .../MetadataClient/AddContextChildren/main.go | 2 +- .../MetadataClient/AddExecutionEvents/main.go | 2 +- .../MetadataClient/CancelOperation/main.go | 2 +- .../MetadataClient/CreateArtifact/main.go | 2 +- .../MetadataClient/CreateContext/main.go | 2 +- .../MetadataClient/CreateExecution/main.go | 2 +- .../CreateMetadataSchema/main.go | 2 +- .../CreateMetadataStore/main.go | 2 +- .../MetadataClient/DeleteArtifact/main.go | 2 +- .../MetadataClient/DeleteContext/main.go | 2 +- .../MetadataClient/DeleteExecution/main.go | 2 +- .../DeleteMetadataStore/main.go | 2 +- .../MetadataClient/DeleteOperation/main.go | 2 +- .../apiv1/MetadataClient/GetArtifact/main.go | 2 +- .../apiv1/MetadataClient/GetContext/main.go | 2 +- .../apiv1/MetadataClient/GetExecution/main.go | 2 +- .../apiv1/MetadataClient/GetIamPolicy/main.go | 2 +- .../apiv1/MetadataClient/GetLocation/main.go | 2 +- .../MetadataClient/GetMetadataSchema/main.go | 2 +- .../MetadataClient/GetMetadataStore/main.go | 2 +- .../apiv1/MetadataClient/GetOperation/main.go | 2 +- .../MetadataClient/ListArtifacts/main.go | 2 +- .../apiv1/MetadataClient/ListContexts/main.go | 2 +- .../MetadataClient/ListExecutions/main.go | 2 +- .../MetadataClient/ListLocations/main.go | 2 +- .../ListMetadataSchemas/main.go | 2 +- .../MetadataClient/ListMetadataStores/main.go | 2 +- .../MetadataClient/ListOperations/main.go | 2 +- .../MetadataClient/PurgeArtifacts/main.go | 2 +- .../MetadataClient/PurgeContexts/main.go | 2 +- .../MetadataClient/PurgeExecutions/main.go | 2 +- .../QueryArtifactLineageSubgraph/main.go | 2 +- .../QueryContextLineageSubgraph/main.go | 2 +- .../QueryExecutionInputsAndOutputs/main.go | 2 +- .../RemoveContextChildren/main.go | 2 +- .../apiv1/MetadataClient/SetIamPolicy/main.go | 2 +- .../MetadataClient/TestIamPermissions/main.go | 2 +- .../MetadataClient/UpdateArtifact/main.go | 2 +- .../MetadataClient/UpdateContext/main.go | 2 +- .../MetadataClient/UpdateExecution/main.go | 2 +- .../MetadataClient/WaitOperation/main.go | 2 +- .../BatchMigrateResources/main.go | 2 +- .../MigrationClient/CancelOperation/main.go | 2 +- .../MigrationClient/DeleteOperation/main.go | 2 +- .../MigrationClient/GetIamPolicy/main.go | 2 +- .../apiv1/MigrationClient/GetLocation/main.go | 2 +- .../MigrationClient/GetOperation/main.go | 2 +- .../MigrationClient/ListLocations/main.go | 2 +- .../MigrationClient/ListOperations/main.go | 2 +- .../SearchMigratableResources/main.go | 2 +- .../MigrationClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../MigrationClient/WaitOperation/main.go | 2 +- .../BatchImportEvaluatedAnnotations/main.go | 2 +- .../BatchImportModelEvaluationSlices/main.go | 2 +- .../apiv1/ModelClient/CancelOperation/main.go | 2 +- .../apiv1/ModelClient/CopyModel/main.go | 2 +- .../apiv1/ModelClient/DeleteModel/main.go | 2 +- .../ModelClient/DeleteModelVersion/main.go | 2 +- .../apiv1/ModelClient/DeleteOperation/main.go | 2 +- .../apiv1/ModelClient/ExportModel/main.go | 2 +- .../apiv1/ModelClient/GetIamPolicy/main.go | 2 +- .../apiv1/ModelClient/GetLocation/main.go | 2 +- .../apiv1/ModelClient/GetModel/main.go | 2 +- .../ModelClient/GetModelEvaluation/main.go | 2 +- .../GetModelEvaluationSlice/main.go | 2 +- .../apiv1/ModelClient/GetOperation/main.go | 2 +- .../ModelClient/ImportModelEvaluation/main.go | 2 +- .../apiv1/ModelClient/ListLocations/main.go | 2 +- .../ListModelEvaluationSlices/main.go | 2 +- .../ModelClient/ListModelEvaluations/main.go | 2 +- .../ModelClient/ListModelVersions/main.go | 2 +- .../apiv1/ModelClient/ListModels/main.go | 2 +- .../apiv1/ModelClient/ListOperations/main.go | 2 +- .../ModelClient/MergeVersionAliases/main.go | 2 +- .../apiv1/ModelClient/SetIamPolicy/main.go | 2 +- .../ModelClient/TestIamPermissions/main.go | 2 +- .../UpdateExplanationDataset/main.go | 2 +- .../apiv1/ModelClient/UpdateModel/main.go | 2 +- .../apiv1/ModelClient/UploadModel/main.go | 2 +- .../apiv1/ModelClient/WaitOperation/main.go | 2 +- .../ModelGardenClient/CancelOperation/main.go | 2 +- .../ModelGardenClient/DeleteOperation/main.go | 2 +- .../ModelGardenClient/GetIamPolicy/main.go | 2 +- .../ModelGardenClient/GetLocation/main.go | 2 +- .../ModelGardenClient/GetOperation/main.go | 2 +- .../GetPublisherModel/main.go | 2 +- .../ModelGardenClient/ListLocations/main.go | 2 +- .../ModelGardenClient/ListOperations/main.go | 2 +- .../ModelGardenClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../ModelGardenClient/WaitOperation/main.go | 2 +- .../AssignNotebookRuntime/main.go | 2 +- .../NotebookClient/CancelOperation/main.go | 2 +- .../CreateNotebookExecutionJob/main.go | 2 +- .../CreateNotebookRuntimeTemplate/main.go | 2 +- .../DeleteNotebookExecutionJob/main.go | 2 +- .../DeleteNotebookRuntime/main.go | 2 +- .../DeleteNotebookRuntimeTemplate/main.go | 2 +- .../NotebookClient/DeleteOperation/main.go | 2 +- .../apiv1/NotebookClient/GetIamPolicy/main.go | 2 +- .../apiv1/NotebookClient/GetLocation/main.go | 2 +- .../GetNotebookExecutionJob/main.go | 2 +- .../NotebookClient/GetNotebookRuntime/main.go | 2 +- .../GetNotebookRuntimeTemplate/main.go | 2 +- .../apiv1/NotebookClient/GetOperation/main.go | 2 +- .../NotebookClient/ListLocations/main.go | 2 +- .../ListNotebookExecutionJobs/main.go | 2 +- .../ListNotebookRuntimeTemplates/main.go | 2 +- .../ListNotebookRuntimes/main.go | 2 +- .../NotebookClient/ListOperations/main.go | 2 +- .../apiv1/NotebookClient/SetIamPolicy/main.go | 2 +- .../StartNotebookRuntime/main.go | 2 +- .../StopNotebookRuntime/main.go | 2 +- .../NotebookClient/TestIamPermissions/main.go | 2 +- .../UpdateNotebookRuntimeTemplate/main.go | 2 +- .../UpgradeNotebookRuntime/main.go | 2 +- .../NotebookClient/WaitOperation/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreatePersistentResource/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../DeletePersistentResource/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetPersistentResource/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListPersistentResources/main.go | 2 +- .../RebootPersistentResource/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdatePersistentResource/main.go | 2 +- .../WaitOperation/main.go | 2 +- .../BatchCancelPipelineJobs/main.go | 2 +- .../BatchDeletePipelineJobs/main.go | 2 +- .../PipelineClient/CancelOperation/main.go | 2 +- .../PipelineClient/CancelPipelineJob/main.go | 2 +- .../CancelTrainingPipeline/main.go | 2 +- .../PipelineClient/CreatePipelineJob/main.go | 2 +- .../CreateTrainingPipeline/main.go | 2 +- .../PipelineClient/DeleteOperation/main.go | 2 +- .../PipelineClient/DeletePipelineJob/main.go | 2 +- .../DeleteTrainingPipeline/main.go | 2 +- .../apiv1/PipelineClient/GetIamPolicy/main.go | 2 +- .../apiv1/PipelineClient/GetLocation/main.go | 2 +- .../apiv1/PipelineClient/GetOperation/main.go | 2 +- .../PipelineClient/GetPipelineJob/main.go | 2 +- .../GetTrainingPipeline/main.go | 2 +- .../PipelineClient/ListLocations/main.go | 2 +- .../PipelineClient/ListOperations/main.go | 2 +- .../PipelineClient/ListPipelineJobs/main.go | 2 +- .../ListTrainingPipelines/main.go | 2 +- .../apiv1/PipelineClient/SetIamPolicy/main.go | 2 +- .../PipelineClient/TestIamPermissions/main.go | 2 +- .../PipelineClient/WaitOperation/main.go | 2 +- .../PredictionClient/CancelOperation/main.go | 2 +- .../PredictionClient/DeleteOperation/main.go | 2 +- .../PredictionClient/DirectPredict/main.go | 2 +- .../PredictionClient/DirectRawPredict/main.go | 2 +- .../apiv1/PredictionClient/Explain/main.go | 2 +- .../PredictionClient/GenerateContent/main.go | 2 +- .../PredictionClient/GetIamPolicy/main.go | 2 +- .../PredictionClient/GetLocation/main.go | 2 +- .../PredictionClient/GetOperation/main.go | 2 +- .../PredictionClient/ListLocations/main.go | 2 +- .../PredictionClient/ListOperations/main.go | 2 +- .../apiv1/PredictionClient/Predict/main.go | 2 +- .../apiv1/PredictionClient/RawPredict/main.go | 2 +- .../PredictionClient/SetIamPolicy/main.go | 2 +- .../StreamDirectPredict/main.go | 2 +- .../StreamDirectRawPredict/main.go | 2 +- .../PredictionClient/StreamingPredict/main.go | 2 +- .../StreamingRawPredict/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../PredictionClient/WaitOperation/main.go | 2 +- .../ScheduleClient/CancelOperation/main.go | 2 +- .../ScheduleClient/CreateSchedule/main.go | 2 +- .../ScheduleClient/DeleteOperation/main.go | 2 +- .../ScheduleClient/DeleteSchedule/main.go | 2 +- .../apiv1/ScheduleClient/GetIamPolicy/main.go | 2 +- .../apiv1/ScheduleClient/GetLocation/main.go | 2 +- .../apiv1/ScheduleClient/GetOperation/main.go | 2 +- .../apiv1/ScheduleClient/GetSchedule/main.go | 2 +- .../ScheduleClient/ListLocations/main.go | 2 +- .../ScheduleClient/ListOperations/main.go | 2 +- .../ScheduleClient/ListSchedules/main.go | 2 +- .../ScheduleClient/PauseSchedule/main.go | 2 +- .../ScheduleClient/ResumeSchedule/main.go | 2 +- .../apiv1/ScheduleClient/SetIamPolicy/main.go | 2 +- .../ScheduleClient/TestIamPermissions/main.go | 2 +- .../ScheduleClient/UpdateSchedule/main.go | 2 +- .../ScheduleClient/WaitOperation/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateSpecialistPool/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../DeleteSpecialistPool/main.go | 2 +- .../SpecialistPoolClient/GetIamPolicy/main.go | 2 +- .../SpecialistPoolClient/GetLocation/main.go | 2 +- .../SpecialistPoolClient/GetOperation/main.go | 2 +- .../GetSpecialistPool/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListSpecialistPools/main.go | 2 +- .../SpecialistPoolClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateSpecialistPool/main.go | 2 +- .../WaitOperation/main.go | 2 +- .../BatchCreateTensorboardRuns/main.go | 2 +- .../BatchCreateTensorboardTimeSeries/main.go | 2 +- .../main.go | 2 +- .../TensorboardClient/CancelOperation/main.go | 2 +- .../CreateTensorboard/main.go | 2 +- .../CreateTensorboardExperiment/main.go | 2 +- .../CreateTensorboardRun/main.go | 2 +- .../CreateTensorboardTimeSeries/main.go | 2 +- .../TensorboardClient/DeleteOperation/main.go | 2 +- .../DeleteTensorboard/main.go | 2 +- .../DeleteTensorboardExperiment/main.go | 2 +- .../DeleteTensorboardRun/main.go | 2 +- .../DeleteTensorboardTimeSeries/main.go | 2 +- .../ExportTensorboardTimeSeriesData/main.go | 2 +- .../TensorboardClient/GetIamPolicy/main.go | 2 +- .../TensorboardClient/GetLocation/main.go | 2 +- .../TensorboardClient/GetOperation/main.go | 2 +- .../TensorboardClient/GetTensorboard/main.go | 2 +- .../GetTensorboardExperiment/main.go | 2 +- .../GetTensorboardRun/main.go | 2 +- .../GetTensorboardTimeSeries/main.go | 2 +- .../TensorboardClient/ListLocations/main.go | 2 +- .../TensorboardClient/ListOperations/main.go | 2 +- .../ListTensorboardExperiments/main.go | 2 +- .../ListTensorboardRuns/main.go | 2 +- .../ListTensorboardTimeSeries/main.go | 2 +- .../ListTensorboards/main.go | 2 +- .../ReadTensorboardSize/main.go | 2 +- .../ReadTensorboardTimeSeriesData/main.go | 2 +- .../ReadTensorboardUsage/main.go | 2 +- .../TensorboardClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateTensorboard/main.go | 2 +- .../UpdateTensorboardExperiment/main.go | 2 +- .../UpdateTensorboardRun/main.go | 2 +- .../UpdateTensorboardTimeSeries/main.go | 2 +- .../TensorboardClient/WaitOperation/main.go | 2 +- .../WriteTensorboardExperimentData/main.go | 2 +- .../WriteTensorboardRunData/main.go | 2 +- .../VertexRagClient/AugmentPrompt/main.go | 2 +- .../VertexRagClient/CancelOperation/main.go | 2 +- .../CorroborateContent/main.go | 2 +- .../VertexRagClient/DeleteOperation/main.go | 2 +- .../VertexRagClient/GetIamPolicy/main.go | 2 +- .../apiv1/VertexRagClient/GetLocation/main.go | 2 +- .../VertexRagClient/GetOperation/main.go | 2 +- .../VertexRagClient/ListLocations/main.go | 2 +- .../VertexRagClient/ListOperations/main.go | 2 +- .../VertexRagClient/RetrieveContexts/main.go | 2 +- .../VertexRagClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../VertexRagClient/WaitOperation/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateRagCorpus/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../DeleteRagCorpus/main.go | 2 +- .../VertexRagDataClient/DeleteRagFile/main.go | 2 +- .../VertexRagDataClient/GetIamPolicy/main.go | 2 +- .../VertexRagDataClient/GetLocation/main.go | 2 +- .../VertexRagDataClient/GetOperation/main.go | 2 +- .../VertexRagDataClient/GetRagCorpus/main.go | 2 +- .../VertexRagDataClient/GetRagFile/main.go | 2 +- .../ImportRagFiles/main.go | 2 +- .../VertexRagDataClient/ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListRagCorpora/main.go | 2 +- .../VertexRagDataClient/ListRagFiles/main.go | 2 +- .../VertexRagDataClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateRagCorpus/main.go | 2 +- .../VertexRagDataClient/UploadRagFile/main.go | 2 +- .../VertexRagDataClient/WaitOperation/main.go | 2 +- .../VizierClient/AddTrialMeasurement/main.go | 2 +- .../VizierClient/CancelOperation/main.go | 2 +- .../CheckTrialEarlyStoppingState/main.go | 2 +- .../apiv1/VizierClient/CompleteTrial/main.go | 2 +- .../apiv1/VizierClient/CreateStudy/main.go | 2 +- .../apiv1/VizierClient/CreateTrial/main.go | 2 +- .../VizierClient/DeleteOperation/main.go | 2 +- .../apiv1/VizierClient/DeleteStudy/main.go | 2 +- .../apiv1/VizierClient/DeleteTrial/main.go | 2 +- .../apiv1/VizierClient/GetIamPolicy/main.go | 2 +- .../apiv1/VizierClient/GetLocation/main.go | 2 +- .../apiv1/VizierClient/GetOperation/main.go | 2 +- .../apiv1/VizierClient/GetStudy/main.go | 2 +- .../apiv1/VizierClient/GetTrial/main.go | 2 +- .../apiv1/VizierClient/ListLocations/main.go | 2 +- .../apiv1/VizierClient/ListOperations/main.go | 2 +- .../VizierClient/ListOptimalTrials/main.go | 2 +- .../apiv1/VizierClient/ListStudies/main.go | 2 +- .../apiv1/VizierClient/ListTrials/main.go | 2 +- .../apiv1/VizierClient/LookupStudy/main.go | 2 +- .../apiv1/VizierClient/SetIamPolicy/main.go | 2 +- .../apiv1/VizierClient/StopTrial/main.go | 2 +- .../apiv1/VizierClient/SuggestTrials/main.go | 2 +- .../VizierClient/TestIamPermissions/main.go | 2 +- .../apiv1/VizierClient/WaitOperation/main.go | 2 +- .../DatasetClient/CancelOperation/main.go | 2 +- .../DatasetClient/CreateDataset/main.go | 2 +- .../CreateDatasetVersion/main.go | 2 +- .../DatasetClient/DeleteDataset/main.go | 2 +- .../DeleteDatasetVersion/main.go | 2 +- .../DatasetClient/DeleteOperation/main.go | 2 +- .../DatasetClient/DeleteSavedQuery/main.go | 2 +- .../DatasetClient/ExportData/main.go | 2 +- .../DatasetClient/GetAnnotationSpec/main.go | 2 +- .../DatasetClient/GetDataset/main.go | 2 +- .../DatasetClient/GetDatasetVersion/main.go | 2 +- .../DatasetClient/GetIamPolicy/main.go | 2 +- .../DatasetClient/GetLocation/main.go | 2 +- .../DatasetClient/GetOperation/main.go | 2 +- .../DatasetClient/ImportData/main.go | 2 +- .../DatasetClient/ListAnnotations/main.go | 2 +- .../DatasetClient/ListDataItems/main.go | 2 +- .../DatasetClient/ListDatasetVersions/main.go | 2 +- .../DatasetClient/ListDatasets/main.go | 2 +- .../DatasetClient/ListLocations/main.go | 2 +- .../DatasetClient/ListOperations/main.go | 2 +- .../DatasetClient/ListSavedQueries/main.go | 2 +- .../RestoreDatasetVersion/main.go | 2 +- .../DatasetClient/SearchDataItems/main.go | 2 +- .../DatasetClient/SetIamPolicy/main.go | 2 +- .../DatasetClient/TestIamPermissions/main.go | 2 +- .../DatasetClient/UpdateDataset/main.go | 2 +- .../UpdateDatasetVersion/main.go | 2 +- .../DatasetClient/WaitOperation/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateDeploymentResourcePool/main.go | 2 +- .../DeleteDeploymentResourcePool/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../GetDeploymentResourcePool/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListDeploymentResourcePools/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../QueryDeployedModels/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateDeploymentResourcePool/main.go | 2 +- .../WaitOperation/main.go | 2 +- .../EndpointClient/CancelOperation/main.go | 2 +- .../EndpointClient/CreateEndpoint/main.go | 2 +- .../EndpointClient/DeleteEndpoint/main.go | 2 +- .../EndpointClient/DeleteOperation/main.go | 2 +- .../EndpointClient/DeployModel/main.go | 2 +- .../EndpointClient/GetEndpoint/main.go | 2 +- .../EndpointClient/GetIamPolicy/main.go | 2 +- .../EndpointClient/GetLocation/main.go | 2 +- .../EndpointClient/GetOperation/main.go | 2 +- .../EndpointClient/ListEndpoints/main.go | 2 +- .../EndpointClient/ListLocations/main.go | 2 +- .../EndpointClient/ListOperations/main.go | 2 +- .../MutateDeployedModel/main.go | 2 +- .../EndpointClient/SetIamPolicy/main.go | 2 +- .../EndpointClient/TestIamPermissions/main.go | 2 +- .../EndpointClient/UndeployModel/main.go | 2 +- .../EndpointClient/UpdateEndpoint/main.go | 2 +- .../UpdateEndpointLongRunning/main.go | 2 +- .../EndpointClient/WaitOperation/main.go | 2 +- .../EvaluationClient/CancelOperation/main.go | 2 +- .../EvaluationClient/DeleteOperation/main.go | 2 +- .../EvaluateInstances/main.go | 2 +- .../EvaluationClient/GetIamPolicy/main.go | 2 +- .../EvaluationClient/GetLocation/main.go | 2 +- .../EvaluationClient/GetOperation/main.go | 2 +- .../EvaluationClient/ListLocations/main.go | 2 +- .../EvaluationClient/ListOperations/main.go | 2 +- .../EvaluationClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../EvaluationClient/WaitOperation/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../ExecuteExtension/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../QueryExtension/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../WaitOperation/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../DeleteExtension/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../GetExtension/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ImportExtension/main.go | 2 +- .../ListExtensions/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateExtension/main.go | 2 +- .../WaitOperation/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateFeatureOnlineStore/main.go | 2 +- .../CreateFeatureView/main.go | 2 +- .../DeleteFeatureOnlineStore/main.go | 2 +- .../DeleteFeatureView/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../GetFeatureOnlineStore/main.go | 2 +- .../GetFeatureView/main.go | 2 +- .../GetFeatureViewSync/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListFeatureOnlineStores/main.go | 2 +- .../ListFeatureViewSyncs/main.go | 2 +- .../ListFeatureViews/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../SyncFeatureView/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateFeatureOnlineStore/main.go | 2 +- .../UpdateFeatureView/main.go | 2 +- .../WaitOperation/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../FetchFeatureValues/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../SearchNearestEntities/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../StreamingFetchFeatureValues/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../WaitOperation/main.go | 2 +- .../BatchCreateFeatures/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateFeature/main.go | 2 +- .../CreateFeatureGroup/main.go | 2 +- .../CreateFeatureMonitor/main.go | 2 +- .../CreateFeatureMonitorJob/main.go | 2 +- .../DeleteFeature/main.go | 2 +- .../DeleteFeatureGroup/main.go | 2 +- .../DeleteFeatureMonitor/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../FeatureRegistryClient/GetFeature/main.go | 2 +- .../GetFeatureGroup/main.go | 2 +- .../GetFeatureMonitor/main.go | 2 +- .../GetFeatureMonitorJob/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../FeatureRegistryClient/GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListFeatureGroups/main.go | 2 +- .../ListFeatureMonitorJobs/main.go | 2 +- .../ListFeatureMonitors/main.go | 2 +- .../ListFeatures/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateFeature/main.go | 2 +- .../UpdateFeatureGroup/main.go | 2 +- .../WaitOperation/main.go | 2 +- .../BatchCreateFeatures/main.go | 2 +- .../BatchReadFeatureValues/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateEntityType/main.go | 2 +- .../FeaturestoreClient/CreateFeature/main.go | 2 +- .../CreateFeaturestore/main.go | 2 +- .../DeleteEntityType/main.go | 2 +- .../FeaturestoreClient/DeleteFeature/main.go | 2 +- .../DeleteFeatureValues/main.go | 2 +- .../DeleteFeaturestore/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../ExportFeatureValues/main.go | 2 +- .../FeaturestoreClient/GetEntityType/main.go | 2 +- .../FeaturestoreClient/GetFeature/main.go | 2 +- .../GetFeaturestore/main.go | 2 +- .../FeaturestoreClient/GetIamPolicy/main.go | 2 +- .../FeaturestoreClient/GetLocation/main.go | 2 +- .../FeaturestoreClient/GetOperation/main.go | 2 +- .../ImportFeatureValues/main.go | 2 +- .../ListEntityTypes/main.go | 2 +- .../FeaturestoreClient/ListFeatures/main.go | 2 +- .../ListFeaturestores/main.go | 2 +- .../FeaturestoreClient/ListLocations/main.go | 2 +- .../FeaturestoreClient/ListOperations/main.go | 2 +- .../FeaturestoreClient/SearchFeatures/main.go | 2 +- .../FeaturestoreClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateEntityType/main.go | 2 +- .../FeaturestoreClient/UpdateFeature/main.go | 2 +- .../UpdateFeaturestore/main.go | 2 +- .../FeaturestoreClient/WaitOperation/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ReadFeatureValues/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../WaitOperation/main.go | 2 +- .../WriteFeatureValues/main.go | 2 +- .../GenAiCacheClient/CancelOperation/main.go | 2 +- .../CreateCachedContent/main.go | 2 +- .../DeleteCachedContent/main.go | 2 +- .../GenAiCacheClient/DeleteOperation/main.go | 2 +- .../GenAiCacheClient/GetCachedContent/main.go | 2 +- .../GenAiCacheClient/GetIamPolicy/main.go | 2 +- .../GenAiCacheClient/GetLocation/main.go | 2 +- .../GenAiCacheClient/GetOperation/main.go | 2 +- .../ListCachedContents/main.go | 2 +- .../GenAiCacheClient/ListLocations/main.go | 2 +- .../GenAiCacheClient/ListOperations/main.go | 2 +- .../GenAiCacheClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateCachedContent/main.go | 2 +- .../GenAiCacheClient/WaitOperation/main.go | 2 +- .../GenAiTuningClient/CancelOperation/main.go | 2 +- .../GenAiTuningClient/CancelTuningJob/main.go | 2 +- .../GenAiTuningClient/CreateTuningJob/main.go | 2 +- .../GenAiTuningClient/DeleteOperation/main.go | 2 +- .../GenAiTuningClient/GetIamPolicy/main.go | 2 +- .../GenAiTuningClient/GetLocation/main.go | 2 +- .../GenAiTuningClient/GetOperation/main.go | 2 +- .../GenAiTuningClient/GetTuningJob/main.go | 2 +- .../GenAiTuningClient/ListLocations/main.go | 2 +- .../GenAiTuningClient/ListOperations/main.go | 2 +- .../GenAiTuningClient/ListTuningJobs/main.go | 2 +- .../RebaseTunedModel/main.go | 2 +- .../GenAiTuningClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../GenAiTuningClient/WaitOperation/main.go | 2 +- .../IndexClient/CancelOperation/main.go | 2 +- .../IndexClient/CreateIndex/main.go | 2 +- .../IndexClient/DeleteIndex/main.go | 2 +- .../IndexClient/DeleteOperation/main.go | 2 +- .../IndexClient/GetIamPolicy/main.go | 2 +- .../apiv1beta1/IndexClient/GetIndex/main.go | 2 +- .../IndexClient/GetLocation/main.go | 2 +- .../IndexClient/GetOperation/main.go | 2 +- .../IndexClient/ListIndexes/main.go | 2 +- .../IndexClient/ListLocations/main.go | 2 +- .../IndexClient/ListOperations/main.go | 2 +- .../IndexClient/RemoveDatapoints/main.go | 2 +- .../IndexClient/SetIamPolicy/main.go | 2 +- .../IndexClient/TestIamPermissions/main.go | 2 +- .../IndexClient/UpdateIndex/main.go | 2 +- .../IndexClient/UpsertDatapoints/main.go | 2 +- .../IndexClient/WaitOperation/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateIndexEndpoint/main.go | 2 +- .../DeleteIndexEndpoint/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../IndexEndpointClient/DeployIndex/main.go | 2 +- .../IndexEndpointClient/GetIamPolicy/main.go | 2 +- .../GetIndexEndpoint/main.go | 2 +- .../IndexEndpointClient/GetLocation/main.go | 2 +- .../IndexEndpointClient/GetOperation/main.go | 2 +- .../ListIndexEndpoints/main.go | 2 +- .../IndexEndpointClient/ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../MutateDeployedIndex/main.go | 2 +- .../IndexEndpointClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../IndexEndpointClient/UndeployIndex/main.go | 2 +- .../UpdateIndexEndpoint/main.go | 2 +- .../IndexEndpointClient/WaitOperation/main.go | 2 +- .../CancelBatchPredictionJob/main.go | 2 +- .../JobClient/CancelCustomJob/main.go | 2 +- .../JobClient/CancelDataLabelingJob/main.go | 2 +- .../CancelHyperparameterTuningJob/main.go | 2 +- .../apiv1beta1/JobClient/CancelNasJob/main.go | 2 +- .../JobClient/CancelOperation/main.go | 2 +- .../CreateBatchPredictionJob/main.go | 2 +- .../JobClient/CreateCustomJob/main.go | 2 +- .../JobClient/CreateDataLabelingJob/main.go | 2 +- .../CreateHyperparameterTuningJob/main.go | 2 +- .../main.go | 2 +- .../apiv1beta1/JobClient/CreateNasJob/main.go | 2 +- .../DeleteBatchPredictionJob/main.go | 2 +- .../JobClient/DeleteCustomJob/main.go | 2 +- .../JobClient/DeleteDataLabelingJob/main.go | 2 +- .../DeleteHyperparameterTuningJob/main.go | 2 +- .../main.go | 2 +- .../apiv1beta1/JobClient/DeleteNasJob/main.go | 2 +- .../JobClient/DeleteOperation/main.go | 2 +- .../JobClient/GetBatchPredictionJob/main.go | 2 +- .../apiv1beta1/JobClient/GetCustomJob/main.go | 2 +- .../JobClient/GetDataLabelingJob/main.go | 2 +- .../GetHyperparameterTuningJob/main.go | 2 +- .../apiv1beta1/JobClient/GetIamPolicy/main.go | 2 +- .../apiv1beta1/JobClient/GetLocation/main.go | 2 +- .../GetModelDeploymentMonitoringJob/main.go | 2 +- .../apiv1beta1/JobClient/GetNasJob/main.go | 2 +- .../JobClient/GetNasTrialDetail/main.go | 2 +- .../apiv1beta1/JobClient/GetOperation/main.go | 2 +- .../JobClient/ListBatchPredictionJobs/main.go | 2 +- .../JobClient/ListCustomJobs/main.go | 2 +- .../JobClient/ListDataLabelingJobs/main.go | 2 +- .../ListHyperparameterTuningJobs/main.go | 2 +- .../JobClient/ListLocations/main.go | 2 +- .../ListModelDeploymentMonitoringJobs/main.go | 2 +- .../apiv1beta1/JobClient/ListNasJobs/main.go | 2 +- .../JobClient/ListNasTrialDetails/main.go | 2 +- .../JobClient/ListOperations/main.go | 2 +- .../PauseModelDeploymentMonitoringJob/main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../apiv1beta1/JobClient/SetIamPolicy/main.go | 2 +- .../JobClient/TestIamPermissions/main.go | 2 +- .../main.go | 2 +- .../JobClient/WaitOperation/main.go | 2 +- .../LlmUtilityClient/CancelOperation/main.go | 2 +- .../LlmUtilityClient/ComputeTokens/main.go | 2 +- .../LlmUtilityClient/DeleteOperation/main.go | 2 +- .../LlmUtilityClient/GetIamPolicy/main.go | 2 +- .../LlmUtilityClient/GetLocation/main.go | 2 +- .../LlmUtilityClient/GetOperation/main.go | 2 +- .../LlmUtilityClient/ListLocations/main.go | 2 +- .../LlmUtilityClient/ListOperations/main.go | 2 +- .../LlmUtilityClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../LlmUtilityClient/WaitOperation/main.go | 2 +- .../MatchClient/CancelOperation/main.go | 2 +- .../MatchClient/DeleteOperation/main.go | 2 +- .../MatchClient/FindNeighbors/main.go | 2 +- .../MatchClient/GetIamPolicy/main.go | 2 +- .../MatchClient/GetLocation/main.go | 2 +- .../MatchClient/GetOperation/main.go | 2 +- .../MatchClient/ListLocations/main.go | 2 +- .../MatchClient/ListOperations/main.go | 2 +- .../MatchClient/ReadIndexDatapoints/main.go | 2 +- .../MatchClient/SetIamPolicy/main.go | 2 +- .../MatchClient/TestIamPermissions/main.go | 2 +- .../MatchClient/WaitOperation/main.go | 2 +- .../AddContextArtifactsAndExecutions/main.go | 2 +- .../MetadataClient/AddContextChildren/main.go | 2 +- .../MetadataClient/AddExecutionEvents/main.go | 2 +- .../MetadataClient/CancelOperation/main.go | 2 +- .../MetadataClient/CreateArtifact/main.go | 2 +- .../MetadataClient/CreateContext/main.go | 2 +- .../MetadataClient/CreateExecution/main.go | 2 +- .../CreateMetadataSchema/main.go | 2 +- .../CreateMetadataStore/main.go | 2 +- .../MetadataClient/DeleteArtifact/main.go | 2 +- .../MetadataClient/DeleteContext/main.go | 2 +- .../MetadataClient/DeleteExecution/main.go | 2 +- .../DeleteMetadataStore/main.go | 2 +- .../MetadataClient/DeleteOperation/main.go | 2 +- .../MetadataClient/GetArtifact/main.go | 2 +- .../MetadataClient/GetContext/main.go | 2 +- .../MetadataClient/GetExecution/main.go | 2 +- .../MetadataClient/GetIamPolicy/main.go | 2 +- .../MetadataClient/GetLocation/main.go | 2 +- .../MetadataClient/GetMetadataSchema/main.go | 2 +- .../MetadataClient/GetMetadataStore/main.go | 2 +- .../MetadataClient/GetOperation/main.go | 2 +- .../MetadataClient/ListArtifacts/main.go | 2 +- .../MetadataClient/ListContexts/main.go | 2 +- .../MetadataClient/ListExecutions/main.go | 2 +- .../MetadataClient/ListLocations/main.go | 2 +- .../ListMetadataSchemas/main.go | 2 +- .../MetadataClient/ListMetadataStores/main.go | 2 +- .../MetadataClient/ListOperations/main.go | 2 +- .../MetadataClient/PurgeArtifacts/main.go | 2 +- .../MetadataClient/PurgeContexts/main.go | 2 +- .../MetadataClient/PurgeExecutions/main.go | 2 +- .../QueryArtifactLineageSubgraph/main.go | 2 +- .../QueryContextLineageSubgraph/main.go | 2 +- .../QueryExecutionInputsAndOutputs/main.go | 2 +- .../RemoveContextChildren/main.go | 2 +- .../MetadataClient/SetIamPolicy/main.go | 2 +- .../MetadataClient/TestIamPermissions/main.go | 2 +- .../MetadataClient/UpdateArtifact/main.go | 2 +- .../MetadataClient/UpdateContext/main.go | 2 +- .../MetadataClient/UpdateExecution/main.go | 2 +- .../MetadataClient/WaitOperation/main.go | 2 +- .../BatchMigrateResources/main.go | 2 +- .../MigrationClient/CancelOperation/main.go | 2 +- .../MigrationClient/DeleteOperation/main.go | 2 +- .../MigrationClient/GetIamPolicy/main.go | 2 +- .../MigrationClient/GetLocation/main.go | 2 +- .../MigrationClient/GetOperation/main.go | 2 +- .../MigrationClient/ListLocations/main.go | 2 +- .../MigrationClient/ListOperations/main.go | 2 +- .../SearchMigratableResources/main.go | 2 +- .../MigrationClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../MigrationClient/WaitOperation/main.go | 2 +- .../BatchImportEvaluatedAnnotations/main.go | 2 +- .../BatchImportModelEvaluationSlices/main.go | 2 +- .../ModelClient/CancelOperation/main.go | 2 +- .../apiv1beta1/ModelClient/CopyModel/main.go | 2 +- .../ModelClient/DeleteModel/main.go | 2 +- .../ModelClient/DeleteModelVersion/main.go | 2 +- .../ModelClient/DeleteOperation/main.go | 2 +- .../ModelClient/ExportModel/main.go | 2 +- .../ModelClient/GetIamPolicy/main.go | 2 +- .../ModelClient/GetLocation/main.go | 2 +- .../apiv1beta1/ModelClient/GetModel/main.go | 2 +- .../ModelClient/GetModelEvaluation/main.go | 2 +- .../GetModelEvaluationSlice/main.go | 2 +- .../ModelClient/GetOperation/main.go | 2 +- .../ModelClient/ImportModelEvaluation/main.go | 2 +- .../ModelClient/ListLocations/main.go | 2 +- .../ListModelEvaluationSlices/main.go | 2 +- .../ModelClient/ListModelEvaluations/main.go | 2 +- .../ModelClient/ListModelVersions/main.go | 2 +- .../apiv1beta1/ModelClient/ListModels/main.go | 2 +- .../ModelClient/ListOperations/main.go | 2 +- .../ModelClient/MergeVersionAliases/main.go | 2 +- .../ModelClient/SetIamPolicy/main.go | 2 +- .../ModelClient/TestIamPermissions/main.go | 2 +- .../UpdateExplanationDataset/main.go | 2 +- .../ModelClient/UpdateModel/main.go | 2 +- .../ModelClient/UploadModel/main.go | 2 +- .../ModelClient/WaitOperation/main.go | 2 +- .../ModelGardenClient/CancelOperation/main.go | 2 +- .../ModelGardenClient/DeleteOperation/main.go | 2 +- .../DeployPublisherModel/main.go | 2 +- .../ModelGardenClient/GetIamPolicy/main.go | 2 +- .../ModelGardenClient/GetLocation/main.go | 2 +- .../ModelGardenClient/GetOperation/main.go | 2 +- .../GetPublisherModel/main.go | 2 +- .../ModelGardenClient/ListLocations/main.go | 2 +- .../ModelGardenClient/ListOperations/main.go | 2 +- .../ListPublisherModels/main.go | 2 +- .../ModelGardenClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../ModelGardenClient/WaitOperation/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateModelMonitor/main.go | 2 +- .../CreateModelMonitoringJob/main.go | 2 +- .../DeleteModelMonitor/main.go | 2 +- .../DeleteModelMonitoringJob/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../ModelMonitoringClient/GetLocation/main.go | 2 +- .../GetModelMonitor/main.go | 2 +- .../GetModelMonitoringJob/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListModelMonitoringJobs/main.go | 2 +- .../ListModelMonitors/main.go | 2 +- .../ListOperations/main.go | 2 +- .../SearchModelMonitoringAlerts/main.go | 2 +- .../SearchModelMonitoringStats/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateModelMonitor/main.go | 2 +- .../WaitOperation/main.go | 2 +- .../AssignNotebookRuntime/main.go | 2 +- .../NotebookClient/CancelOperation/main.go | 2 +- .../CreateNotebookExecutionJob/main.go | 2 +- .../CreateNotebookRuntimeTemplate/main.go | 2 +- .../DeleteNotebookExecutionJob/main.go | 2 +- .../DeleteNotebookRuntime/main.go | 2 +- .../DeleteNotebookRuntimeTemplate/main.go | 2 +- .../NotebookClient/DeleteOperation/main.go | 2 +- .../NotebookClient/GetIamPolicy/main.go | 2 +- .../NotebookClient/GetLocation/main.go | 2 +- .../GetNotebookExecutionJob/main.go | 2 +- .../NotebookClient/GetNotebookRuntime/main.go | 2 +- .../GetNotebookRuntimeTemplate/main.go | 2 +- .../NotebookClient/GetOperation/main.go | 2 +- .../NotebookClient/ListLocations/main.go | 2 +- .../ListNotebookExecutionJobs/main.go | 2 +- .../ListNotebookRuntimeTemplates/main.go | 2 +- .../ListNotebookRuntimes/main.go | 2 +- .../NotebookClient/ListOperations/main.go | 2 +- .../NotebookClient/SetIamPolicy/main.go | 2 +- .../StartNotebookRuntime/main.go | 2 +- .../StopNotebookRuntime/main.go | 2 +- .../NotebookClient/TestIamPermissions/main.go | 2 +- .../UpdateNotebookRuntimeTemplate/main.go | 2 +- .../UpgradeNotebookRuntime/main.go | 2 +- .../NotebookClient/WaitOperation/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreatePersistentResource/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../DeletePersistentResource/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetPersistentResource/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListPersistentResources/main.go | 2 +- .../RebootPersistentResource/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdatePersistentResource/main.go | 2 +- .../WaitOperation/main.go | 2 +- .../BatchCancelPipelineJobs/main.go | 2 +- .../BatchDeletePipelineJobs/main.go | 2 +- .../PipelineClient/CancelOperation/main.go | 2 +- .../PipelineClient/CancelPipelineJob/main.go | 2 +- .../CancelTrainingPipeline/main.go | 2 +- .../PipelineClient/CreatePipelineJob/main.go | 2 +- .../CreateTrainingPipeline/main.go | 2 +- .../PipelineClient/DeleteOperation/main.go | 2 +- .../PipelineClient/DeletePipelineJob/main.go | 2 +- .../DeleteTrainingPipeline/main.go | 2 +- .../PipelineClient/GetIamPolicy/main.go | 2 +- .../PipelineClient/GetLocation/main.go | 2 +- .../PipelineClient/GetOperation/main.go | 2 +- .../PipelineClient/GetPipelineJob/main.go | 2 +- .../GetTrainingPipeline/main.go | 2 +- .../PipelineClient/ListLocations/main.go | 2 +- .../PipelineClient/ListOperations/main.go | 2 +- .../PipelineClient/ListPipelineJobs/main.go | 2 +- .../ListTrainingPipelines/main.go | 2 +- .../PipelineClient/SetIamPolicy/main.go | 2 +- .../PipelineClient/TestIamPermissions/main.go | 2 +- .../PipelineClient/WaitOperation/main.go | 2 +- .../PredictionClient/CancelOperation/main.go | 2 +- .../PredictionClient/CountTokens/main.go | 2 +- .../PredictionClient/DeleteOperation/main.go | 2 +- .../PredictionClient/DirectPredict/main.go | 2 +- .../PredictionClient/DirectRawPredict/main.go | 2 +- .../PredictionClient/Explain/main.go | 2 +- .../PredictionClient/GenerateContent/main.go | 2 +- .../PredictionClient/GetIamPolicy/main.go | 2 +- .../PredictionClient/GetLocation/main.go | 2 +- .../PredictionClient/GetOperation/main.go | 2 +- .../PredictionClient/ListLocations/main.go | 2 +- .../PredictionClient/ListOperations/main.go | 2 +- .../PredictionClient/Predict/main.go | 2 +- .../PredictionClient/RawPredict/main.go | 2 +- .../PredictionClient/SetIamPolicy/main.go | 2 +- .../StreamDirectPredict/main.go | 2 +- .../StreamDirectRawPredict/main.go | 2 +- .../PredictionClient/StreamingPredict/main.go | 2 +- .../StreamingRawPredict/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../PredictionClient/WaitOperation/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateReasoningEngine/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../DeleteReasoningEngine/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../ReasoningEngineClient/GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetReasoningEngine/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListReasoningEngines/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateReasoningEngine/main.go | 2 +- .../WaitOperation/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../QueryReasoningEngine/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../WaitOperation/main.go | 2 +- .../ScheduleClient/CancelOperation/main.go | 2 +- .../ScheduleClient/CreateSchedule/main.go | 2 +- .../ScheduleClient/DeleteOperation/main.go | 2 +- .../ScheduleClient/DeleteSchedule/main.go | 2 +- .../ScheduleClient/GetIamPolicy/main.go | 2 +- .../ScheduleClient/GetLocation/main.go | 2 +- .../ScheduleClient/GetOperation/main.go | 2 +- .../ScheduleClient/GetSchedule/main.go | 2 +- .../ScheduleClient/ListLocations/main.go | 2 +- .../ScheduleClient/ListOperations/main.go | 2 +- .../ScheduleClient/ListSchedules/main.go | 2 +- .../ScheduleClient/PauseSchedule/main.go | 2 +- .../ScheduleClient/ResumeSchedule/main.go | 2 +- .../ScheduleClient/SetIamPolicy/main.go | 2 +- .../ScheduleClient/TestIamPermissions/main.go | 2 +- .../ScheduleClient/UpdateSchedule/main.go | 2 +- .../ScheduleClient/WaitOperation/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateSpecialistPool/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../DeleteSpecialistPool/main.go | 2 +- .../SpecialistPoolClient/GetIamPolicy/main.go | 2 +- .../SpecialistPoolClient/GetLocation/main.go | 2 +- .../SpecialistPoolClient/GetOperation/main.go | 2 +- .../GetSpecialistPool/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListSpecialistPools/main.go | 2 +- .../SpecialistPoolClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateSpecialistPool/main.go | 2 +- .../WaitOperation/main.go | 2 +- .../BatchCreateTensorboardRuns/main.go | 2 +- .../BatchCreateTensorboardTimeSeries/main.go | 2 +- .../main.go | 2 +- .../TensorboardClient/CancelOperation/main.go | 2 +- .../CreateTensorboard/main.go | 2 +- .../CreateTensorboardExperiment/main.go | 2 +- .../CreateTensorboardRun/main.go | 2 +- .../CreateTensorboardTimeSeries/main.go | 2 +- .../TensorboardClient/DeleteOperation/main.go | 2 +- .../DeleteTensorboard/main.go | 2 +- .../DeleteTensorboardExperiment/main.go | 2 +- .../DeleteTensorboardRun/main.go | 2 +- .../DeleteTensorboardTimeSeries/main.go | 2 +- .../ExportTensorboardTimeSeriesData/main.go | 2 +- .../TensorboardClient/GetIamPolicy/main.go | 2 +- .../TensorboardClient/GetLocation/main.go | 2 +- .../TensorboardClient/GetOperation/main.go | 2 +- .../TensorboardClient/GetTensorboard/main.go | 2 +- .../GetTensorboardExperiment/main.go | 2 +- .../GetTensorboardRun/main.go | 2 +- .../GetTensorboardTimeSeries/main.go | 2 +- .../TensorboardClient/ListLocations/main.go | 2 +- .../TensorboardClient/ListOperations/main.go | 2 +- .../ListTensorboardExperiments/main.go | 2 +- .../ListTensorboardRuns/main.go | 2 +- .../ListTensorboardTimeSeries/main.go | 2 +- .../ListTensorboards/main.go | 2 +- .../ReadTensorboardSize/main.go | 2 +- .../ReadTensorboardTimeSeriesData/main.go | 2 +- .../ReadTensorboardUsage/main.go | 2 +- .../TensorboardClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateTensorboard/main.go | 2 +- .../UpdateTensorboardExperiment/main.go | 2 +- .../UpdateTensorboardRun/main.go | 2 +- .../UpdateTensorboardTimeSeries/main.go | 2 +- .../TensorboardClient/WaitOperation/main.go | 2 +- .../WriteTensorboardExperimentData/main.go | 2 +- .../WriteTensorboardRunData/main.go | 2 +- .../VertexRagClient/AugmentPrompt/main.go | 2 +- .../VertexRagClient/CancelOperation/main.go | 2 +- .../CorroborateContent/main.go | 2 +- .../VertexRagClient/DeleteOperation/main.go | 2 +- .../VertexRagClient/GetIamPolicy/main.go | 2 +- .../VertexRagClient/GetLocation/main.go | 2 +- .../VertexRagClient/GetOperation/main.go | 2 +- .../VertexRagClient/ListLocations/main.go | 2 +- .../VertexRagClient/ListOperations/main.go | 2 +- .../VertexRagClient/RetrieveContexts/main.go | 2 +- .../VertexRagClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../VertexRagClient/WaitOperation/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateRagCorpus/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../DeleteRagCorpus/main.go | 2 +- .../VertexRagDataClient/DeleteRagFile/main.go | 2 +- .../VertexRagDataClient/GetIamPolicy/main.go | 2 +- .../VertexRagDataClient/GetLocation/main.go | 2 +- .../VertexRagDataClient/GetOperation/main.go | 2 +- .../VertexRagDataClient/GetRagCorpus/main.go | 2 +- .../VertexRagDataClient/GetRagFile/main.go | 2 +- .../ImportRagFiles/main.go | 2 +- .../VertexRagDataClient/ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListRagCorpora/main.go | 2 +- .../VertexRagDataClient/ListRagFiles/main.go | 2 +- .../VertexRagDataClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateRagCorpus/main.go | 2 +- .../VertexRagDataClient/UploadRagFile/main.go | 2 +- .../VertexRagDataClient/WaitOperation/main.go | 2 +- .../VizierClient/AddTrialMeasurement/main.go | 2 +- .../VizierClient/CancelOperation/main.go | 2 +- .../CheckTrialEarlyStoppingState/main.go | 2 +- .../VizierClient/CompleteTrial/main.go | 2 +- .../VizierClient/CreateStudy/main.go | 2 +- .../VizierClient/CreateTrial/main.go | 2 +- .../VizierClient/DeleteOperation/main.go | 2 +- .../VizierClient/DeleteStudy/main.go | 2 +- .../VizierClient/DeleteTrial/main.go | 2 +- .../VizierClient/GetIamPolicy/main.go | 2 +- .../VizierClient/GetLocation/main.go | 2 +- .../VizierClient/GetOperation/main.go | 2 +- .../apiv1beta1/VizierClient/GetStudy/main.go | 2 +- .../apiv1beta1/VizierClient/GetTrial/main.go | 2 +- .../VizierClient/ListLocations/main.go | 2 +- .../VizierClient/ListOperations/main.go | 2 +- .../VizierClient/ListOptimalTrials/main.go | 2 +- .../VizierClient/ListStudies/main.go | 2 +- .../VizierClient/ListTrials/main.go | 2 +- .../VizierClient/LookupStudy/main.go | 2 +- .../VizierClient/SetIamPolicy/main.go | 2 +- .../apiv1beta1/VizierClient/StopTrial/main.go | 2 +- .../VizierClient/SuggestTrials/main.go | 2 +- .../VizierClient/TestIamPermissions/main.go | 2 +- .../VizierClient/WaitOperation/main.go | 2 +- .../BatchCreateInstances/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../AlloyDBAdminClient/CreateBackup/main.go | 2 +- .../AlloyDBAdminClient/CreateCluster/main.go | 2 +- .../AlloyDBAdminClient/CreateInstance/main.go | 2 +- .../CreateSecondaryCluster/main.go | 2 +- .../CreateSecondaryInstance/main.go | 2 +- .../AlloyDBAdminClient/CreateUser/main.go | 2 +- .../AlloyDBAdminClient/DeleteBackup/main.go | 2 +- .../AlloyDBAdminClient/DeleteCluster/main.go | 2 +- .../AlloyDBAdminClient/DeleteInstance/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../AlloyDBAdminClient/DeleteUser/main.go | 2 +- .../AlloyDBAdminClient/ExecuteSql/main.go | 2 +- .../FailoverInstance/main.go | 2 +- .../GenerateClientCertificate/main.go | 2 +- .../AlloyDBAdminClient/GetBackup/main.go | 2 +- .../AlloyDBAdminClient/GetCluster/main.go | 2 +- .../GetConnectionInfo/main.go | 2 +- .../AlloyDBAdminClient/GetInstance/main.go | 2 +- .../AlloyDBAdminClient/GetLocation/main.go | 2 +- .../AlloyDBAdminClient/GetOperation/main.go | 2 +- .../apiv1/AlloyDBAdminClient/GetUser/main.go | 2 +- .../AlloyDBAdminClient/InjectFault/main.go | 2 +- .../AlloyDBAdminClient/ListBackups/main.go | 2 +- .../AlloyDBAdminClient/ListClusters/main.go | 2 +- .../AlloyDBAdminClient/ListDatabases/main.go | 2 +- .../AlloyDBAdminClient/ListInstances/main.go | 2 +- .../AlloyDBAdminClient/ListLocations/main.go | 2 +- .../AlloyDBAdminClient/ListOperations/main.go | 2 +- .../ListSupportedDatabaseFlags/main.go | 2 +- .../AlloyDBAdminClient/ListUsers/main.go | 2 +- .../AlloyDBAdminClient/PromoteCluster/main.go | 2 +- .../RestartInstance/main.go | 2 +- .../AlloyDBAdminClient/RestoreCluster/main.go | 2 +- .../SwitchoverCluster/main.go | 2 +- .../AlloyDBAdminClient/UpdateBackup/main.go | 2 +- .../AlloyDBAdminClient/UpdateCluster/main.go | 2 +- .../AlloyDBAdminClient/UpdateInstance/main.go | 2 +- .../AlloyDBAdminClient/UpdateUser/main.go | 2 +- ...ppet_metadata.google.cloud.alloydb.v1.json | 2 +- .../BatchCreateInstances/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../AlloyDBAdminClient/CreateBackup/main.go | 2 +- .../AlloyDBAdminClient/CreateCluster/main.go | 2 +- .../AlloyDBAdminClient/CreateInstance/main.go | 2 +- .../CreateSecondaryCluster/main.go | 2 +- .../CreateSecondaryInstance/main.go | 2 +- .../AlloyDBAdminClient/CreateUser/main.go | 2 +- .../AlloyDBAdminClient/DeleteBackup/main.go | 2 +- .../AlloyDBAdminClient/DeleteCluster/main.go | 2 +- .../AlloyDBAdminClient/DeleteInstance/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../AlloyDBAdminClient/DeleteUser/main.go | 2 +- .../AlloyDBAdminClient/ExecuteSql/main.go | 2 +- .../FailoverInstance/main.go | 2 +- .../GenerateClientCertificate/main.go | 2 +- .../AlloyDBAdminClient/GetBackup/main.go | 2 +- .../AlloyDBAdminClient/GetCluster/main.go | 2 +- .../GetConnectionInfo/main.go | 2 +- .../AlloyDBAdminClient/GetInstance/main.go | 2 +- .../AlloyDBAdminClient/GetLocation/main.go | 2 +- .../AlloyDBAdminClient/GetOperation/main.go | 2 +- .../AlloyDBAdminClient/GetUser/main.go | 2 +- .../AlloyDBAdminClient/InjectFault/main.go | 2 +- .../AlloyDBAdminClient/ListBackups/main.go | 2 +- .../AlloyDBAdminClient/ListClusters/main.go | 2 +- .../AlloyDBAdminClient/ListDatabases/main.go | 2 +- .../AlloyDBAdminClient/ListInstances/main.go | 2 +- .../AlloyDBAdminClient/ListLocations/main.go | 2 +- .../AlloyDBAdminClient/ListOperations/main.go | 2 +- .../ListSupportedDatabaseFlags/main.go | 2 +- .../AlloyDBAdminClient/ListUsers/main.go | 2 +- .../AlloyDBAdminClient/PromoteCluster/main.go | 2 +- .../RestartInstance/main.go | 2 +- .../AlloyDBAdminClient/RestoreCluster/main.go | 2 +- .../SwitchoverCluster/main.go | 2 +- .../AlloyDBAdminClient/UpdateBackup/main.go | 2 +- .../AlloyDBAdminClient/UpdateCluster/main.go | 2 +- .../AlloyDBAdminClient/UpdateInstance/main.go | 2 +- .../AlloyDBAdminClient/UpdateUser/main.go | 2 +- .../AlloyDBAdminClient/UpgradeCluster/main.go | 2 +- ...metadata.google.cloud.alloydb.v1alpha.json | 2 +- .../BatchCreateInstances/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../AlloyDBAdminClient/CreateBackup/main.go | 2 +- .../AlloyDBAdminClient/CreateCluster/main.go | 2 +- .../AlloyDBAdminClient/CreateInstance/main.go | 2 +- .../CreateSecondaryCluster/main.go | 2 +- .../CreateSecondaryInstance/main.go | 2 +- .../AlloyDBAdminClient/CreateUser/main.go | 2 +- .../AlloyDBAdminClient/DeleteBackup/main.go | 2 +- .../AlloyDBAdminClient/DeleteCluster/main.go | 2 +- .../AlloyDBAdminClient/DeleteInstance/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../AlloyDBAdminClient/DeleteUser/main.go | 2 +- .../AlloyDBAdminClient/ExecuteSql/main.go | 2 +- .../FailoverInstance/main.go | 2 +- .../GenerateClientCertificate/main.go | 2 +- .../AlloyDBAdminClient/GetBackup/main.go | 2 +- .../AlloyDBAdminClient/GetCluster/main.go | 2 +- .../GetConnectionInfo/main.go | 2 +- .../AlloyDBAdminClient/GetInstance/main.go | 2 +- .../AlloyDBAdminClient/GetLocation/main.go | 2 +- .../AlloyDBAdminClient/GetOperation/main.go | 2 +- .../AlloyDBAdminClient/GetUser/main.go | 2 +- .../AlloyDBAdminClient/InjectFault/main.go | 2 +- .../AlloyDBAdminClient/ListBackups/main.go | 2 +- .../AlloyDBAdminClient/ListClusters/main.go | 2 +- .../AlloyDBAdminClient/ListDatabases/main.go | 2 +- .../AlloyDBAdminClient/ListInstances/main.go | 2 +- .../AlloyDBAdminClient/ListLocations/main.go | 2 +- .../AlloyDBAdminClient/ListOperations/main.go | 2 +- .../ListSupportedDatabaseFlags/main.go | 2 +- .../AlloyDBAdminClient/ListUsers/main.go | 2 +- .../AlloyDBAdminClient/PromoteCluster/main.go | 2 +- .../RestartInstance/main.go | 2 +- .../AlloyDBAdminClient/RestoreCluster/main.go | 2 +- .../SwitchoverCluster/main.go | 2 +- .../AlloyDBAdminClient/UpdateBackup/main.go | 2 +- .../AlloyDBAdminClient/UpdateCluster/main.go | 2 +- .../AlloyDBAdminClient/UpdateInstance/main.go | 2 +- .../AlloyDBAdminClient/UpdateUser/main.go | 2 +- .../AlloyDBAdminClient/UpgradeCluster/main.go | 2 +- ..._metadata.google.cloud.alloydb.v1beta.json | 2 +- .../AcknowledgeUserDataCollection/main.go | 2 +- .../main.go | 2 +- .../ArchiveAudience/main.go | 2 +- .../ArchiveCustomDimension/main.go | 2 +- .../ArchiveCustomMetric/main.go | 2 +- .../BatchCreateAccessBindings/main.go | 2 +- .../BatchDeleteAccessBindings/main.go | 2 +- .../BatchGetAccessBindings/main.go | 2 +- .../BatchUpdateAccessBindings/main.go | 2 +- .../main.go | 2 +- .../CreateAccessBinding/main.go | 2 +- .../CreateAdSenseLink/main.go | 2 +- .../CreateAudience/main.go | 2 +- .../CreateBigQueryLink/main.go | 2 +- .../CreateCalculatedMetric/main.go | 2 +- .../CreateChannelGroup/main.go | 2 +- .../CreateConnectedSiteTag/main.go | 2 +- .../CreateConversionEvent/main.go | 2 +- .../CreateCustomDimension/main.go | 2 +- .../CreateCustomMetric/main.go | 2 +- .../CreateDataStream/main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../CreateEventCreateRule/main.go | 2 +- .../CreateEventEditRule/main.go | 2 +- .../CreateExpandedDataSet/main.go | 2 +- .../CreateFirebaseLink/main.go | 2 +- .../CreateGoogleAdsLink/main.go | 2 +- .../CreateKeyEvent/main.go | 2 +- .../CreateMeasurementProtocolSecret/main.go | 2 +- .../CreateProperty/main.go | 2 +- .../CreateRollupProperty/main.go | 2 +- .../CreateRollupPropertySourceLink/main.go | 2 +- .../main.go | 2 +- .../CreateSearchAds360Link/main.go | 2 +- .../CreateSubpropertyEventFilter/main.go | 2 +- .../DeleteAccessBinding/main.go | 2 +- .../DeleteAccount/main.go | 2 +- .../DeleteAdSenseLink/main.go | 2 +- .../DeleteBigQueryLink/main.go | 2 +- .../DeleteCalculatedMetric/main.go | 2 +- .../DeleteChannelGroup/main.go | 2 +- .../DeleteConnectedSiteTag/main.go | 2 +- .../DeleteConversionEvent/main.go | 2 +- .../DeleteDataStream/main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../DeleteEventCreateRule/main.go | 2 +- .../DeleteEventEditRule/main.go | 2 +- .../DeleteExpandedDataSet/main.go | 2 +- .../DeleteFirebaseLink/main.go | 2 +- .../DeleteGoogleAdsLink/main.go | 2 +- .../DeleteKeyEvent/main.go | 2 +- .../DeleteMeasurementProtocolSecret/main.go | 2 +- .../DeleteProperty/main.go | 2 +- .../DeleteRollupPropertySourceLink/main.go | 2 +- .../main.go | 2 +- .../DeleteSearchAds360Link/main.go | 2 +- .../DeleteSubpropertyEventFilter/main.go | 2 +- .../main.go | 2 +- .../FetchConnectedGa4Property/main.go | 2 +- .../GetAccessBinding/main.go | 2 +- .../AnalyticsAdminClient/GetAccount/main.go | 2 +- .../GetAdSenseLink/main.go | 2 +- .../GetAttributionSettings/main.go | 2 +- .../AnalyticsAdminClient/GetAudience/main.go | 2 +- .../GetBigQueryLink/main.go | 2 +- .../GetCalculatedMetric/main.go | 2 +- .../GetChannelGroup/main.go | 2 +- .../GetConversionEvent/main.go | 2 +- .../GetCustomDimension/main.go | 2 +- .../GetCustomMetric/main.go | 2 +- .../GetDataRedactionSettings/main.go | 2 +- .../GetDataRetentionSettings/main.go | 2 +- .../GetDataSharingSettings/main.go | 2 +- .../GetDataStream/main.go | 2 +- .../GetDisplayVideo360AdvertiserLink/main.go | 2 +- .../main.go | 2 +- .../GetEnhancedMeasurementSettings/main.go | 2 +- .../GetEventCreateRule/main.go | 2 +- .../GetEventEditRule/main.go | 2 +- .../GetExpandedDataSet/main.go | 2 +- .../GetGlobalSiteTag/main.go | 2 +- .../GetGoogleSignalsSettings/main.go | 2 +- .../AnalyticsAdminClient/GetKeyEvent/main.go | 2 +- .../GetMeasurementProtocolSecret/main.go | 2 +- .../AnalyticsAdminClient/GetProperty/main.go | 2 +- .../GetRollupPropertySourceLink/main.go | 2 +- .../main.go | 2 +- .../GetSearchAds360Link/main.go | 2 +- .../GetSubpropertyEventFilter/main.go | 2 +- .../ListAccessBindings/main.go | 2 +- .../ListAccountSummaries/main.go | 2 +- .../AnalyticsAdminClient/ListAccounts/main.go | 2 +- .../ListAdSenseLinks/main.go | 2 +- .../ListAudiences/main.go | 2 +- .../ListBigQueryLinks/main.go | 2 +- .../ListCalculatedMetrics/main.go | 2 +- .../ListChannelGroups/main.go | 2 +- .../ListConnectedSiteTags/main.go | 2 +- .../ListConversionEvents/main.go | 2 +- .../ListCustomDimensions/main.go | 2 +- .../ListCustomMetrics/main.go | 2 +- .../ListDataStreams/main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../ListEventCreateRules/main.go | 2 +- .../ListEventEditRules/main.go | 2 +- .../ListExpandedDataSets/main.go | 2 +- .../ListFirebaseLinks/main.go | 2 +- .../ListGoogleAdsLinks/main.go | 2 +- .../ListKeyEvents/main.go | 2 +- .../ListMeasurementProtocolSecrets/main.go | 2 +- .../ListProperties/main.go | 2 +- .../ListRollupPropertySourceLinks/main.go | 2 +- .../main.go | 2 +- .../ListSearchAds360Links/main.go | 2 +- .../ListSubpropertyEventFilters/main.go | 2 +- .../ProvisionAccountTicket/main.go | 2 +- .../ProvisionSubproperty/main.go | 2 +- .../ReorderEventEditRules/main.go | 2 +- .../RunAccessReport/main.go | 2 +- .../SearchChangeHistoryEvents/main.go | 2 +- .../main.go | 2 +- .../UpdateAccessBinding/main.go | 2 +- .../UpdateAccount/main.go | 2 +- .../UpdateAttributionSettings/main.go | 2 +- .../UpdateAudience/main.go | 2 +- .../UpdateBigQueryLink/main.go | 2 +- .../UpdateCalculatedMetric/main.go | 2 +- .../UpdateChannelGroup/main.go | 2 +- .../UpdateConversionEvent/main.go | 2 +- .../UpdateCustomDimension/main.go | 2 +- .../UpdateCustomMetric/main.go | 2 +- .../UpdateDataRedactionSettings/main.go | 2 +- .../UpdateDataRetentionSettings/main.go | 2 +- .../UpdateDataStream/main.go | 2 +- .../main.go | 2 +- .../UpdateEnhancedMeasurementSettings/main.go | 2 +- .../UpdateEventCreateRule/main.go | 2 +- .../UpdateEventEditRule/main.go | 2 +- .../UpdateExpandedDataSet/main.go | 2 +- .../UpdateGoogleAdsLink/main.go | 2 +- .../UpdateGoogleSignalsSettings/main.go | 2 +- .../UpdateKeyEvent/main.go | 2 +- .../UpdateMeasurementProtocolSecret/main.go | 2 +- .../UpdateProperty/main.go | 2 +- .../main.go | 2 +- .../UpdateSearchAds360Link/main.go | 2 +- .../UpdateSubpropertyEventFilter/main.go | 2 +- ...tadata.google.analytics.admin.v1alpha.json | 2 +- .../apigateway/apiv1/Client/CreateApi/main.go | 2 +- .../apiv1/Client/CreateApiConfig/main.go | 2 +- .../apiv1/Client/CreateGateway/main.go | 2 +- .../apigateway/apiv1/Client/DeleteApi/main.go | 2 +- .../apiv1/Client/DeleteApiConfig/main.go | 2 +- .../apiv1/Client/DeleteGateway/main.go | 2 +- .../apigateway/apiv1/Client/GetApi/main.go | 2 +- .../apiv1/Client/GetApiConfig/main.go | 2 +- .../apiv1/Client/GetGateway/main.go | 2 +- .../apiv1/Client/ListApiConfigs/main.go | 2 +- .../apigateway/apiv1/Client/ListApis/main.go | 2 +- .../apiv1/Client/ListGateways/main.go | 2 +- .../apigateway/apiv1/Client/UpdateApi/main.go | 2 +- .../apiv1/Client/UpdateApiConfig/main.go | 2 +- .../apiv1/Client/UpdateGateway/main.go | 2 +- .../ConnectionClient/ListConnections/main.go | 2 +- .../apiv1/TetherClient/Egress/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../ProvisioningClient/CreateInstance/main.go | 2 +- .../ProvisioningClient/DeleteInstance/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../ProvisioningClient/GetIamPolicy/main.go | 2 +- .../ProvisioningClient/GetInstance/main.go | 2 +- .../ProvisioningClient/GetLocation/main.go | 2 +- .../ProvisioningClient/GetOperation/main.go | 2 +- .../ProvisioningClient/ListLocations/main.go | 2 +- .../ProvisioningClient/ListOperations/main.go | 2 +- .../ProvisioningClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../RegistryClient/CancelOperation/main.go | 2 +- .../apiv1/RegistryClient/CreateApi/main.go | 2 +- .../CreateApiDeployment/main.go | 2 +- .../RegistryClient/CreateApiSpec/main.go | 2 +- .../RegistryClient/CreateApiVersion/main.go | 2 +- .../RegistryClient/CreateArtifact/main.go | 2 +- .../apiv1/RegistryClient/DeleteApi/main.go | 2 +- .../DeleteApiDeployment/main.go | 2 +- .../DeleteApiDeploymentRevision/main.go | 2 +- .../RegistryClient/DeleteApiSpec/main.go | 2 +- .../DeleteApiSpecRevision/main.go | 2 +- .../RegistryClient/DeleteApiVersion/main.go | 2 +- .../RegistryClient/DeleteArtifact/main.go | 2 +- .../RegistryClient/DeleteOperation/main.go | 2 +- .../apiv1/RegistryClient/GetApi/main.go | 2 +- .../RegistryClient/GetApiDeployment/main.go | 2 +- .../apiv1/RegistryClient/GetApiSpec/main.go | 2 +- .../RegistryClient/GetApiSpecContents/main.go | 2 +- .../RegistryClient/GetApiVersion/main.go | 2 +- .../apiv1/RegistryClient/GetArtifact/main.go | 2 +- .../GetArtifactContents/main.go | 2 +- .../apiv1/RegistryClient/GetIamPolicy/main.go | 2 +- .../apiv1/RegistryClient/GetLocation/main.go | 2 +- .../apiv1/RegistryClient/GetOperation/main.go | 2 +- .../ListApiDeploymentRevisions/main.go | 2 +- .../RegistryClient/ListApiDeployments/main.go | 2 +- .../ListApiSpecRevisions/main.go | 2 +- .../apiv1/RegistryClient/ListApiSpecs/main.go | 2 +- .../RegistryClient/ListApiVersions/main.go | 2 +- .../apiv1/RegistryClient/ListApis/main.go | 2 +- .../RegistryClient/ListArtifacts/main.go | 2 +- .../RegistryClient/ListLocations/main.go | 2 +- .../RegistryClient/ListOperations/main.go | 2 +- .../RegistryClient/ReplaceArtifact/main.go | 2 +- .../RollbackApiDeployment/main.go | 2 +- .../RegistryClient/RollbackApiSpec/main.go | 2 +- .../apiv1/RegistryClient/SetIamPolicy/main.go | 2 +- .../TagApiDeploymentRevision/main.go | 2 +- .../RegistryClient/TagApiSpecRevision/main.go | 2 +- .../RegistryClient/TestIamPermissions/main.go | 2 +- .../apiv1/RegistryClient/UpdateApi/main.go | 2 +- .../UpdateApiDeployment/main.go | 2 +- .../RegistryClient/UpdateApiSpec/main.go | 2 +- .../RegistryClient/UpdateApiVersion/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateDependency/main.go | 2 +- .../DeleteDependency/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../GetDependency/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListDependencies/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../UpdateDependency/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../ApiHubPluginClient/DisablePlugin/main.go | 2 +- .../ApiHubPluginClient/EnablePlugin/main.go | 2 +- .../ApiHubPluginClient/GetLocation/main.go | 2 +- .../ApiHubPluginClient/GetOperation/main.go | 2 +- .../ApiHubPluginClient/GetPlugin/main.go | 2 +- .../ApiHubPluginClient/ListLocations/main.go | 2 +- .../ApiHubPluginClient/ListOperations/main.go | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apihub/apiv1/Client/CreateApi/main.go | 2 +- .../apiv1/Client/CreateAttribute/main.go | 2 +- .../apiv1/Client/CreateDeployment/main.go | 2 +- .../apiv1/Client/CreateExternalApi/main.go | 2 +- .../apihub/apiv1/Client/CreateSpec/main.go | 2 +- .../apihub/apiv1/Client/CreateVersion/main.go | 2 +- .../apihub/apiv1/Client/DeleteApi/main.go | 2 +- .../apiv1/Client/DeleteAttribute/main.go | 2 +- .../apiv1/Client/DeleteDeployment/main.go | 2 +- .../apiv1/Client/DeleteExternalApi/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../apihub/apiv1/Client/DeleteSpec/main.go | 2 +- .../apihub/apiv1/Client/DeleteVersion/main.go | 2 +- .../apihub/apiv1/Client/GetApi/main.go | 2 +- .../apiv1/Client/GetApiOperation/main.go | 2 +- .../apihub/apiv1/Client/GetAttribute/main.go | 2 +- .../apihub/apiv1/Client/GetDefinition/main.go | 2 +- .../apihub/apiv1/Client/GetDeployment/main.go | 2 +- .../apiv1/Client/GetExternalApi/main.go | 2 +- .../apihub/apiv1/Client/GetLocation/main.go | 2 +- .../apihub/apiv1/Client/GetOperation/main.go | 2 +- .../apihub/apiv1/Client/GetSpec/main.go | 2 +- .../apiv1/Client/GetSpecContents/main.go | 2 +- .../apihub/apiv1/Client/GetVersion/main.go | 2 +- .../apiv1/Client/ListApiOperations/main.go | 2 +- .../apihub/apiv1/Client/ListApis/main.go | 2 +- .../apiv1/Client/ListAttributes/main.go | 2 +- .../apiv1/Client/ListDeployments/main.go | 2 +- .../apiv1/Client/ListExternalApis/main.go | 2 +- .../apihub/apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apihub/apiv1/Client/ListSpecs/main.go | 2 +- .../apihub/apiv1/Client/ListVersions/main.go | 2 +- .../apiv1/Client/SearchResources/main.go | 2 +- .../apihub/apiv1/Client/UpdateApi/main.go | 2 +- .../apiv1/Client/UpdateAttribute/main.go | 2 +- .../apiv1/Client/UpdateDeployment/main.go | 2 +- .../apiv1/Client/UpdateExternalApi/main.go | 2 +- .../apihub/apiv1/Client/UpdateSpec/main.go | 2 +- .../apihub/apiv1/Client/UpdateVersion/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateHostProjectRegistration/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../GetHostProjectRegistration/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListHostProjectRegistrations/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../LintingClient/CancelOperation/main.go | 2 +- .../LintingClient/DeleteOperation/main.go | 2 +- .../apiv1/LintingClient/GetLocation/main.go | 2 +- .../apiv1/LintingClient/GetOperation/main.go | 2 +- .../apiv1/LintingClient/GetStyleGuide/main.go | 2 +- .../GetStyleGuideContents/main.go | 2 +- .../apiv1/LintingClient/LintSpec/main.go | 2 +- .../apiv1/LintingClient/ListLocations/main.go | 2 +- .../LintingClient/ListOperations/main.go | 2 +- .../LintingClient/UpdateStyleGuide/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateApiHubInstance/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../GetApiHubInstance/main.go | 2 +- .../ProvisioningClient/GetLocation/main.go | 2 +- .../ProvisioningClient/GetOperation/main.go | 2 +- .../ProvisioningClient/ListLocations/main.go | 2 +- .../ProvisioningClient/ListOperations/main.go | 2 +- .../LookupApiHubInstance/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateRuntimeProjectAttachment/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../DeleteRuntimeProjectAttachment/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetRuntimeProjectAttachment/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListRuntimeProjectAttachments/main.go | 2 +- .../LookupRuntimeProjectAttachment/main.go | 2 +- ...ippet_metadata.google.cloud.apihub.v1.json | 2 +- .../apikeys/apiv2/Client/CreateKey/main.go | 2 +- .../apikeys/apiv2/Client/DeleteKey/main.go | 2 +- .../apikeys/apiv2/Client/GetKey/main.go | 2 +- .../apikeys/apiv2/Client/GetKeyString/main.go | 2 +- .../apikeys/apiv2/Client/GetOperation/main.go | 2 +- .../apikeys/apiv2/Client/ListKeys/main.go | 2 +- .../apikeys/apiv2/Client/LookupKey/main.go | 2 +- .../apikeys/apiv2/Client/UndeleteKey/main.go | 2 +- .../apikeys/apiv2/Client/UpdateKey/main.go | 2 +- .../CreateApplication/main.go | 2 +- .../ApplicationsClient/GetApplication/main.go | 2 +- .../RepairApplication/main.go | 2 +- .../UpdateApplication/main.go | 2 +- .../CreateAuthorizedCertificate/main.go | 2 +- .../DeleteAuthorizedCertificate/main.go | 2 +- .../GetAuthorizedCertificate/main.go | 2 +- .../ListAuthorizedCertificates/main.go | 2 +- .../UpdateAuthorizedCertificate/main.go | 2 +- .../ListAuthorizedDomains/main.go | 2 +- .../CreateDomainMapping/main.go | 2 +- .../DeleteDomainMapping/main.go | 2 +- .../GetDomainMapping/main.go | 2 +- .../ListDomainMappings/main.go | 2 +- .../UpdateDomainMapping/main.go | 2 +- .../BatchUpdateIngressRules/main.go | 2 +- .../FirewallClient/CreateIngressRule/main.go | 2 +- .../FirewallClient/DeleteIngressRule/main.go | 2 +- .../FirewallClient/GetIngressRule/main.go | 2 +- .../FirewallClient/ListIngressRules/main.go | 2 +- .../FirewallClient/UpdateIngressRule/main.go | 2 +- .../InstancesClient/DebugInstance/main.go | 2 +- .../InstancesClient/DeleteInstance/main.go | 2 +- .../apiv1/InstancesClient/GetInstance/main.go | 2 +- .../InstancesClient/ListInstances/main.go | 2 +- .../ServicesClient/DeleteService/main.go | 2 +- .../apiv1/ServicesClient/GetService/main.go | 2 +- .../apiv1/ServicesClient/ListServices/main.go | 2 +- .../ServicesClient/UpdateService/main.go | 2 +- .../VersionsClient/CreateVersion/main.go | 2 +- .../VersionsClient/DeleteVersion/main.go | 2 +- .../apiv1/VersionsClient/GetVersion/main.go | 2 +- .../apiv1/VersionsClient/ListVersions/main.go | 2 +- .../VersionsClient/UpdateVersion/main.go | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apiv1/Client/CreateApplication/main.go | 2 +- .../apphub/apiv1/Client/CreateService/main.go | 2 +- .../CreateServiceProjectAttachment/main.go | 2 +- .../apiv1/Client/CreateWorkload/main.go | 2 +- .../apiv1/Client/DeleteApplication/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../apphub/apiv1/Client/DeleteService/main.go | 2 +- .../DeleteServiceProjectAttachment/main.go | 2 +- .../apiv1/Client/DeleteWorkload/main.go | 2 +- .../DetachServiceProjectAttachment/main.go | 2 +- .../apiv1/Client/GetApplication/main.go | 2 +- .../apiv1/Client/GetDiscoveredService/main.go | 2 +- .../Client/GetDiscoveredWorkload/main.go | 2 +- .../apphub/apiv1/Client/GetIamPolicy/main.go | 2 +- .../apphub/apiv1/Client/GetLocation/main.go | 2 +- .../apphub/apiv1/Client/GetOperation/main.go | 2 +- .../apphub/apiv1/Client/GetService/main.go | 2 +- .../GetServiceProjectAttachment/main.go | 2 +- .../apphub/apiv1/Client/GetWorkload/main.go | 2 +- .../apiv1/Client/ListApplications/main.go | 2 +- .../Client/ListDiscoveredServices/main.go | 2 +- .../Client/ListDiscoveredWorkloads/main.go | 2 +- .../apphub/apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../ListServiceProjectAttachments/main.go | 2 +- .../apphub/apiv1/Client/ListServices/main.go | 2 +- .../apphub/apiv1/Client/ListWorkloads/main.go | 2 +- .../Client/LookupDiscoveredService/main.go | 2 +- .../Client/LookupDiscoveredWorkload/main.go | 2 +- .../LookupServiceProjectAttachment/main.go | 2 +- .../apphub/apiv1/Client/SetIamPolicy/main.go | 2 +- .../apiv1/Client/TestIamPermissions/main.go | 2 +- .../apiv1/Client/UpdateApplication/main.go | 2 +- .../apphub/apiv1/Client/UpdateService/main.go | 2 +- .../apiv1/Client/UpdateWorkload/main.go | 2 +- ...ippet_metadata.google.cloud.apphub.v1.json | 2 +- .../apiv1/Client/CreateSubscription/main.go | 2 +- .../apiv1/Client/DeleteSubscription/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/GetSubscription/main.go | 2 +- .../apiv1/Client/ListSubscriptions/main.go | 2 +- .../Client/ReactivateSubscription/main.go | 2 +- .../apiv1/Client/UpdateSubscription/main.go | 2 +- ...a.google.apps.events.subscriptions.v1.json | 2 +- .../GetConferenceRecord/main.go | 2 +- .../GetParticipant/main.go | 2 +- .../GetParticipantSession/main.go | 2 +- .../GetRecording/main.go | 2 +- .../GetTranscript/main.go | 2 +- .../GetTranscriptEntry/main.go | 2 +- .../ListConferenceRecords/main.go | 2 +- .../ListParticipantSessions/main.go | 2 +- .../ListParticipants/main.go | 2 +- .../ListRecordings/main.go | 2 +- .../ListTranscriptEntries/main.go | 2 +- .../ListTranscripts/main.go | 2 +- .../apiv2/SpacesClient/CreateSpace/main.go | 2 +- .../SpacesClient/EndActiveConference/main.go | 2 +- .../meet/apiv2/SpacesClient/GetSpace/main.go | 2 +- .../apiv2/SpacesClient/UpdateSpace/main.go | 2 +- .../snippet_metadata.google.apps.meet.v2.json | 2 +- .../GetConferenceRecord/main.go | 2 +- .../GetParticipant/main.go | 2 +- .../GetParticipantSession/main.go | 2 +- .../GetRecording/main.go | 2 +- .../GetTranscript/main.go | 2 +- .../GetTranscriptEntry/main.go | 2 +- .../ListConferenceRecords/main.go | 2 +- .../ListParticipantSessions/main.go | 2 +- .../ListParticipants/main.go | 2 +- .../ListRecordings/main.go | 2 +- .../ListTranscriptEntries/main.go | 2 +- .../ListTranscripts/main.go | 2 +- .../SpacesClient/CreateSpace/main.go | 2 +- .../SpacesClient/EndActiveConference/main.go | 2 +- .../apiv2beta/SpacesClient/GetSpace/main.go | 2 +- .../SpacesClient/UpdateSpace/main.go | 2 +- ...ppet_metadata.google.apps.meet.v2beta.json | 2 +- .../Client/BatchCreateRows/main.go | 2 +- .../Client/BatchDeleteRows/main.go | 2 +- .../Client/BatchUpdateRows/main.go | 2 +- .../apiv1alpha1/Client/CreateRow/main.go | 2 +- .../apiv1alpha1/Client/DeleteRow/main.go | 2 +- .../tables/apiv1alpha1/Client/GetRow/main.go | 2 +- .../apiv1alpha1/Client/GetTable/main.go | 2 +- .../apiv1alpha1/Client/GetWorkspace/main.go | 2 +- .../apiv1alpha1/Client/ListRows/main.go | 2 +- .../apiv1alpha1/Client/ListTables/main.go | 2 +- .../apiv1alpha1/Client/ListWorkspaces/main.go | 2 +- .../apiv1alpha1/Client/UpdateRow/main.go | 2 +- .../apiv1/Client/BatchDeleteVersions/main.go | 2 +- .../apiv1/Client/CreateAttachment/main.go | 2 +- .../apiv1/Client/CreateRepository/main.go | 2 +- .../apiv1/Client/CreateRule/main.go | 2 +- .../apiv1/Client/CreateTag/main.go | 2 +- .../apiv1/Client/DeleteAttachment/main.go | 2 +- .../apiv1/Client/DeleteFile/main.go | 2 +- .../apiv1/Client/DeletePackage/main.go | 2 +- .../apiv1/Client/DeleteRepository/main.go | 2 +- .../apiv1/Client/DeleteRule/main.go | 2 +- .../apiv1/Client/DeleteTag/main.go | 2 +- .../apiv1/Client/DeleteVersion/main.go | 2 +- .../apiv1/Client/GetAttachment/main.go | 2 +- .../apiv1/Client/GetDockerImage/main.go | 2 +- .../apiv1/Client/GetFile/main.go | 2 +- .../apiv1/Client/GetIamPolicy/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetMavenArtifact/main.go | 2 +- .../apiv1/Client/GetNpmPackage/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/GetPackage/main.go | 2 +- .../apiv1/Client/GetProjectSettings/main.go | 2 +- .../apiv1/Client/GetPythonPackage/main.go | 2 +- .../apiv1/Client/GetRepository/main.go | 2 +- .../apiv1/Client/GetRule/main.go | 2 +- .../apiv1/Client/GetTag/main.go | 2 +- .../apiv1/Client/GetVPCSCConfig/main.go | 2 +- .../apiv1/Client/GetVersion/main.go | 2 +- .../apiv1/Client/ImportAptArtifacts/main.go | 2 +- .../apiv1/Client/ImportYumArtifacts/main.go | 2 +- .../apiv1/Client/ListAttachments/main.go | 2 +- .../apiv1/Client/ListDockerImages/main.go | 2 +- .../apiv1/Client/ListFiles/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListMavenArtifacts/main.go | 2 +- .../apiv1/Client/ListNpmPackages/main.go | 2 +- .../apiv1/Client/ListPackages/main.go | 2 +- .../apiv1/Client/ListPythonPackages/main.go | 2 +- .../apiv1/Client/ListRepositories/main.go | 2 +- .../apiv1/Client/ListRules/main.go | 2 +- .../apiv1/Client/ListTags/main.go | 2 +- .../apiv1/Client/ListVersions/main.go | 2 +- .../apiv1/Client/SetIamPolicy/main.go | 2 +- .../apiv1/Client/TestIamPermissions/main.go | 2 +- .../apiv1/Client/UpdateFile/main.go | 2 +- .../apiv1/Client/UpdatePackage/main.go | 2 +- .../Client/UpdateProjectSettings/main.go | 2 +- .../apiv1/Client/UpdateRepository/main.go | 2 +- .../apiv1/Client/UpdateRule/main.go | 2 +- .../apiv1/Client/UpdateTag/main.go | 2 +- .../apiv1/Client/UpdateVPCSCConfig/main.go | 2 +- .../apiv1/Client/UpdateVersion/main.go | 2 +- .../Client/CreateRepository/main.go | 2 +- .../apiv1beta2/Client/CreateTag/main.go | 2 +- .../apiv1beta2/Client/DeletePackage/main.go | 2 +- .../Client/DeleteRepository/main.go | 2 +- .../apiv1beta2/Client/DeleteTag/main.go | 2 +- .../apiv1beta2/Client/DeleteVersion/main.go | 2 +- .../apiv1beta2/Client/GetFile/main.go | 2 +- .../apiv1beta2/Client/GetIamPolicy/main.go | 2 +- .../apiv1beta2/Client/GetLocation/main.go | 2 +- .../apiv1beta2/Client/GetPackage/main.go | 2 +- .../Client/GetProjectSettings/main.go | 2 +- .../apiv1beta2/Client/GetRepository/main.go | 2 +- .../apiv1beta2/Client/GetTag/main.go | 2 +- .../apiv1beta2/Client/GetVersion/main.go | 2 +- .../Client/ImportAptArtifacts/main.go | 2 +- .../Client/ImportYumArtifacts/main.go | 2 +- .../apiv1beta2/Client/ListFiles/main.go | 2 +- .../apiv1beta2/Client/ListLocations/main.go | 2 +- .../apiv1beta2/Client/ListPackages/main.go | 2 +- .../Client/ListRepositories/main.go | 2 +- .../apiv1beta2/Client/ListTags/main.go | 2 +- .../apiv1beta2/Client/ListVersions/main.go | 2 +- .../apiv1beta2/Client/SetIamPolicy/main.go | 2 +- .../Client/TestIamPermissions/main.go | 2 +- .../Client/UpdateProjectSettings/main.go | 2 +- .../Client/UpdateRepository/main.go | 2 +- .../apiv1beta2/Client/UpdateTag/main.go | 2 +- .../apiv1/Client/AnalyzeIamPolicy/main.go | 2 +- .../AnalyzeIamPolicyLongrunning/main.go | 2 +- .../asset/apiv1/Client/AnalyzeMove/main.go | 2 +- .../apiv1/Client/AnalyzeOrgPolicies/main.go | 2 +- .../AnalyzeOrgPolicyGovernedAssets/main.go | 2 +- .../main.go | 2 +- .../Client/BatchGetAssetsHistory/main.go | 2 +- .../BatchGetEffectiveIamPolicies/main.go | 2 +- .../asset/apiv1/Client/CreateFeed/main.go | 2 +- .../apiv1/Client/CreateSavedQuery/main.go | 2 +- .../asset/apiv1/Client/DeleteFeed/main.go | 2 +- .../apiv1/Client/DeleteSavedQuery/main.go | 2 +- .../asset/apiv1/Client/ExportAssets/main.go | 2 +- .../asset/apiv1/Client/GetFeed/main.go | 2 +- .../asset/apiv1/Client/GetOperation/main.go | 2 +- .../asset/apiv1/Client/GetSavedQuery/main.go | 2 +- .../asset/apiv1/Client/ListAssets/main.go | 2 +- .../asset/apiv1/Client/ListFeeds/main.go | 2 +- .../apiv1/Client/ListSavedQueries/main.go | 2 +- .../asset/apiv1/Client/QueryAssets/main.go | 2 +- .../apiv1/Client/SearchAllIamPolicies/main.go | 2 +- .../apiv1/Client/SearchAllResources/main.go | 2 +- .../asset/apiv1/Client/UpdateFeed/main.go | 2 +- .../apiv1/Client/UpdateSavedQuery/main.go | 2 +- ...nippet_metadata.google.cloud.asset.v1.json | 2 +- .../apiv1p2beta1/Client/CreateFeed/main.go | 2 +- .../apiv1p2beta1/Client/DeleteFeed/main.go | 2 +- .../asset/apiv1p2beta1/Client/GetFeed/main.go | 2 +- .../apiv1p2beta1/Client/GetOperation/main.go | 2 +- .../apiv1p2beta1/Client/ListFeeds/main.go | 2 +- .../apiv1p2beta1/Client/UpdateFeed/main.go | 2 +- ...metadata.google.cloud.asset.v1p2beta1.json | 2 +- .../apiv1p5beta1/Client/ListAssets/main.go | 2 +- ...metadata.google.cloud.asset.v1p5beta1.json | 2 +- .../apiv1/Client/AcknowledgeViolation/main.go | 2 +- .../apiv1/Client/CreateWorkload/main.go | 2 +- .../apiv1/Client/DeleteWorkload/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/GetViolation/main.go | 2 +- .../apiv1/Client/GetWorkload/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/ListViolations/main.go | 2 +- .../apiv1/Client/ListWorkloads/main.go | 2 +- .../Client/RestrictAllowedResources/main.go | 2 +- .../apiv1/Client/UpdateWorkload/main.go | 2 +- .../Client/AnalyzeWorkloadMove/main.go | 2 +- .../apiv1beta1/Client/CreateWorkload/main.go | 2 +- .../apiv1beta1/Client/DeleteWorkload/main.go | 2 +- .../apiv1beta1/Client/GetOperation/main.go | 2 +- .../apiv1beta1/Client/GetWorkload/main.go | 2 +- .../apiv1beta1/Client/ListOperations/main.go | 2 +- .../apiv1beta1/Client/ListWorkloads/main.go | 2 +- .../Client/RestrictAllowedResources/main.go | 2 +- .../apiv1beta1/Client/UpdateWorkload/main.go | 2 +- .../automl/apiv1/Client/CreateDataset/main.go | 2 +- .../automl/apiv1/Client/CreateModel/main.go | 2 +- .../automl/apiv1/Client/DeleteDataset/main.go | 2 +- .../automl/apiv1/Client/DeleteModel/main.go | 2 +- .../automl/apiv1/Client/DeployModel/main.go | 2 +- .../automl/apiv1/Client/ExportData/main.go | 2 +- .../automl/apiv1/Client/ExportModel/main.go | 2 +- .../apiv1/Client/GetAnnotationSpec/main.go | 2 +- .../automl/apiv1/Client/GetDataset/main.go | 2 +- .../automl/apiv1/Client/GetModel/main.go | 2 +- .../apiv1/Client/GetModelEvaluation/main.go | 2 +- .../automl/apiv1/Client/ImportData/main.go | 2 +- .../automl/apiv1/Client/ListDatasets/main.go | 2 +- .../apiv1/Client/ListModelEvaluations/main.go | 2 +- .../automl/apiv1/Client/ListModels/main.go | 2 +- .../automl/apiv1/Client/UndeployModel/main.go | 2 +- .../automl/apiv1/Client/UpdateDataset/main.go | 2 +- .../automl/apiv1/Client/UpdateModel/main.go | 2 +- .../PredictionClient/BatchPredict/main.go | 2 +- .../apiv1/PredictionClient/Predict/main.go | 2 +- .../apiv1beta1/Client/CreateDataset/main.go | 2 +- .../apiv1beta1/Client/CreateModel/main.go | 2 +- .../apiv1beta1/Client/DeleteDataset/main.go | 2 +- .../apiv1beta1/Client/DeleteModel/main.go | 2 +- .../apiv1beta1/Client/DeployModel/main.go | 2 +- .../apiv1beta1/Client/ExportData/main.go | 2 +- .../Client/ExportEvaluatedExamples/main.go | 2 +- .../apiv1beta1/Client/ExportModel/main.go | 2 +- .../Client/GetAnnotationSpec/main.go | 2 +- .../apiv1beta1/Client/GetColumnSpec/main.go | 2 +- .../apiv1beta1/Client/GetDataset/main.go | 2 +- .../automl/apiv1beta1/Client/GetModel/main.go | 2 +- .../Client/GetModelEvaluation/main.go | 2 +- .../apiv1beta1/Client/GetTableSpec/main.go | 2 +- .../apiv1beta1/Client/ImportData/main.go | 2 +- .../apiv1beta1/Client/ListColumnSpecs/main.go | 2 +- .../apiv1beta1/Client/ListDatasets/main.go | 2 +- .../Client/ListModelEvaluations/main.go | 2 +- .../apiv1beta1/Client/ListModels/main.go | 2 +- .../apiv1beta1/Client/ListTableSpecs/main.go | 2 +- .../apiv1beta1/Client/UndeployModel/main.go | 2 +- .../Client/UpdateColumnSpec/main.go | 2 +- .../apiv1beta1/Client/UpdateDataset/main.go | 2 +- .../apiv1beta1/Client/UpdateTableSpec/main.go | 2 +- .../PredictionClient/BatchPredict/main.go | 2 +- .../PredictionClient/Predict/main.go | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apiv1/Client/CreateBackupPlan/main.go | 2 +- .../CreateBackupPlanAssociation/main.go | 2 +- .../apiv1/Client/CreateBackupVault/main.go | 2 +- .../Client/CreateManagementServer/main.go | 2 +- .../apiv1/Client/DeleteBackup/main.go | 2 +- .../apiv1/Client/DeleteBackupPlan/main.go | 2 +- .../DeleteBackupPlanAssociation/main.go | 2 +- .../apiv1/Client/DeleteBackupVault/main.go | 2 +- .../Client/DeleteManagementServer/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../Client/FetchUsableBackupVaults/main.go | 2 +- .../backupdr/apiv1/Client/GetBackup/main.go | 2 +- .../apiv1/Client/GetBackupPlan/main.go | 2 +- .../Client/GetBackupPlanAssociation/main.go | 2 +- .../apiv1/Client/GetBackupVault/main.go | 2 +- .../apiv1/Client/GetDataSource/main.go | 2 +- .../apiv1/Client/GetIamPolicy/main.go | 2 +- .../backupdr/apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetManagementServer/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../Client/ListBackupPlanAssociations/main.go | 2 +- .../apiv1/Client/ListBackupPlans/main.go | 2 +- .../apiv1/Client/ListBackupVaults/main.go | 2 +- .../backupdr/apiv1/Client/ListBackups/main.go | 2 +- .../apiv1/Client/ListDataSources/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../Client/ListManagementServers/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/RestoreBackup/main.go | 2 +- .../apiv1/Client/SetIamPolicy/main.go | 2 +- .../apiv1/Client/TestIamPermissions/main.go | 2 +- .../apiv1/Client/TriggerBackup/main.go | 2 +- .../apiv1/Client/UpdateBackup/main.go | 2 +- .../apiv1/Client/UpdateBackupVault/main.go | 2 +- .../apiv1/Client/UpdateDataSource/main.go | 2 +- ...pet_metadata.google.cloud.backupdr.v1.json | 2 +- .../apiv2/Client/CreateNfsShare/main.go | 2 +- .../Client/CreateProvisioningConfig/main.go | 2 +- .../apiv2/Client/CreateSSHKey/main.go | 2 +- .../apiv2/Client/CreateVolumeSnapshot/main.go | 2 +- .../apiv2/Client/DeleteNfsShare/main.go | 2 +- .../apiv2/Client/DeleteSSHKey/main.go | 2 +- .../apiv2/Client/DeleteVolumeSnapshot/main.go | 2 +- .../apiv2/Client/DetachLun/main.go | 2 +- .../DisableInteractiveSerialConsole/main.go | 2 +- .../EnableInteractiveSerialConsole/main.go | 2 +- .../apiv2/Client/EvictLun/main.go | 2 +- .../apiv2/Client/EvictVolume/main.go | 2 +- .../apiv2/Client/GetInstance/main.go | 2 +- .../apiv2/Client/GetLocation/main.go | 2 +- .../apiv2/Client/GetLun/main.go | 2 +- .../apiv2/Client/GetNetwork/main.go | 2 +- .../apiv2/Client/GetNfsShare/main.go | 2 +- .../Client/GetProvisioningConfig/main.go | 2 +- .../apiv2/Client/GetVolume/main.go | 2 +- .../apiv2/Client/GetVolumeSnapshot/main.go | 2 +- .../apiv2/Client/ListInstances/main.go | 2 +- .../apiv2/Client/ListLocations/main.go | 2 +- .../apiv2/Client/ListLuns/main.go | 2 +- .../apiv2/Client/ListNetworkUsage/main.go | 2 +- .../apiv2/Client/ListNetworks/main.go | 2 +- .../apiv2/Client/ListNfsShares/main.go | 2 +- .../apiv2/Client/ListOSImages/main.go | 2 +- .../Client/ListProvisioningQuotas/main.go | 2 +- .../apiv2/Client/ListSSHKeys/main.go | 2 +- .../apiv2/Client/ListVolumeSnapshots/main.go | 2 +- .../apiv2/Client/ListVolumes/main.go | 2 +- .../apiv2/Client/RenameInstance/main.go | 2 +- .../apiv2/Client/RenameNetwork/main.go | 2 +- .../apiv2/Client/RenameNfsShare/main.go | 2 +- .../apiv2/Client/RenameVolume/main.go | 2 +- .../apiv2/Client/ResetInstance/main.go | 2 +- .../apiv2/Client/ResizeVolume/main.go | 2 +- .../Client/RestoreVolumeSnapshot/main.go | 2 +- .../apiv2/Client/StartInstance/main.go | 2 +- .../apiv2/Client/StopInstance/main.go | 2 +- .../Client/SubmitProvisioningConfig/main.go | 2 +- .../apiv2/Client/UpdateInstance/main.go | 2 +- .../apiv2/Client/UpdateNetwork/main.go | 2 +- .../apiv2/Client/UpdateNfsShare/main.go | 2 +- .../Client/UpdateProvisioningConfig/main.go | 2 +- .../apiv2/Client/UpdateVolume/main.go | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../batch/apiv1/Client/CreateJob/main.go | 2 +- .../batch/apiv1/Client/DeleteJob/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../batch/apiv1/Client/GetJob/main.go | 2 +- .../batch/apiv1/Client/GetLocation/main.go | 2 +- .../batch/apiv1/Client/GetOperation/main.go | 2 +- .../batch/apiv1/Client/GetTask/main.go | 2 +- .../batch/apiv1/Client/ListJobs/main.go | 2 +- .../batch/apiv1/Client/ListLocations/main.go | 2 +- .../batch/apiv1/Client/ListOperations/main.go | 2 +- .../batch/apiv1/Client/ListTasks/main.go | 2 +- ...nippet_metadata.google.cloud.batch.v1.json | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apiv1/Client/CreateAppConnection/main.go | 2 +- .../apiv1/Client/DeleteAppConnection/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../apiv1/Client/GetAppConnection/main.go | 2 +- .../apiv1/Client/GetIamPolicy/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/ListAppConnections/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../Client/ResolveAppConnections/main.go | 2 +- .../apiv1/Client/SetIamPolicy/main.go | 2 +- .../apiv1/Client/TestIamPermissions/main.go | 2 +- .../apiv1/Client/UpdateAppConnection/main.go | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apiv1/Client/CreateAppConnector/main.go | 2 +- .../apiv1/Client/DeleteAppConnector/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../apiv1/Client/GetAppConnector/main.go | 2 +- .../apiv1/Client/GetIamPolicy/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/ListAppConnectors/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/ReportStatus/main.go | 2 +- .../apiv1/Client/SetIamPolicy/main.go | 2 +- .../apiv1/Client/TestIamPermissions/main.go | 2 +- .../apiv1/Client/UpdateAppConnector/main.go | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apiv1/Client/CreateAppGateway/main.go | 2 +- .../apiv1/Client/DeleteAppGateway/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../apiv1/Client/GetAppGateway/main.go | 2 +- .../apiv1/Client/GetIamPolicy/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/ListAppGateways/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/SetIamPolicy/main.go | 2 +- .../apiv1/Client/TestIamPermissions/main.go | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../CreateClientConnectorService/main.go | 2 +- .../DeleteClientConnectorService/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../Client/GetClientConnectorService/main.go | 2 +- .../apiv1/Client/GetIamPolicy/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../ListClientConnectorServices/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/SetIamPolicy/main.go | 2 +- .../apiv1/Client/TestIamPermissions/main.go | 2 +- .../UpdateClientConnectorService/main.go | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apiv1/Client/CreateClientGateway/main.go | 2 +- .../apiv1/Client/DeleteClientGateway/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../apiv1/Client/GetClientGateway/main.go | 2 +- .../apiv1/Client/GetIamPolicy/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/ListClientGateways/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/SetIamPolicy/main.go | 2 +- .../apiv1/Client/TestIamPermissions/main.go | 2 +- .../apiv1/Client/CreateDataExchange/main.go | 2 +- .../apiv1/Client/CreateListing/main.go | 2 +- .../apiv1/Client/DeleteDataExchange/main.go | 2 +- .../apiv1/Client/DeleteListing/main.go | 2 +- .../apiv1/Client/DeleteSubscription/main.go | 2 +- .../apiv1/Client/GetDataExchange/main.go | 2 +- .../apiv1/Client/GetIamPolicy/main.go | 2 +- .../apiv1/Client/GetListing/main.go | 2 +- .../apiv1/Client/GetSubscription/main.go | 2 +- .../apiv1/Client/ListDataExchanges/main.go | 2 +- .../apiv1/Client/ListListings/main.go | 2 +- .../apiv1/Client/ListOrgDataExchanges/main.go | 2 +- .../ListSharedResourceSubscriptions/main.go | 2 +- .../apiv1/Client/ListSubscriptions/main.go | 2 +- .../apiv1/Client/RefreshSubscription/main.go | 2 +- .../apiv1/Client/RevokeSubscription/main.go | 2 +- .../apiv1/Client/SetIamPolicy/main.go | 2 +- .../Client/SubscribeDataExchange/main.go | 2 +- .../apiv1/Client/SubscribeListing/main.go | 2 +- .../apiv1/Client/TestIamPermissions/main.go | 2 +- .../apiv1/Client/UpdateDataExchange/main.go | 2 +- .../apiv1/Client/UpdateListing/main.go | 2 +- .../MetastoreClient/CreateCatalog/main.go | 2 +- .../MetastoreClient/CreateDatabase/main.go | 2 +- .../apiv1/MetastoreClient/CreateTable/main.go | 2 +- .../MetastoreClient/DeleteCatalog/main.go | 2 +- .../MetastoreClient/DeleteDatabase/main.go | 2 +- .../apiv1/MetastoreClient/DeleteTable/main.go | 2 +- .../apiv1/MetastoreClient/GetCatalog/main.go | 2 +- .../apiv1/MetastoreClient/GetDatabase/main.go | 2 +- .../apiv1/MetastoreClient/GetTable/main.go | 2 +- .../MetastoreClient/ListCatalogs/main.go | 2 +- .../MetastoreClient/ListDatabases/main.go | 2 +- .../apiv1/MetastoreClient/ListTables/main.go | 2 +- .../apiv1/MetastoreClient/RenameTable/main.go | 2 +- .../MetastoreClient/UpdateDatabase/main.go | 2 +- .../apiv1/MetastoreClient/UpdateTable/main.go | 2 +- .../MetastoreClient/CheckLock/main.go | 2 +- .../MetastoreClient/CreateCatalog/main.go | 2 +- .../MetastoreClient/CreateDatabase/main.go | 2 +- .../MetastoreClient/CreateLock/main.go | 2 +- .../MetastoreClient/CreateTable/main.go | 2 +- .../MetastoreClient/DeleteCatalog/main.go | 2 +- .../MetastoreClient/DeleteDatabase/main.go | 2 +- .../MetastoreClient/DeleteLock/main.go | 2 +- .../MetastoreClient/DeleteTable/main.go | 2 +- .../MetastoreClient/GetCatalog/main.go | 2 +- .../MetastoreClient/GetDatabase/main.go | 2 +- .../MetastoreClient/GetTable/main.go | 2 +- .../MetastoreClient/ListCatalogs/main.go | 2 +- .../MetastoreClient/ListDatabases/main.go | 2 +- .../MetastoreClient/ListLocks/main.go | 2 +- .../MetastoreClient/ListTables/main.go | 2 +- .../MetastoreClient/RenameTable/main.go | 2 +- .../MetastoreClient/UpdateDatabase/main.go | 2 +- .../MetastoreClient/UpdateTable/main.go | 2 +- .../apiv1/Client/CreateConnection/main.go | 2 +- .../apiv1/Client/DeleteConnection/main.go | 2 +- .../apiv1/Client/GetConnection/main.go | 2 +- .../apiv1/Client/GetIamPolicy/main.go | 2 +- .../apiv1/Client/ListConnections/main.go | 2 +- .../apiv1/Client/SetIamPolicy/main.go | 2 +- .../apiv1/Client/TestIamPermissions/main.go | 2 +- .../apiv1/Client/UpdateConnection/main.go | 2 +- .../Client/CreateConnection/main.go | 2 +- .../Client/DeleteConnection/main.go | 2 +- .../apiv1beta1/Client/GetConnection/main.go | 2 +- .../apiv1beta1/Client/GetIamPolicy/main.go | 2 +- .../apiv1beta1/Client/ListConnections/main.go | 2 +- .../apiv1beta1/Client/SetIamPolicy/main.go | 2 +- .../Client/TestIamPermissions/main.go | 2 +- .../Client/UpdateConnection/main.go | 2 +- .../Client/UpdateConnectionCredential/main.go | 2 +- .../CreateDataExchange/main.go | 2 +- .../AnalyticsHubClient/CreateListing/main.go | 2 +- .../DeleteDataExchange/main.go | 2 +- .../AnalyticsHubClient/DeleteListing/main.go | 2 +- .../GetDataExchange/main.go | 2 +- .../AnalyticsHubClient/GetIamPolicy/main.go | 2 +- .../AnalyticsHubClient/GetListing/main.go | 2 +- .../AnalyticsHubClient/GetLocation/main.go | 2 +- .../ListDataExchanges/main.go | 2 +- .../AnalyticsHubClient/ListListings/main.go | 2 +- .../AnalyticsHubClient/ListLocations/main.go | 2 +- .../ListOrgDataExchanges/main.go | 2 +- .../AnalyticsHubClient/SetIamPolicy/main.go | 2 +- .../SubscribeListing/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateDataExchange/main.go | 2 +- .../AnalyticsHubClient/UpdateListing/main.go | 2 +- .../DataPolicyClient/CreateDataPolicy/main.go | 2 +- .../DataPolicyClient/DeleteDataPolicy/main.go | 2 +- .../DataPolicyClient/GetDataPolicy/main.go | 2 +- .../DataPolicyClient/GetIamPolicy/main.go | 2 +- .../DataPolicyClient/ListDataPolicies/main.go | 2 +- .../DataPolicyClient/RenameDataPolicy/main.go | 2 +- .../DataPolicyClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../DataPolicyClient/UpdateDataPolicy/main.go | 2 +- .../DataPolicyClient/CreateDataPolicy/main.go | 2 +- .../DataPolicyClient/DeleteDataPolicy/main.go | 2 +- .../DataPolicyClient/GetDataPolicy/main.go | 2 +- .../DataPolicyClient/GetIamPolicy/main.go | 2 +- .../DataPolicyClient/ListDataPolicies/main.go | 2 +- .../DataPolicyClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../DataPolicyClient/UpdateDataPolicy/main.go | 2 +- .../apiv1/Client/CheckValidCreds/main.go | 2 +- .../apiv1/Client/CreateTransferConfig/main.go | 2 +- .../apiv1/Client/DeleteTransferConfig/main.go | 2 +- .../apiv1/Client/DeleteTransferRun/main.go | 2 +- .../apiv1/Client/EnrollDataSources/main.go | 2 +- .../apiv1/Client/GetDataSource/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetTransferConfig/main.go | 2 +- .../apiv1/Client/GetTransferRun/main.go | 2 +- .../apiv1/Client/ListDataSources/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListTransferConfigs/main.go | 2 +- .../apiv1/Client/ListTransferLogs/main.go | 2 +- .../apiv1/Client/ListTransferRuns/main.go | 2 +- .../apiv1/Client/ScheduleTransferRuns/main.go | 2 +- .../Client/StartManualTransferRuns/main.go | 2 +- .../apiv1/Client/UnenrollDataSources/main.go | 2 +- .../apiv1/Client/UpdateTransferConfig/main.go | 2 +- .../Client/CreateMigrationWorkflow/main.go | 2 +- .../Client/DeleteMigrationWorkflow/main.go | 2 +- .../apiv2/Client/GetMigrationSubtask/main.go | 2 +- .../apiv2/Client/GetMigrationWorkflow/main.go | 2 +- .../Client/ListMigrationSubtasks/main.go | 2 +- .../Client/ListMigrationWorkflows/main.go | 2 +- .../Client/StartMigrationWorkflow/main.go | 2 +- .../Client/CreateMigrationWorkflow/main.go | 2 +- .../Client/DeleteMigrationWorkflow/main.go | 2 +- .../Client/GetMigrationSubtask/main.go | 2 +- .../Client/GetMigrationWorkflow/main.go | 2 +- .../Client/ListMigrationSubtasks/main.go | 2 +- .../Client/ListMigrationWorkflows/main.go | 2 +- .../Client/StartMigrationWorkflow/main.go | 2 +- .../TranslateQuery/main.go | 2 +- .../apiv1/Client/CreateAssignment/main.go | 2 +- .../Client/CreateCapacityCommitment/main.go | 2 +- .../apiv1/Client/CreateReservation/main.go | 2 +- .../apiv1/Client/DeleteAssignment/main.go | 2 +- .../Client/DeleteCapacityCommitment/main.go | 2 +- .../apiv1/Client/DeleteReservation/main.go | 2 +- .../apiv1/Client/FailoverReservation/main.go | 2 +- .../apiv1/Client/GetBiReservation/main.go | 2 +- .../Client/GetCapacityCommitment/main.go | 2 +- .../apiv1/Client/GetReservation/main.go | 2 +- .../apiv1/Client/ListAssignments/main.go | 2 +- .../Client/ListCapacityCommitments/main.go | 2 +- .../apiv1/Client/ListReservations/main.go | 2 +- .../Client/MergeCapacityCommitments/main.go | 2 +- .../apiv1/Client/MoveAssignment/main.go | 2 +- .../apiv1/Client/SearchAllAssignments/main.go | 2 +- .../apiv1/Client/SearchAssignments/main.go | 2 +- .../Client/SplitCapacityCommitment/main.go | 2 +- .../apiv1/Client/UpdateAssignment/main.go | 2 +- .../apiv1/Client/UpdateBiReservation/main.go | 2 +- .../Client/UpdateCapacityCommitment/main.go | 2 +- .../apiv1/Client/UpdateReservation/main.go | 2 +- .../CreateReadSession/main.go | 2 +- .../SplitReadStream/main.go | 2 +- .../BigQueryWriteClient/AppendRows/main.go | 2 +- .../BatchCommitWriteStreams/main.go | 2 +- .../CreateWriteStream/main.go | 2 +- .../FinalizeWriteStream/main.go | 2 +- .../BigQueryWriteClient/FlushRows/main.go | 2 +- .../GetWriteStream/main.go | 2 +- .../BatchCreateMetastorePartitions/main.go | 2 +- .../BatchDeleteMetastorePartitions/main.go | 2 +- .../BatchUpdateMetastorePartitions/main.go | 2 +- .../ListMetastorePartitions/main.go | 2 +- .../StreamMetastorePartitions/main.go | 2 +- .../BatchCreateReadSessionStreams/main.go | 2 +- .../CreateReadSession/main.go | 2 +- .../FinalizeStream/main.go | 2 +- .../SplitReadStream/main.go | 2 +- .../CreateReadSession/main.go | 2 +- .../SplitReadStream/main.go | 2 +- .../BigQueryWriteClient/AppendRows/main.go | 2 +- .../BatchCommitWriteStreams/main.go | 2 +- .../CreateWriteStream/main.go | 2 +- .../FinalizeWriteStream/main.go | 2 +- .../BigQueryWriteClient/FlushRows/main.go | 2 +- .../GetWriteStream/main.go | 2 +- .../CreateBillingAccount/main.go | 2 +- .../GetBillingAccount/main.go | 2 +- .../CloudBillingClient/GetIamPolicy/main.go | 2 +- .../GetProjectBillingInfo/main.go | 2 +- .../ListBillingAccounts/main.go | 2 +- .../ListProjectBillingInfo/main.go | 2 +- .../MoveBillingAccount/main.go | 2 +- .../CloudBillingClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateBillingAccount/main.go | 2 +- .../UpdateProjectBillingInfo/main.go | 2 +- .../CloudCatalogClient/ListServices/main.go | 2 +- .../apiv1/CloudCatalogClient/ListSkus/main.go | 2 +- .../apiv1/BudgetClient/CreateBudget/main.go | 2 +- .../apiv1/BudgetClient/DeleteBudget/main.go | 2 +- .../apiv1/BudgetClient/GetBudget/main.go | 2 +- .../apiv1/BudgetClient/ListBudgets/main.go | 2 +- .../apiv1/BudgetClient/UpdateBudget/main.go | 2 +- .../BudgetClient/CreateBudget/main.go | 2 +- .../BudgetClient/DeleteBudget/main.go | 2 +- .../apiv1beta1/BudgetClient/GetBudget/main.go | 2 +- .../BudgetClient/ListBudgets/main.go | 2 +- .../BudgetClient/UpdateBudget/main.go | 2 +- .../CreateAttestor/main.go | 2 +- .../DeleteAttestor/main.go | 2 +- .../GetAttestor/main.go | 2 +- .../GetPolicy/main.go | 2 +- .../ListAttestors/main.go | 2 +- .../UpdateAttestor/main.go | 2 +- .../UpdatePolicy/main.go | 2 +- .../GetSystemPolicy/main.go | 2 +- .../ValidateAttestationOccurrence/main.go | 2 +- ...a.google.cloud.binaryauthorization.v1.json | 2 +- .../CreateAttestor/main.go | 2 +- .../DeleteAttestor/main.go | 2 +- .../GetAttestor/main.go | 2 +- .../GetPolicy/main.go | 2 +- .../ListAttestors/main.go | 2 +- .../UpdateAttestor/main.go | 2 +- .../UpdatePolicy/main.go | 2 +- .../GetSystemPolicy/main.go | 2 +- ...gle.cloud.binaryauthorization.v1beta1.json | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apiv1/Client/CreateCertificate/main.go | 2 +- .../CreateCertificateIssuanceConfig/main.go | 2 +- .../apiv1/Client/CreateCertificateMap/main.go | 2 +- .../Client/CreateCertificateMapEntry/main.go | 2 +- .../Client/CreateDnsAuthorization/main.go | 2 +- .../apiv1/Client/CreateTrustConfig/main.go | 2 +- .../apiv1/Client/DeleteCertificate/main.go | 2 +- .../DeleteCertificateIssuanceConfig/main.go | 2 +- .../apiv1/Client/DeleteCertificateMap/main.go | 2 +- .../Client/DeleteCertificateMapEntry/main.go | 2 +- .../Client/DeleteDnsAuthorization/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../apiv1/Client/DeleteTrustConfig/main.go | 2 +- .../apiv1/Client/GetCertificate/main.go | 2 +- .../GetCertificateIssuanceConfig/main.go | 2 +- .../apiv1/Client/GetCertificateMap/main.go | 2 +- .../Client/GetCertificateMapEntry/main.go | 2 +- .../apiv1/Client/GetDnsAuthorization/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/GetTrustConfig/main.go | 2 +- .../ListCertificateIssuanceConfigs/main.go | 2 +- .../Client/ListCertificateMapEntries/main.go | 2 +- .../apiv1/Client/ListCertificateMaps/main.go | 2 +- .../apiv1/Client/ListCertificates/main.go | 2 +- .../Client/ListDnsAuthorizations/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/ListTrustConfigs/main.go | 2 +- .../apiv1/Client/UpdateCertificate/main.go | 2 +- .../apiv1/Client/UpdateCertificateMap/main.go | 2 +- .../Client/UpdateCertificateMapEntry/main.go | 2 +- .../Client/UpdateDnsAuthorization/main.go | 2 +- .../apiv1/Client/UpdateTrustConfig/main.go | 2 +- ...ta.google.cloud.certificatemanager.v1.json | 2 +- .../ActivateEntitlement/main.go | 2 +- .../CancelEntitlement/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CloudChannelClient/ChangeOffer/main.go | 2 +- .../ChangeParameters/main.go | 2 +- .../ChangeRenewalSettings/main.go | 2 +- .../CheckCloudIdentityAccountsExist/main.go | 2 +- .../CreateChannelPartnerLink/main.go | 2 +- .../main.go | 2 +- .../CloudChannelClient/CreateCustomer/main.go | 2 +- .../CreateCustomerRepricingConfig/main.go | 2 +- .../CreateEntitlement/main.go | 2 +- .../main.go | 2 +- .../CloudChannelClient/DeleteCustomer/main.go | 2 +- .../DeleteCustomerRepricingConfig/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../GetChannelPartnerLink/main.go | 2 +- .../GetChannelPartnerRepricingConfig/main.go | 2 +- .../CloudChannelClient/GetCustomer/main.go | 2 +- .../GetCustomerRepricingConfig/main.go | 2 +- .../CloudChannelClient/GetEntitlement/main.go | 2 +- .../CloudChannelClient/GetOperation/main.go | 2 +- .../CloudChannelClient/ImportCustomer/main.go | 2 +- .../ListChannelPartnerLinks/main.go | 2 +- .../main.go | 2 +- .../ListCustomerRepricingConfigs/main.go | 2 +- .../CloudChannelClient/ListCustomers/main.go | 2 +- .../ListEntitlementChanges/main.go | 2 +- .../ListEntitlements/main.go | 2 +- .../CloudChannelClient/ListOffers/main.go | 2 +- .../CloudChannelClient/ListOperations/main.go | 2 +- .../CloudChannelClient/ListProducts/main.go | 2 +- .../ListPurchasableOffers/main.go | 2 +- .../ListPurchasableSkus/main.go | 2 +- .../ListSkuGroupBillableSkus/main.go | 2 +- .../CloudChannelClient/ListSkuGroups/main.go | 2 +- .../apiv1/CloudChannelClient/ListSkus/main.go | 2 +- .../ListSubscribers/main.go | 2 +- .../ListTransferableOffers/main.go | 2 +- .../ListTransferableSkus/main.go | 2 +- .../CloudChannelClient/LookupOffer/main.go | 2 +- .../ProvisionCloudIdentity/main.go | 2 +- .../QueryEligibleBillingAccounts/main.go | 2 +- .../RegisterSubscriber/main.go | 2 +- .../StartPaidService/main.go | 2 +- .../SuspendEntitlement/main.go | 2 +- .../TransferEntitlements/main.go | 2 +- .../TransferEntitlementsToGoogle/main.go | 2 +- .../UnregisterSubscriber/main.go | 2 +- .../UpdateChannelPartnerLink/main.go | 2 +- .../main.go | 2 +- .../CloudChannelClient/UpdateCustomer/main.go | 2 +- .../UpdateCustomerRepricingConfig/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../FetchReportResults/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListReports/main.go | 2 +- .../RunReportJob/main.go | 2 +- .../apiv1/Client/CompleteImportSpace/main.go | 2 +- .../apiv1/Client/CreateMembership/main.go | 2 +- .../chat/apiv1/Client/CreateMessage/main.go | 2 +- .../chat/apiv1/Client/CreateReaction/main.go | 2 +- .../chat/apiv1/Client/CreateSpace/main.go | 2 +- .../apiv1/Client/DeleteMembership/main.go | 2 +- .../chat/apiv1/Client/DeleteMessage/main.go | 2 +- .../chat/apiv1/Client/DeleteReaction/main.go | 2 +- .../chat/apiv1/Client/DeleteSpace/main.go | 2 +- .../apiv1/Client/FindDirectMessage/main.go | 2 +- .../chat/apiv1/Client/GetAttachment/main.go | 2 +- .../chat/apiv1/Client/GetMembership/main.go | 2 +- .../chat/apiv1/Client/GetMessage/main.go | 2 +- .../chat/apiv1/Client/GetSpace/main.go | 2 +- .../chat/apiv1/Client/GetSpaceEvent/main.go | 2 +- .../apiv1/Client/GetSpaceReadState/main.go | 2 +- .../apiv1/Client/GetThreadReadState/main.go | 2 +- .../chat/apiv1/Client/ListMemberships/main.go | 2 +- .../chat/apiv1/Client/ListMessages/main.go | 2 +- .../chat/apiv1/Client/ListReactions/main.go | 2 +- .../chat/apiv1/Client/ListSpaceEvents/main.go | 2 +- .../chat/apiv1/Client/ListSpaces/main.go | 2 +- .../chat/apiv1/Client/SearchSpaces/main.go | 2 +- .../chat/apiv1/Client/SetUpSpace/main.go | 2 +- .../apiv1/Client/UpdateMembership/main.go | 2 +- .../chat/apiv1/Client/UpdateMessage/main.go | 2 +- .../chat/apiv1/Client/UpdateSpace/main.go | 2 +- .../apiv1/Client/UpdateSpaceReadState/main.go | 2 +- .../apiv1/Client/UploadAttachment/main.go | 2 +- .../snippet_metadata.google.chat.v1.json | 2 +- .../apiv1/v2/Client/ApproveBuild/main.go | 2 +- .../apiv1/v2/Client/CancelBuild/main.go | 2 +- .../apiv1/v2/Client/CreateBuild/main.go | 2 +- .../v2/Client/CreateBuildTrigger/main.go | 2 +- .../apiv1/v2/Client/CreateWorkerPool/main.go | 2 +- .../v2/Client/DeleteBuildTrigger/main.go | 2 +- .../apiv1/v2/Client/DeleteWorkerPool/main.go | 2 +- .../apiv1/v2/Client/GetBuild/main.go | 2 +- .../apiv1/v2/Client/GetBuildTrigger/main.go | 2 +- .../apiv1/v2/Client/GetWorkerPool/main.go | 2 +- .../apiv1/v2/Client/ListBuildTriggers/main.go | 2 +- .../apiv1/v2/Client/ListBuilds/main.go | 2 +- .../apiv1/v2/Client/ListWorkerPools/main.go | 2 +- .../v2/Client/ReceiveTriggerWebhook/main.go | 2 +- .../apiv1/v2/Client/RetryBuild/main.go | 2 +- .../apiv1/v2/Client/RunBuildTrigger/main.go | 2 +- .../v2/Client/UpdateBuildTrigger/main.go | 2 +- .../apiv1/v2/Client/UpdateWorkerPool/main.go | 2 +- ...etadata.google.devtools.cloudbuild.v1.json | 2 +- .../BatchCreateRepositories/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateConnection/main.go | 2 +- .../CreateRepository/main.go | 2 +- .../DeleteConnection/main.go | 2 +- .../DeleteRepository/main.go | 2 +- .../FetchGitRefs/main.go | 2 +- .../FetchLinkableRepositories/main.go | 2 +- .../FetchReadToken/main.go | 2 +- .../FetchReadWriteToken/main.go | 2 +- .../GetConnection/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetRepository/main.go | 2 +- .../ListConnections/main.go | 2 +- .../ListRepositories/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateConnection/main.go | 2 +- ...etadata.google.devtools.cloudbuild.v2.json | 2 +- .../GetCustomer/main.go | 2 +- .../GetEkmConnections/main.go | 2 +- .../GetPartner/main.go | 2 +- .../GetPartnerPermissions/main.go | 2 +- .../GetWorkload/main.go | 2 +- .../ListAccessApprovalRequests/main.go | 2 +- .../ListCustomers/main.go | 2 +- .../ListWorkloads/main.go | 2 +- .../GetViolation/main.go | 2 +- .../ListViolations/main.go | 2 +- ....google.cloud.cloudcontrolspartner.v1.json | 2 +- .../GetCustomer/main.go | 2 +- .../GetEkmConnections/main.go | 2 +- .../GetPartner/main.go | 2 +- .../GetPartnerPermissions/main.go | 2 +- .../GetWorkload/main.go | 2 +- .../ListAccessApprovalRequests/main.go | 2 +- .../ListCustomers/main.go | 2 +- .../ListWorkloads/main.go | 2 +- .../GetViolation/main.go | 2 +- .../ListViolations/main.go | 2 +- ...gle.cloud.cloudcontrolspartner.v1beta.json | 2 +- .../ApplyConversionWorkspace/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CommitConversionWorkspace/main.go | 2 +- .../ConvertConversionWorkspace/main.go | 2 +- .../CreateConnectionProfile/main.go | 2 +- .../CreateConversionWorkspace/main.go | 2 +- .../CreateMappingRule/main.go | 2 +- .../CreateMigrationJob/main.go | 2 +- .../CreatePrivateConnection/main.go | 2 +- .../DeleteConnectionProfile/main.go | 2 +- .../DeleteConversionWorkspace/main.go | 2 +- .../DeleteMappingRule/main.go | 2 +- .../DeleteMigrationJob/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../DeletePrivateConnection/main.go | 2 +- .../main.go | 2 +- .../DescribeDatabaseEntities/main.go | 2 +- .../FetchStaticIps/main.go | 2 +- .../GenerateSshScript/main.go | 2 +- .../GenerateTcpProxyScript/main.go | 2 +- .../GetConnectionProfile/main.go | 2 +- .../GetConversionWorkspace/main.go | 2 +- .../DataMigrationClient/GetIamPolicy/main.go | 2 +- .../DataMigrationClient/GetLocation/main.go | 2 +- .../GetMappingRule/main.go | 2 +- .../GetMigrationJob/main.go | 2 +- .../DataMigrationClient/GetOperation/main.go | 2 +- .../GetPrivateConnection/main.go | 2 +- .../ImportMappingRules/main.go | 2 +- .../ListConnectionProfiles/main.go | 2 +- .../ListConversionWorkspaces/main.go | 2 +- .../DataMigrationClient/ListLocations/main.go | 2 +- .../ListMappingRules/main.go | 2 +- .../ListMigrationJobs/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListPrivateConnections/main.go | 2 +- .../PromoteMigrationJob/main.go | 2 +- .../RestartMigrationJob/main.go | 2 +- .../ResumeMigrationJob/main.go | 2 +- .../RollbackConversionWorkspace/main.go | 2 +- .../SearchBackgroundJobs/main.go | 2 +- .../SeedConversionWorkspace/main.go | 2 +- .../DataMigrationClient/SetIamPolicy/main.go | 2 +- .../StartMigrationJob/main.go | 2 +- .../StopMigrationJob/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateConnectionProfile/main.go | 2 +- .../UpdateConversionWorkspace/main.go | 2 +- .../UpdateMigrationJob/main.go | 2 +- .../VerifyMigrationJob/main.go | 2 +- .../apiv2/ExportClient/ListProfiles/main.go | 2 +- .../CreateOfflineProfile/main.go | 2 +- .../ProfilerClient/CreateProfile/main.go | 2 +- .../ProfilerClient/UpdateProfile/main.go | 2 +- ...data.google.devtools.cloudprofiler.v2.json | 2 +- .../Client/CreateQuotaPreference/main.go | 2 +- .../apiv1/Client/GetQuotaInfo/main.go | 2 +- .../apiv1/Client/GetQuotaPreference/main.go | 2 +- .../apiv1/Client/ListQuotaInfos/main.go | 2 +- .../apiv1/Client/ListQuotaPreferences/main.go | 2 +- .../Client/UpdateQuotaPreference/main.go | 2 +- ...et_metadata.google.api.cloudquotas.v1.json | 2 +- .../apiv2/Client/CreateQueue/main.go | 2 +- .../apiv2/Client/CreateTask/main.go | 2 +- .../apiv2/Client/DeleteQueue/main.go | 2 +- .../apiv2/Client/DeleteTask/main.go | 2 +- .../apiv2/Client/GetIamPolicy/main.go | 2 +- .../apiv2/Client/GetLocation/main.go | 2 +- .../cloudtasks/apiv2/Client/GetQueue/main.go | 2 +- .../cloudtasks/apiv2/Client/GetTask/main.go | 2 +- .../apiv2/Client/ListLocations/main.go | 2 +- .../apiv2/Client/ListQueues/main.go | 2 +- .../cloudtasks/apiv2/Client/ListTasks/main.go | 2 +- .../apiv2/Client/PauseQueue/main.go | 2 +- .../apiv2/Client/PurgeQueue/main.go | 2 +- .../apiv2/Client/ResumeQueue/main.go | 2 +- .../cloudtasks/apiv2/Client/RunTask/main.go | 2 +- .../apiv2/Client/SetIamPolicy/main.go | 2 +- .../apiv2/Client/TestIamPermissions/main.go | 2 +- .../apiv2/Client/UpdateQueue/main.go | 2 +- .../apiv2beta2/Client/AcknowledgeTask/main.go | 2 +- .../apiv2beta2/Client/CancelLease/main.go | 2 +- .../apiv2beta2/Client/CreateQueue/main.go | 2 +- .../apiv2beta2/Client/CreateTask/main.go | 2 +- .../apiv2beta2/Client/DeleteQueue/main.go | 2 +- .../apiv2beta2/Client/DeleteTask/main.go | 2 +- .../apiv2beta2/Client/GetIamPolicy/main.go | 2 +- .../apiv2beta2/Client/GetLocation/main.go | 2 +- .../apiv2beta2/Client/GetQueue/main.go | 2 +- .../apiv2beta2/Client/GetTask/main.go | 2 +- .../apiv2beta2/Client/LeaseTasks/main.go | 2 +- .../apiv2beta2/Client/ListLocations/main.go | 2 +- .../apiv2beta2/Client/ListQueues/main.go | 2 +- .../apiv2beta2/Client/ListTasks/main.go | 2 +- .../apiv2beta2/Client/PauseQueue/main.go | 2 +- .../apiv2beta2/Client/PurgeQueue/main.go | 2 +- .../apiv2beta2/Client/RenewLease/main.go | 2 +- .../apiv2beta2/Client/ResumeQueue/main.go | 2 +- .../apiv2beta2/Client/RunTask/main.go | 2 +- .../apiv2beta2/Client/SetIamPolicy/main.go | 2 +- .../Client/TestIamPermissions/main.go | 2 +- .../apiv2beta2/Client/UpdateQueue/main.go | 2 +- .../apiv2beta2/Client/UploadQueueYaml/main.go | 2 +- .../apiv2beta3/Client/CreateQueue/main.go | 2 +- .../apiv2beta3/Client/CreateTask/main.go | 2 +- .../apiv2beta3/Client/DeleteQueue/main.go | 2 +- .../apiv2beta3/Client/DeleteTask/main.go | 2 +- .../apiv2beta3/Client/GetIamPolicy/main.go | 2 +- .../apiv2beta3/Client/GetLocation/main.go | 2 +- .../apiv2beta3/Client/GetQueue/main.go | 2 +- .../apiv2beta3/Client/GetTask/main.go | 2 +- .../apiv2beta3/Client/ListLocations/main.go | 2 +- .../apiv2beta3/Client/ListQueues/main.go | 2 +- .../apiv2beta3/Client/ListTasks/main.go | 2 +- .../apiv2beta3/Client/PauseQueue/main.go | 2 +- .../apiv2beta3/Client/PurgeQueue/main.go | 2 +- .../apiv2beta3/Client/ResumeQueue/main.go | 2 +- .../apiv2beta3/Client/RunTask/main.go | 2 +- .../apiv2beta3/Client/SetIamPolicy/main.go | 2 +- .../Client/TestIamPermissions/main.go | 2 +- .../apiv2beta3/Client/UpdateQueue/main.go | 2 +- .../CancelOrder/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetOrder/main.go | 2 +- .../ListOrders/main.go | 2 +- .../ModifyOrder/main.go | 2 +- .../PlaceOrder/main.go | 2 +- .../LicenseManagementClient/Assign/main.go | 2 +- .../EnumerateLicensedUsers/main.go | 2 +- .../GetLicensePool/main.go | 2 +- .../GetOperation/main.go | 2 +- .../LicenseManagementClient/Unassign/main.go | 2 +- .../UpdateLicensePool/main.go | 2 +- ...loud.commerce.consumer.procurement.v1.json | 2 +- .../AggregatedList/main.go | 2 +- .../apiv1/AcceleratorTypesClient/Get/main.go | 2 +- .../apiv1/AcceleratorTypesClient/List/main.go | 2 +- .../AddressesClient/AggregatedList/main.go | 2 +- .../apiv1/AddressesClient/Delete/main.go | 2 +- .../compute/apiv1/AddressesClient/Get/main.go | 2 +- .../apiv1/AddressesClient/Insert/main.go | 2 +- .../apiv1/AddressesClient/List/main.go | 2 +- .../apiv1/AddressesClient/Move/main.go | 2 +- .../apiv1/AddressesClient/SetLabels/main.go | 2 +- .../AutoscalersClient/AggregatedList/main.go | 2 +- .../apiv1/AutoscalersClient/Delete/main.go | 2 +- .../apiv1/AutoscalersClient/Get/main.go | 2 +- .../apiv1/AutoscalersClient/Insert/main.go | 2 +- .../apiv1/AutoscalersClient/List/main.go | 2 +- .../apiv1/AutoscalersClient/Patch/main.go | 2 +- .../apiv1/AutoscalersClient/Update/main.go | 2 +- .../AddSignedUrlKey/main.go | 2 +- .../apiv1/BackendBucketsClient/Delete/main.go | 2 +- .../DeleteSignedUrlKey/main.go | 2 +- .../apiv1/BackendBucketsClient/Get/main.go | 2 +- .../BackendBucketsClient/GetIamPolicy/main.go | 2 +- .../apiv1/BackendBucketsClient/Insert/main.go | 2 +- .../apiv1/BackendBucketsClient/List/main.go | 2 +- .../apiv1/BackendBucketsClient/Patch/main.go | 2 +- .../SetEdgeSecurityPolicy/main.go | 2 +- .../BackendBucketsClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../apiv1/BackendBucketsClient/Update/main.go | 2 +- .../AddSignedUrlKey/main.go | 2 +- .../AggregatedList/main.go | 2 +- .../BackendServicesClient/Delete/main.go | 2 +- .../DeleteSignedUrlKey/main.go | 2 +- .../apiv1/BackendServicesClient/Get/main.go | 2 +- .../BackendServicesClient/GetHealth/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../BackendServicesClient/Insert/main.go | 2 +- .../apiv1/BackendServicesClient/List/main.go | 2 +- .../BackendServicesClient/ListUsable/main.go | 2 +- .../apiv1/BackendServicesClient/Patch/main.go | 2 +- .../SetEdgeSecurityPolicy/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../SetSecurityPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../BackendServicesClient/Update/main.go | 2 +- .../DiskTypesClient/AggregatedList/main.go | 2 +- .../compute/apiv1/DiskTypesClient/Get/main.go | 2 +- .../apiv1/DiskTypesClient/List/main.go | 2 +- .../DisksClient/AddResourcePolicies/main.go | 2 +- .../apiv1/DisksClient/AggregatedList/main.go | 2 +- .../apiv1/DisksClient/BulkInsert/main.go | 2 +- .../apiv1/DisksClient/CreateSnapshot/main.go | 2 +- .../compute/apiv1/DisksClient/Delete/main.go | 2 +- .../compute/apiv1/DisksClient/Get/main.go | 2 +- .../apiv1/DisksClient/GetIamPolicy/main.go | 2 +- .../compute/apiv1/DisksClient/Insert/main.go | 2 +- .../compute/apiv1/DisksClient/List/main.go | 2 +- .../RemoveResourcePolicies/main.go | 2 +- .../compute/apiv1/DisksClient/Resize/main.go | 2 +- .../apiv1/DisksClient/SetIamPolicy/main.go | 2 +- .../apiv1/DisksClient/SetLabels/main.go | 2 +- .../DisksClient/StartAsyncReplication/main.go | 2 +- .../DisksClient/StopAsyncReplication/main.go | 2 +- .../StopGroupAsyncReplication/main.go | 2 +- .../DisksClient/TestIamPermissions/main.go | 2 +- .../compute/apiv1/DisksClient/Update/main.go | 2 +- .../ExternalVpnGatewaysClient/Delete/main.go | 2 +- .../ExternalVpnGatewaysClient/Get/main.go | 2 +- .../ExternalVpnGatewaysClient/Insert/main.go | 2 +- .../ExternalVpnGatewaysClient/List/main.go | 2 +- .../SetLabels/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../AddAssociation/main.go | 2 +- .../FirewallPoliciesClient/AddRule/main.go | 2 +- .../FirewallPoliciesClient/CloneRules/main.go | 2 +- .../FirewallPoliciesClient/Delete/main.go | 2 +- .../apiv1/FirewallPoliciesClient/Get/main.go | 2 +- .../GetAssociation/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../FirewallPoliciesClient/GetRule/main.go | 2 +- .../FirewallPoliciesClient/Insert/main.go | 2 +- .../apiv1/FirewallPoliciesClient/List/main.go | 2 +- .../ListAssociations/main.go | 2 +- .../apiv1/FirewallPoliciesClient/Move/main.go | 2 +- .../FirewallPoliciesClient/Patch/main.go | 2 +- .../FirewallPoliciesClient/PatchRule/main.go | 2 +- .../RemoveAssociation/main.go | 2 +- .../FirewallPoliciesClient/RemoveRule/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../apiv1/FirewallsClient/Delete/main.go | 2 +- .../compute/apiv1/FirewallsClient/Get/main.go | 2 +- .../apiv1/FirewallsClient/Insert/main.go | 2 +- .../apiv1/FirewallsClient/List/main.go | 2 +- .../apiv1/FirewallsClient/Patch/main.go | 2 +- .../apiv1/FirewallsClient/Update/main.go | 2 +- .../AggregatedList/main.go | 2 +- .../ForwardingRulesClient/Delete/main.go | 2 +- .../apiv1/ForwardingRulesClient/Get/main.go | 2 +- .../ForwardingRulesClient/Insert/main.go | 2 +- .../apiv1/ForwardingRulesClient/List/main.go | 2 +- .../apiv1/ForwardingRulesClient/Patch/main.go | 2 +- .../ForwardingRulesClient/SetLabels/main.go | 2 +- .../ForwardingRulesClient/SetTarget/main.go | 2 +- .../GlobalAddressesClient/Delete/main.go | 2 +- .../apiv1/GlobalAddressesClient/Get/main.go | 2 +- .../GlobalAddressesClient/Insert/main.go | 2 +- .../apiv1/GlobalAddressesClient/List/main.go | 2 +- .../apiv1/GlobalAddressesClient/Move/main.go | 2 +- .../GlobalAddressesClient/SetLabels/main.go | 2 +- .../Delete/main.go | 2 +- .../GlobalForwardingRulesClient/Get/main.go | 2 +- .../Insert/main.go | 2 +- .../GlobalForwardingRulesClient/List/main.go | 2 +- .../GlobalForwardingRulesClient/Patch/main.go | 2 +- .../SetLabels/main.go | 2 +- .../SetTarget/main.go | 2 +- .../AttachNetworkEndpoints/main.go | 2 +- .../Delete/main.go | 2 +- .../DetachNetworkEndpoints/main.go | 2 +- .../Get/main.go | 2 +- .../Insert/main.go | 2 +- .../List/main.go | 2 +- .../ListNetworkEndpoints/main.go | 2 +- .../AggregatedList/main.go | 2 +- .../GlobalOperationsClient/Delete/main.go | 2 +- .../apiv1/GlobalOperationsClient/Get/main.go | 2 +- .../apiv1/GlobalOperationsClient/List/main.go | 2 +- .../apiv1/GlobalOperationsClient/Wait/main.go | 2 +- .../Delete/main.go | 2 +- .../Get/main.go | 2 +- .../List/main.go | 2 +- .../Delete/main.go | 2 +- .../Get/main.go | 2 +- .../Insert/main.go | 2 +- .../List/main.go | 2 +- .../Patch/main.go | 2 +- .../HealthChecksClient/AggregatedList/main.go | 2 +- .../apiv1/HealthChecksClient/Delete/main.go | 2 +- .../apiv1/HealthChecksClient/Get/main.go | 2 +- .../apiv1/HealthChecksClient/Insert/main.go | 2 +- .../apiv1/HealthChecksClient/List/main.go | 2 +- .../apiv1/HealthChecksClient/Patch/main.go | 2 +- .../apiv1/HealthChecksClient/Update/main.go | 2 +- .../apiv1/ImageFamilyViewsClient/Get/main.go | 2 +- .../compute/apiv1/ImagesClient/Delete/main.go | 2 +- .../apiv1/ImagesClient/Deprecate/main.go | 2 +- .../compute/apiv1/ImagesClient/Get/main.go | 2 +- .../apiv1/ImagesClient/GetFromFamily/main.go | 2 +- .../apiv1/ImagesClient/GetIamPolicy/main.go | 2 +- .../compute/apiv1/ImagesClient/Insert/main.go | 2 +- .../compute/apiv1/ImagesClient/List/main.go | 2 +- .../compute/apiv1/ImagesClient/Patch/main.go | 2 +- .../apiv1/ImagesClient/SetIamPolicy/main.go | 2 +- .../apiv1/ImagesClient/SetLabels/main.go | 2 +- .../ImagesClient/TestIamPermissions/main.go | 2 +- .../Cancel/main.go | 2 +- .../Delete/main.go | 2 +- .../Get/main.go | 2 +- .../Insert/main.go | 2 +- .../List/main.go | 2 +- .../AbandonInstances/main.go | 2 +- .../AggregatedList/main.go | 2 +- .../ApplyUpdatesToInstances/main.go | 2 +- .../CreateInstances/main.go | 2 +- .../Delete/main.go | 2 +- .../DeleteInstances/main.go | 2 +- .../DeletePerInstanceConfigs/main.go | 2 +- .../InstanceGroupManagersClient/Get/main.go | 2 +- .../Insert/main.go | 2 +- .../InstanceGroupManagersClient/List/main.go | 2 +- .../ListErrors/main.go | 2 +- .../ListManagedInstances/main.go | 2 +- .../ListPerInstanceConfigs/main.go | 2 +- .../InstanceGroupManagersClient/Patch/main.go | 2 +- .../PatchPerInstanceConfigs/main.go | 2 +- .../RecreateInstances/main.go | 2 +- .../Resize/main.go | 2 +- .../ResumeInstances/main.go | 2 +- .../SetInstanceTemplate/main.go | 2 +- .../SetTargetPools/main.go | 2 +- .../StartInstances/main.go | 2 +- .../StopInstances/main.go | 2 +- .../SuspendInstances/main.go | 2 +- .../UpdatePerInstanceConfigs/main.go | 2 +- .../InstanceGroupsClient/AddInstances/main.go | 2 +- .../AggregatedList/main.go | 2 +- .../apiv1/InstanceGroupsClient/Delete/main.go | 2 +- .../apiv1/InstanceGroupsClient/Get/main.go | 2 +- .../apiv1/InstanceGroupsClient/Insert/main.go | 2 +- .../apiv1/InstanceGroupsClient/List/main.go | 2 +- .../ListInstances/main.go | 2 +- .../RemoveInstances/main.go | 2 +- .../SetNamedPorts/main.go | 2 +- .../apiv1/InstanceSettingsClient/Get/main.go | 2 +- .../InstanceSettingsClient/Patch/main.go | 2 +- .../AggregatedList/main.go | 2 +- .../InstanceTemplatesClient/Delete/main.go | 2 +- .../apiv1/InstanceTemplatesClient/Get/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../InstanceTemplatesClient/Insert/main.go | 2 +- .../InstanceTemplatesClient/List/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../InstancesClient/AddAccessConfig/main.go | 2 +- .../AddResourcePolicies/main.go | 2 +- .../InstancesClient/AggregatedList/main.go | 2 +- .../apiv1/InstancesClient/AttachDisk/main.go | 2 +- .../apiv1/InstancesClient/BulkInsert/main.go | 2 +- .../apiv1/InstancesClient/Delete/main.go | 2 +- .../DeleteAccessConfig/main.go | 2 +- .../apiv1/InstancesClient/DetachDisk/main.go | 2 +- .../compute/apiv1/InstancesClient/Get/main.go | 2 +- .../GetEffectiveFirewalls/main.go | 2 +- .../GetGuestAttributes/main.go | 2 +- .../InstancesClient/GetIamPolicy/main.go | 2 +- .../InstancesClient/GetScreenshot/main.go | 2 +- .../GetSerialPortOutput/main.go | 2 +- .../GetShieldedInstanceIdentity/main.go | 2 +- .../apiv1/InstancesClient/Insert/main.go | 2 +- .../apiv1/InstancesClient/List/main.go | 2 +- .../InstancesClient/ListReferrers/main.go | 2 +- .../PerformMaintenance/main.go | 2 +- .../RemoveResourcePolicies/main.go | 2 +- .../apiv1/InstancesClient/Reset/main.go | 2 +- .../apiv1/InstancesClient/Resume/main.go | 2 +- .../SendDiagnosticInterrupt/main.go | 2 +- .../SetDeletionProtection/main.go | 2 +- .../InstancesClient/SetDiskAutoDelete/main.go | 2 +- .../InstancesClient/SetIamPolicy/main.go | 2 +- .../apiv1/InstancesClient/SetLabels/main.go | 2 +- .../SetMachineResources/main.go | 2 +- .../InstancesClient/SetMachineType/main.go | 2 +- .../apiv1/InstancesClient/SetMetadata/main.go | 2 +- .../InstancesClient/SetMinCpuPlatform/main.go | 2 +- .../apiv1/InstancesClient/SetName/main.go | 2 +- .../InstancesClient/SetScheduling/main.go | 2 +- .../InstancesClient/SetSecurityPolicy/main.go | 2 +- .../InstancesClient/SetServiceAccount/main.go | 2 +- .../main.go | 2 +- .../apiv1/InstancesClient/SetTags/main.go | 2 +- .../SimulateMaintenanceEvent/main.go | 2 +- .../apiv1/InstancesClient/Start/main.go | 2 +- .../StartWithEncryptionKey/main.go | 2 +- .../apiv1/InstancesClient/Stop/main.go | 2 +- .../apiv1/InstancesClient/Suspend/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../apiv1/InstancesClient/Update/main.go | 2 +- .../UpdateAccessConfig/main.go | 2 +- .../UpdateDisplayDevice/main.go | 2 +- .../UpdateNetworkInterface/main.go | 2 +- .../UpdateShieldedInstanceConfig/main.go | 2 +- .../AggregatedList/main.go | 2 +- .../InstantSnapshotsClient/Delete/main.go | 2 +- .../apiv1/InstantSnapshotsClient/Get/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../InstantSnapshotsClient/Insert/main.go | 2 +- .../apiv1/InstantSnapshotsClient/List/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../InstantSnapshotsClient/SetLabels/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../AggregatedList/main.go | 2 +- .../Delete/main.go | 2 +- .../InterconnectAttachmentsClient/Get/main.go | 2 +- .../Insert/main.go | 2 +- .../List/main.go | 2 +- .../Patch/main.go | 2 +- .../SetLabels/main.go | 2 +- .../InterconnectLocationsClient/Get/main.go | 2 +- .../InterconnectLocationsClient/List/main.go | 2 +- .../Get/main.go | 2 +- .../List/main.go | 2 +- .../apiv1/InterconnectsClient/Delete/main.go | 2 +- .../apiv1/InterconnectsClient/Get/main.go | 2 +- .../GetDiagnostics/main.go | 2 +- .../GetMacsecConfig/main.go | 2 +- .../apiv1/InterconnectsClient/Insert/main.go | 2 +- .../apiv1/InterconnectsClient/List/main.go | 2 +- .../apiv1/InterconnectsClient/Patch/main.go | 2 +- .../InterconnectsClient/SetLabels/main.go | 2 +- .../apiv1/LicenseCodesClient/Get/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../apiv1/LicensesClient/Delete/main.go | 2 +- .../compute/apiv1/LicensesClient/Get/main.go | 2 +- .../apiv1/LicensesClient/GetIamPolicy/main.go | 2 +- .../apiv1/LicensesClient/Insert/main.go | 2 +- .../compute/apiv1/LicensesClient/List/main.go | 2 +- .../apiv1/LicensesClient/SetIamPolicy/main.go | 2 +- .../LicensesClient/TestIamPermissions/main.go | 2 +- .../apiv1/MachineImagesClient/Delete/main.go | 2 +- .../apiv1/MachineImagesClient/Get/main.go | 2 +- .../MachineImagesClient/GetIamPolicy/main.go | 2 +- .../apiv1/MachineImagesClient/Insert/main.go | 2 +- .../apiv1/MachineImagesClient/List/main.go | 2 +- .../MachineImagesClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../MachineTypesClient/AggregatedList/main.go | 2 +- .../apiv1/MachineTypesClient/Get/main.go | 2 +- .../apiv1/MachineTypesClient/List/main.go | 2 +- .../AggregatedList/main.go | 2 +- .../NetworkAttachmentsClient/Delete/main.go | 2 +- .../NetworkAttachmentsClient/Get/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../NetworkAttachmentsClient/Insert/main.go | 2 +- .../NetworkAttachmentsClient/List/main.go | 2 +- .../NetworkAttachmentsClient/Patch/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../AggregatedList/main.go | 2 +- .../Delete/main.go | 2 +- .../Get/main.go | 2 +- .../Insert/main.go | 2 +- .../Patch/main.go | 2 +- .../AggregatedList/main.go | 2 +- .../AttachNetworkEndpoints/main.go | 2 +- .../Delete/main.go | 2 +- .../DetachNetworkEndpoints/main.go | 2 +- .../NetworkEndpointGroupsClient/Get/main.go | 2 +- .../Insert/main.go | 2 +- .../NetworkEndpointGroupsClient/List/main.go | 2 +- .../ListNetworkEndpoints/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../AddAssociation/main.go | 2 +- .../AddRule/main.go | 2 +- .../CloneRules/main.go | 2 +- .../Delete/main.go | 2 +- .../NetworkFirewallPoliciesClient/Get/main.go | 2 +- .../GetAssociation/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetRule/main.go | 2 +- .../Insert/main.go | 2 +- .../List/main.go | 2 +- .../Patch/main.go | 2 +- .../PatchRule/main.go | 2 +- .../RemoveAssociation/main.go | 2 +- .../RemoveRule/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../apiv1/NetworkProfilesClient/Get/main.go | 2 +- .../apiv1/NetworkProfilesClient/List/main.go | 2 +- .../apiv1/NetworksClient/AddPeering/main.go | 2 +- .../apiv1/NetworksClient/Delete/main.go | 2 +- .../compute/apiv1/NetworksClient/Get/main.go | 2 +- .../GetEffectiveFirewalls/main.go | 2 +- .../apiv1/NetworksClient/Insert/main.go | 2 +- .../compute/apiv1/NetworksClient/List/main.go | 2 +- .../NetworksClient/ListPeeringRoutes/main.go | 2 +- .../apiv1/NetworksClient/Patch/main.go | 2 +- .../NetworksClient/RemovePeering/main.go | 2 +- .../NetworksClient/SwitchToCustomMode/main.go | 2 +- .../NetworksClient/UpdatePeering/main.go | 2 +- .../apiv1/NodeGroupsClient/AddNodes/main.go | 2 +- .../NodeGroupsClient/AggregatedList/main.go | 2 +- .../apiv1/NodeGroupsClient/Delete/main.go | 2 +- .../NodeGroupsClient/DeleteNodes/main.go | 2 +- .../apiv1/NodeGroupsClient/Get/main.go | 2 +- .../NodeGroupsClient/GetIamPolicy/main.go | 2 +- .../apiv1/NodeGroupsClient/Insert/main.go | 2 +- .../apiv1/NodeGroupsClient/List/main.go | 2 +- .../apiv1/NodeGroupsClient/ListNodes/main.go | 2 +- .../apiv1/NodeGroupsClient/Patch/main.go | 2 +- .../PerformMaintenance/main.go | 2 +- .../NodeGroupsClient/SetIamPolicy/main.go | 2 +- .../NodeGroupsClient/SetNodeTemplate/main.go | 2 +- .../SimulateMaintenanceEvent/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../AggregatedList/main.go | 2 +- .../apiv1/NodeTemplatesClient/Delete/main.go | 2 +- .../apiv1/NodeTemplatesClient/Get/main.go | 2 +- .../NodeTemplatesClient/GetIamPolicy/main.go | 2 +- .../apiv1/NodeTemplatesClient/Insert/main.go | 2 +- .../apiv1/NodeTemplatesClient/List/main.go | 2 +- .../NodeTemplatesClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../NodeTypesClient/AggregatedList/main.go | 2 +- .../compute/apiv1/NodeTypesClient/Get/main.go | 2 +- .../apiv1/NodeTypesClient/List/main.go | 2 +- .../AggregatedList/main.go | 2 +- .../PacketMirroringsClient/Delete/main.go | 2 +- .../apiv1/PacketMirroringsClient/Get/main.go | 2 +- .../PacketMirroringsClient/Insert/main.go | 2 +- .../apiv1/PacketMirroringsClient/List/main.go | 2 +- .../PacketMirroringsClient/Patch/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../ProjectsClient/DisableXpnHost/main.go | 2 +- .../ProjectsClient/DisableXpnResource/main.go | 2 +- .../ProjectsClient/EnableXpnHost/main.go | 2 +- .../ProjectsClient/EnableXpnResource/main.go | 2 +- .../compute/apiv1/ProjectsClient/Get/main.go | 2 +- .../apiv1/ProjectsClient/GetXpnHost/main.go | 2 +- .../ProjectsClient/GetXpnResources/main.go | 2 +- .../apiv1/ProjectsClient/ListXpnHosts/main.go | 2 +- .../apiv1/ProjectsClient/MoveDisk/main.go | 2 +- .../apiv1/ProjectsClient/MoveInstance/main.go | 2 +- .../ProjectsClient/SetCloudArmorTier/main.go | 2 +- .../SetCommonInstanceMetadata/main.go | 2 +- .../SetDefaultNetworkTier/main.go | 2 +- .../SetUsageExportBucket/main.go | 2 +- .../Announce/main.go | 2 +- .../Delete/main.go | 2 +- .../Get/main.go | 2 +- .../Insert/main.go | 2 +- .../List/main.go | 2 +- .../Patch/main.go | 2 +- .../Withdraw/main.go | 2 +- .../AggregatedList/main.go | 2 +- .../Announce/main.go | 2 +- .../Delete/main.go | 2 +- .../PublicDelegatedPrefixesClient/Get/main.go | 2 +- .../Insert/main.go | 2 +- .../List/main.go | 2 +- .../Patch/main.go | 2 +- .../Withdraw/main.go | 2 +- .../RegionAutoscalersClient/Delete/main.go | 2 +- .../apiv1/RegionAutoscalersClient/Get/main.go | 2 +- .../RegionAutoscalersClient/Insert/main.go | 2 +- .../RegionAutoscalersClient/List/main.go | 2 +- .../RegionAutoscalersClient/Patch/main.go | 2 +- .../RegionAutoscalersClient/Update/main.go | 2 +- .../Delete/main.go | 2 +- .../RegionBackendServicesClient/Get/main.go | 2 +- .../GetHealth/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../Insert/main.go | 2 +- .../RegionBackendServicesClient/List/main.go | 2 +- .../ListUsable/main.go | 2 +- .../RegionBackendServicesClient/Patch/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../SetSecurityPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../Update/main.go | 2 +- .../AggregatedList/main.go | 2 +- .../apiv1/RegionCommitmentsClient/Get/main.go | 2 +- .../RegionCommitmentsClient/Insert/main.go | 2 +- .../RegionCommitmentsClient/List/main.go | 2 +- .../RegionCommitmentsClient/Update/main.go | 2 +- .../apiv1/RegionDiskTypesClient/Get/main.go | 2 +- .../apiv1/RegionDiskTypesClient/List/main.go | 2 +- .../AddResourcePolicies/main.go | 2 +- .../RegionDisksClient/BulkInsert/main.go | 2 +- .../RegionDisksClient/CreateSnapshot/main.go | 2 +- .../apiv1/RegionDisksClient/Delete/main.go | 2 +- .../apiv1/RegionDisksClient/Get/main.go | 2 +- .../RegionDisksClient/GetIamPolicy/main.go | 2 +- .../apiv1/RegionDisksClient/Insert/main.go | 2 +- .../apiv1/RegionDisksClient/List/main.go | 2 +- .../RemoveResourcePolicies/main.go | 2 +- .../apiv1/RegionDisksClient/Resize/main.go | 2 +- .../RegionDisksClient/SetIamPolicy/main.go | 2 +- .../apiv1/RegionDisksClient/SetLabels/main.go | 2 +- .../StartAsyncReplication/main.go | 2 +- .../StopAsyncReplication/main.go | 2 +- .../StopGroupAsyncReplication/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../apiv1/RegionDisksClient/Update/main.go | 2 +- .../Delete/main.go | 2 +- .../Get/main.go | 2 +- .../Insert/main.go | 2 +- .../List/main.go | 2 +- .../Patch/main.go | 2 +- .../RegionHealthChecksClient/Delete/main.go | 2 +- .../RegionHealthChecksClient/Get/main.go | 2 +- .../RegionHealthChecksClient/Insert/main.go | 2 +- .../RegionHealthChecksClient/List/main.go | 2 +- .../RegionHealthChecksClient/Patch/main.go | 2 +- .../RegionHealthChecksClient/Update/main.go | 2 +- .../AbandonInstances/main.go | 2 +- .../ApplyUpdatesToInstances/main.go | 2 +- .../CreateInstances/main.go | 2 +- .../Delete/main.go | 2 +- .../DeleteInstances/main.go | 2 +- .../DeletePerInstanceConfigs/main.go | 2 +- .../Get/main.go | 2 +- .../Insert/main.go | 2 +- .../List/main.go | 2 +- .../ListErrors/main.go | 2 +- .../ListManagedInstances/main.go | 2 +- .../ListPerInstanceConfigs/main.go | 2 +- .../Patch/main.go | 2 +- .../PatchPerInstanceConfigs/main.go | 2 +- .../RecreateInstances/main.go | 2 +- .../Resize/main.go | 2 +- .../ResumeInstances/main.go | 2 +- .../SetInstanceTemplate/main.go | 2 +- .../SetTargetPools/main.go | 2 +- .../StartInstances/main.go | 2 +- .../StopInstances/main.go | 2 +- .../SuspendInstances/main.go | 2 +- .../UpdatePerInstanceConfigs/main.go | 2 +- .../RegionInstanceGroupsClient/Get/main.go | 2 +- .../RegionInstanceGroupsClient/List/main.go | 2 +- .../ListInstances/main.go | 2 +- .../SetNamedPorts/main.go | 2 +- .../Delete/main.go | 2 +- .../RegionInstanceTemplatesClient/Get/main.go | 2 +- .../Insert/main.go | 2 +- .../List/main.go | 2 +- .../RegionInstancesClient/BulkInsert/main.go | 2 +- .../Delete/main.go | 2 +- .../RegionInstantSnapshotsClient/Get/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../Insert/main.go | 2 +- .../RegionInstantSnapshotsClient/List/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../SetLabels/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../AttachNetworkEndpoints/main.go | 2 +- .../Delete/main.go | 2 +- .../DetachNetworkEndpoints/main.go | 2 +- .../Get/main.go | 2 +- .../Insert/main.go | 2 +- .../List/main.go | 2 +- .../ListNetworkEndpoints/main.go | 2 +- .../AddAssociation/main.go | 2 +- .../AddRule/main.go | 2 +- .../CloneRules/main.go | 2 +- .../Delete/main.go | 2 +- .../Get/main.go | 2 +- .../GetAssociation/main.go | 2 +- .../GetEffectiveFirewalls/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetRule/main.go | 2 +- .../Insert/main.go | 2 +- .../List/main.go | 2 +- .../Patch/main.go | 2 +- .../PatchRule/main.go | 2 +- .../RemoveAssociation/main.go | 2 +- .../RemoveRule/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../Delete/main.go | 2 +- .../Get/main.go | 2 +- .../Insert/main.go | 2 +- .../List/main.go | 2 +- .../RegionOperationsClient/Delete/main.go | 2 +- .../apiv1/RegionOperationsClient/Get/main.go | 2 +- .../apiv1/RegionOperationsClient/List/main.go | 2 +- .../apiv1/RegionOperationsClient/Wait/main.go | 2 +- .../AddRule/main.go | 2 +- .../Delete/main.go | 2 +- .../RegionSecurityPoliciesClient/Get/main.go | 2 +- .../GetRule/main.go | 2 +- .../Insert/main.go | 2 +- .../RegionSecurityPoliciesClient/List/main.go | 2 +- .../Patch/main.go | 2 +- .../PatchRule/main.go | 2 +- .../RemoveRule/main.go | 2 +- .../SetLabels/main.go | 2 +- .../Delete/main.go | 2 +- .../RegionSslCertificatesClient/Get/main.go | 2 +- .../Insert/main.go | 2 +- .../RegionSslCertificatesClient/List/main.go | 2 +- .../RegionSslPoliciesClient/Delete/main.go | 2 +- .../apiv1/RegionSslPoliciesClient/Get/main.go | 2 +- .../RegionSslPoliciesClient/Insert/main.go | 2 +- .../RegionSslPoliciesClient/List/main.go | 2 +- .../ListAvailableFeatures/main.go | 2 +- .../RegionSslPoliciesClient/Patch/main.go | 2 +- .../Delete/main.go | 2 +- .../RegionTargetHttpProxiesClient/Get/main.go | 2 +- .../Insert/main.go | 2 +- .../List/main.go | 2 +- .../SetUrlMap/main.go | 2 +- .../Delete/main.go | 2 +- .../Get/main.go | 2 +- .../Insert/main.go | 2 +- .../List/main.go | 2 +- .../Patch/main.go | 2 +- .../SetSslCertificates/main.go | 2 +- .../SetUrlMap/main.go | 2 +- .../Delete/main.go | 2 +- .../RegionTargetTcpProxiesClient/Get/main.go | 2 +- .../Insert/main.go | 2 +- .../RegionTargetTcpProxiesClient/List/main.go | 2 +- .../apiv1/RegionUrlMapsClient/Delete/main.go | 2 +- .../apiv1/RegionUrlMapsClient/Get/main.go | 2 +- .../apiv1/RegionUrlMapsClient/Insert/main.go | 2 +- .../apiv1/RegionUrlMapsClient/List/main.go | 2 +- .../apiv1/RegionUrlMapsClient/Patch/main.go | 2 +- .../apiv1/RegionUrlMapsClient/Update/main.go | 2 +- .../RegionUrlMapsClient/Validate/main.go | 2 +- .../apiv1/RegionZonesClient/List/main.go | 2 +- .../compute/apiv1/RegionsClient/Get/main.go | 2 +- .../compute/apiv1/RegionsClient/List/main.go | 2 +- .../ReservationsClient/AggregatedList/main.go | 2 +- .../apiv1/ReservationsClient/Delete/main.go | 2 +- .../apiv1/ReservationsClient/Get/main.go | 2 +- .../ReservationsClient/GetIamPolicy/main.go | 2 +- .../apiv1/ReservationsClient/Insert/main.go | 2 +- .../apiv1/ReservationsClient/List/main.go | 2 +- .../apiv1/ReservationsClient/Resize/main.go | 2 +- .../ReservationsClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../apiv1/ReservationsClient/Update/main.go | 2 +- .../AggregatedList/main.go | 2 +- .../ResourcePoliciesClient/Delete/main.go | 2 +- .../apiv1/ResourcePoliciesClient/Get/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../ResourcePoliciesClient/Insert/main.go | 2 +- .../apiv1/ResourcePoliciesClient/List/main.go | 2 +- .../ResourcePoliciesClient/Patch/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../RoutersClient/AggregatedList/main.go | 2 +- .../apiv1/RoutersClient/Delete/main.go | 2 +- .../compute/apiv1/RoutersClient/Get/main.go | 2 +- .../apiv1/RoutersClient/GetNatIpInfo/main.go | 2 +- .../RoutersClient/GetNatMappingInfo/main.go | 2 +- .../RoutersClient/GetRouterStatus/main.go | 2 +- .../apiv1/RoutersClient/Insert/main.go | 2 +- .../compute/apiv1/RoutersClient/List/main.go | 2 +- .../compute/apiv1/RoutersClient/Patch/main.go | 2 +- .../apiv1/RoutersClient/Preview/main.go | 2 +- .../apiv1/RoutersClient/Update/main.go | 2 +- .../compute/apiv1/RoutesClient/Delete/main.go | 2 +- .../compute/apiv1/RoutesClient/Get/main.go | 2 +- .../compute/apiv1/RoutesClient/Insert/main.go | 2 +- .../compute/apiv1/RoutesClient/List/main.go | 2 +- .../SecurityPoliciesClient/AddRule/main.go | 2 +- .../AggregatedList/main.go | 2 +- .../SecurityPoliciesClient/Delete/main.go | 2 +- .../apiv1/SecurityPoliciesClient/Get/main.go | 2 +- .../SecurityPoliciesClient/GetRule/main.go | 2 +- .../SecurityPoliciesClient/Insert/main.go | 2 +- .../apiv1/SecurityPoliciesClient/List/main.go | 2 +- .../ListPreconfiguredExpressionSets/main.go | 2 +- .../SecurityPoliciesClient/Patch/main.go | 2 +- .../SecurityPoliciesClient/PatchRule/main.go | 2 +- .../SecurityPoliciesClient/RemoveRule/main.go | 2 +- .../SecurityPoliciesClient/SetLabels/main.go | 2 +- .../AggregatedList/main.go | 2 +- .../ServiceAttachmentsClient/Delete/main.go | 2 +- .../ServiceAttachmentsClient/Get/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../ServiceAttachmentsClient/Insert/main.go | 2 +- .../ServiceAttachmentsClient/List/main.go | 2 +- .../ServiceAttachmentsClient/Patch/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../apiv1/SnapshotSettingsClient/Get/main.go | 2 +- .../SnapshotSettingsClient/Patch/main.go | 2 +- .../apiv1/SnapshotsClient/Delete/main.go | 2 +- .../compute/apiv1/SnapshotsClient/Get/main.go | 2 +- .../SnapshotsClient/GetIamPolicy/main.go | 2 +- .../apiv1/SnapshotsClient/Insert/main.go | 2 +- .../apiv1/SnapshotsClient/List/main.go | 2 +- .../SnapshotsClient/SetIamPolicy/main.go | 2 +- .../apiv1/SnapshotsClient/SetLabels/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../AggregatedList/main.go | 2 +- .../SslCertificatesClient/Delete/main.go | 2 +- .../apiv1/SslCertificatesClient/Get/main.go | 2 +- .../SslCertificatesClient/Insert/main.go | 2 +- .../apiv1/SslCertificatesClient/List/main.go | 2 +- .../SslPoliciesClient/AggregatedList/main.go | 2 +- .../apiv1/SslPoliciesClient/Delete/main.go | 2 +- .../apiv1/SslPoliciesClient/Get/main.go | 2 +- .../apiv1/SslPoliciesClient/Insert/main.go | 2 +- .../apiv1/SslPoliciesClient/List/main.go | 2 +- .../ListAvailableFeatures/main.go | 2 +- .../apiv1/SslPoliciesClient/Patch/main.go | 2 +- .../AggregatedList/main.go | 2 +- .../apiv1/StoragePoolTypesClient/Get/main.go | 2 +- .../apiv1/StoragePoolTypesClient/List/main.go | 2 +- .../StoragePoolsClient/AggregatedList/main.go | 2 +- .../apiv1/StoragePoolsClient/Delete/main.go | 2 +- .../apiv1/StoragePoolsClient/Get/main.go | 2 +- .../StoragePoolsClient/GetIamPolicy/main.go | 2 +- .../apiv1/StoragePoolsClient/Insert/main.go | 2 +- .../apiv1/StoragePoolsClient/List/main.go | 2 +- .../StoragePoolsClient/ListDisks/main.go | 2 +- .../StoragePoolsClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../apiv1/StoragePoolsClient/Update/main.go | 2 +- .../SubnetworksClient/AggregatedList/main.go | 2 +- .../apiv1/SubnetworksClient/Delete/main.go | 2 +- .../ExpandIpCidrRange/main.go | 2 +- .../apiv1/SubnetworksClient/Get/main.go | 2 +- .../SubnetworksClient/GetIamPolicy/main.go | 2 +- .../apiv1/SubnetworksClient/Insert/main.go | 2 +- .../apiv1/SubnetworksClient/List/main.go | 2 +- .../SubnetworksClient/ListUsable/main.go | 2 +- .../apiv1/SubnetworksClient/Patch/main.go | 2 +- .../SubnetworksClient/SetIamPolicy/main.go | 2 +- .../SetPrivateIpGoogleAccess/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../TargetGrpcProxiesClient/Delete/main.go | 2 +- .../apiv1/TargetGrpcProxiesClient/Get/main.go | 2 +- .../TargetGrpcProxiesClient/Insert/main.go | 2 +- .../TargetGrpcProxiesClient/List/main.go | 2 +- .../TargetGrpcProxiesClient/Patch/main.go | 2 +- .../AggregatedList/main.go | 2 +- .../TargetHttpProxiesClient/Delete/main.go | 2 +- .../apiv1/TargetHttpProxiesClient/Get/main.go | 2 +- .../TargetHttpProxiesClient/Insert/main.go | 2 +- .../TargetHttpProxiesClient/List/main.go | 2 +- .../TargetHttpProxiesClient/Patch/main.go | 2 +- .../TargetHttpProxiesClient/SetUrlMap/main.go | 2 +- .../AggregatedList/main.go | 2 +- .../TargetHttpsProxiesClient/Delete/main.go | 2 +- .../TargetHttpsProxiesClient/Get/main.go | 2 +- .../TargetHttpsProxiesClient/Insert/main.go | 2 +- .../TargetHttpsProxiesClient/List/main.go | 2 +- .../TargetHttpsProxiesClient/Patch/main.go | 2 +- .../SetCertificateMap/main.go | 2 +- .../SetQuicOverride/main.go | 2 +- .../SetSslCertificates/main.go | 2 +- .../SetSslPolicy/main.go | 2 +- .../SetUrlMap/main.go | 2 +- .../AggregatedList/main.go | 2 +- .../TargetInstancesClient/Delete/main.go | 2 +- .../apiv1/TargetInstancesClient/Get/main.go | 2 +- .../TargetInstancesClient/Insert/main.go | 2 +- .../apiv1/TargetInstancesClient/List/main.go | 2 +- .../SetSecurityPolicy/main.go | 2 +- .../TargetPoolsClient/AddHealthCheck/main.go | 2 +- .../TargetPoolsClient/AddInstance/main.go | 2 +- .../TargetPoolsClient/AggregatedList/main.go | 2 +- .../apiv1/TargetPoolsClient/Delete/main.go | 2 +- .../apiv1/TargetPoolsClient/Get/main.go | 2 +- .../apiv1/TargetPoolsClient/GetHealth/main.go | 2 +- .../apiv1/TargetPoolsClient/Insert/main.go | 2 +- .../apiv1/TargetPoolsClient/List/main.go | 2 +- .../RemoveHealthCheck/main.go | 2 +- .../TargetPoolsClient/RemoveInstance/main.go | 2 +- .../apiv1/TargetPoolsClient/SetBackup/main.go | 2 +- .../SetSecurityPolicy/main.go | 2 +- .../TargetSslProxiesClient/Delete/main.go | 2 +- .../apiv1/TargetSslProxiesClient/Get/main.go | 2 +- .../TargetSslProxiesClient/Insert/main.go | 2 +- .../apiv1/TargetSslProxiesClient/List/main.go | 2 +- .../SetBackendService/main.go | 2 +- .../SetCertificateMap/main.go | 2 +- .../SetProxyHeader/main.go | 2 +- .../SetSslCertificates/main.go | 2 +- .../SetSslPolicy/main.go | 2 +- .../AggregatedList/main.go | 2 +- .../TargetTcpProxiesClient/Delete/main.go | 2 +- .../apiv1/TargetTcpProxiesClient/Get/main.go | 2 +- .../TargetTcpProxiesClient/Insert/main.go | 2 +- .../apiv1/TargetTcpProxiesClient/List/main.go | 2 +- .../SetBackendService/main.go | 2 +- .../SetProxyHeader/main.go | 2 +- .../AggregatedList/main.go | 2 +- .../TargetVpnGatewaysClient/Delete/main.go | 2 +- .../apiv1/TargetVpnGatewaysClient/Get/main.go | 2 +- .../TargetVpnGatewaysClient/Insert/main.go | 2 +- .../TargetVpnGatewaysClient/List/main.go | 2 +- .../TargetVpnGatewaysClient/SetLabels/main.go | 2 +- .../UrlMapsClient/AggregatedList/main.go | 2 +- .../apiv1/UrlMapsClient/Delete/main.go | 2 +- .../compute/apiv1/UrlMapsClient/Get/main.go | 2 +- .../apiv1/UrlMapsClient/Insert/main.go | 2 +- .../UrlMapsClient/InvalidateCache/main.go | 2 +- .../compute/apiv1/UrlMapsClient/List/main.go | 2 +- .../compute/apiv1/UrlMapsClient/Patch/main.go | 2 +- .../apiv1/UrlMapsClient/Update/main.go | 2 +- .../apiv1/UrlMapsClient/Validate/main.go | 2 +- .../VpnGatewaysClient/AggregatedList/main.go | 2 +- .../apiv1/VpnGatewaysClient/Delete/main.go | 2 +- .../apiv1/VpnGatewaysClient/Get/main.go | 2 +- .../apiv1/VpnGatewaysClient/GetStatus/main.go | 2 +- .../apiv1/VpnGatewaysClient/Insert/main.go | 2 +- .../apiv1/VpnGatewaysClient/List/main.go | 2 +- .../apiv1/VpnGatewaysClient/SetLabels/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../VpnTunnelsClient/AggregatedList/main.go | 2 +- .../apiv1/VpnTunnelsClient/Delete/main.go | 2 +- .../apiv1/VpnTunnelsClient/Get/main.go | 2 +- .../apiv1/VpnTunnelsClient/Insert/main.go | 2 +- .../apiv1/VpnTunnelsClient/List/main.go | 2 +- .../apiv1/VpnTunnelsClient/SetLabels/main.go | 2 +- .../apiv1/ZoneOperationsClient/Delete/main.go | 2 +- .../apiv1/ZoneOperationsClient/Get/main.go | 2 +- .../apiv1/ZoneOperationsClient/List/main.go | 2 +- .../apiv1/ZoneOperationsClient/Wait/main.go | 2 +- .../compute/apiv1/ZonesClient/Get/main.go | 2 +- .../compute/apiv1/ZonesClient/List/main.go | 2 +- ...ppet_metadata.google.cloud.compute.v1.json | 2 +- .../apiv1/Client/CreateChallenge/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/VerifyAttestation/main.go | 2 +- ...google.cloud.confidentialcomputing.v1.json | 2 +- .../Client/CreateChallenge/main.go | 2 +- .../apiv1alpha1/Client/GetLocation/main.go | 2 +- .../apiv1alpha1/Client/ListLocations/main.go | 2 +- .../Client/VerifyAttestation/main.go | 2 +- ....cloud.confidentialcomputing.v1alpha1.json | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apiv1/Client/CreateDeployment/main.go | 2 +- .../config/apiv1/Client/CreatePreview/main.go | 2 +- .../apiv1/Client/DeleteDeployment/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../config/apiv1/Client/DeletePreview/main.go | 2 +- .../apiv1/Client/DeleteStatefile/main.go | 2 +- .../Client/ExportDeploymentStatefile/main.go | 2 +- .../apiv1/Client/ExportLockInfo/main.go | 2 +- .../apiv1/Client/ExportPreviewResult/main.go | 2 +- .../Client/ExportRevisionStatefile/main.go | 2 +- .../config/apiv1/Client/GetDeployment/main.go | 2 +- .../config/apiv1/Client/GetIamPolicy/main.go | 2 +- .../config/apiv1/Client/GetLocation/main.go | 2 +- .../config/apiv1/Client/GetOperation/main.go | 2 +- .../config/apiv1/Client/GetPreview/main.go | 2 +- .../config/apiv1/Client/GetResource/main.go | 2 +- .../config/apiv1/Client/GetRevision/main.go | 2 +- .../apiv1/Client/GetTerraformVersion/main.go | 2 +- .../apiv1/Client/ImportStatefile/main.go | 2 +- .../apiv1/Client/ListDeployments/main.go | 2 +- .../config/apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../config/apiv1/Client/ListPreviews/main.go | 2 +- .../config/apiv1/Client/ListResources/main.go | 2 +- .../config/apiv1/Client/ListRevisions/main.go | 2 +- .../Client/ListTerraformVersions/main.go | 2 +- .../apiv1/Client/LockDeployment/main.go | 2 +- .../config/apiv1/Client/SetIamPolicy/main.go | 2 +- .../apiv1/Client/TestIamPermissions/main.go | 2 +- .../apiv1/Client/UnlockDeployment/main.go | 2 +- .../apiv1/Client/UpdateDeployment/main.go | 2 +- ...ippet_metadata.google.cloud.config.v1.json | 2 +- .../Client/BulkAnalyzeConversations/main.go | 2 +- .../Client/BulkDeleteConversations/main.go | 2 +- .../Client/BulkDownloadFeedbackLabels/main.go | 2 +- .../Client/BulkUploadFeedbackLabels/main.go | 2 +- .../Client/CalculateIssueModelStats/main.go | 2 +- .../apiv1/Client/CalculateStats/main.go | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apiv1/Client/CreateAnalysis/main.go | 2 +- .../apiv1/Client/CreateAnalysisRule/main.go | 2 +- .../apiv1/Client/CreateConversation/main.go | 2 +- .../apiv1/Client/CreateFeedbackLabel/main.go | 2 +- .../apiv1/Client/CreateIssueModel/main.go | 2 +- .../apiv1/Client/CreatePhraseMatcher/main.go | 2 +- .../apiv1/Client/CreateQaQuestion/main.go | 2 +- .../apiv1/Client/CreateQaScorecard/main.go | 2 +- .../Client/CreateQaScorecardRevision/main.go | 2 +- .../apiv1/Client/CreateView/main.go | 2 +- .../apiv1/Client/DeleteAnalysis/main.go | 2 +- .../apiv1/Client/DeleteAnalysisRule/main.go | 2 +- .../apiv1/Client/DeleteConversation/main.go | 2 +- .../apiv1/Client/DeleteFeedbackLabel/main.go | 2 +- .../apiv1/Client/DeleteIssue/main.go | 2 +- .../apiv1/Client/DeleteIssueModel/main.go | 2 +- .../apiv1/Client/DeletePhraseMatcher/main.go | 2 +- .../apiv1/Client/DeleteQaQuestion/main.go | 2 +- .../apiv1/Client/DeleteQaScorecard/main.go | 2 +- .../Client/DeleteQaScorecardRevision/main.go | 2 +- .../apiv1/Client/DeleteView/main.go | 2 +- .../apiv1/Client/DeployIssueModel/main.go | 2 +- .../Client/DeployQaScorecardRevision/main.go | 2 +- .../apiv1/Client/ExportInsightsData/main.go | 2 +- .../apiv1/Client/ExportIssueModel/main.go | 2 +- .../apiv1/Client/GetAnalysis/main.go | 2 +- .../apiv1/Client/GetAnalysisRule/main.go | 2 +- .../apiv1/Client/GetConversation/main.go | 2 +- .../apiv1/Client/GetEncryptionSpec/main.go | 2 +- .../apiv1/Client/GetFeedbackLabel/main.go | 2 +- .../apiv1/Client/GetIssue/main.go | 2 +- .../apiv1/Client/GetIssueModel/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/GetPhraseMatcher/main.go | 2 +- .../apiv1/Client/GetQaQuestion/main.go | 2 +- .../apiv1/Client/GetQaScorecard/main.go | 2 +- .../Client/GetQaScorecardRevision/main.go | 2 +- .../apiv1/Client/GetSettings/main.go | 2 +- .../apiv1/Client/GetView/main.go | 2 +- .../apiv1/Client/ImportIssueModel/main.go | 2 +- .../apiv1/Client/IngestConversations/main.go | 2 +- .../Client/InitializeEncryptionSpec/main.go | 2 +- .../Client/ListAllFeedbackLabels/main.go | 2 +- .../apiv1/Client/ListAnalyses/main.go | 2 +- .../apiv1/Client/ListAnalysisRules/main.go | 2 +- .../apiv1/Client/ListConversations/main.go | 2 +- .../apiv1/Client/ListFeedbackLabels/main.go | 2 +- .../apiv1/Client/ListIssueModels/main.go | 2 +- .../apiv1/Client/ListIssues/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/ListPhraseMatchers/main.go | 2 +- .../apiv1/Client/ListQaQuestions/main.go | 2 +- .../Client/ListQaScorecardRevisions/main.go | 2 +- .../apiv1/Client/ListQaScorecards/main.go | 2 +- .../apiv1/Client/ListViews/main.go | 2 +- .../apiv1/Client/QueryMetrics/main.go | 2 +- .../Client/TuneQaScorecardRevision/main.go | 2 +- .../apiv1/Client/UndeployIssueModel/main.go | 2 +- .../UndeployQaScorecardRevision/main.go | 2 +- .../apiv1/Client/UpdateAnalysisRule/main.go | 2 +- .../apiv1/Client/UpdateConversation/main.go | 2 +- .../apiv1/Client/UpdateFeedbackLabel/main.go | 2 +- .../apiv1/Client/UpdateIssue/main.go | 2 +- .../apiv1/Client/UpdateIssueModel/main.go | 2 +- .../apiv1/Client/UpdatePhraseMatcher/main.go | 2 +- .../apiv1/Client/UpdateQaQuestion/main.go | 2 +- .../apiv1/Client/UpdateQaScorecard/main.go | 2 +- .../apiv1/Client/UpdateSettings/main.go | 2 +- .../apiv1/Client/UpdateView/main.go | 2 +- .../apiv1/Client/UploadConversation/main.go | 2 +- ...google.cloud.contactcenterinsights.v1.json | 2 +- .../CancelOperation/main.go | 2 +- .../CheckAutopilotCompatibility/main.go | 2 +- .../CompleteIPRotation/main.go | 2 +- .../CompleteNodePoolUpgrade/main.go | 2 +- .../CreateCluster/main.go | 2 +- .../CreateNodePool/main.go | 2 +- .../DeleteCluster/main.go | 2 +- .../DeleteNodePool/main.go | 2 +- .../ClusterManagerClient/GetCluster/main.go | 2 +- .../GetJSONWebKeys/main.go | 2 +- .../ClusterManagerClient/GetNodePool/main.go | 2 +- .../ClusterManagerClient/GetOperation/main.go | 2 +- .../GetServerConfig/main.go | 2 +- .../ClusterManagerClient/ListClusters/main.go | 2 +- .../ListNodePools/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListUsableSubnetworks/main.go | 2 +- .../RollbackNodePoolUpgrade/main.go | 2 +- .../SetAddonsConfig/main.go | 2 +- .../ClusterManagerClient/SetLabels/main.go | 2 +- .../SetLegacyAbac/main.go | 2 +- .../ClusterManagerClient/SetLocations/main.go | 2 +- .../SetLoggingService/main.go | 2 +- .../SetMaintenancePolicy/main.go | 2 +- .../SetMasterAuth/main.go | 2 +- .../SetMonitoringService/main.go | 2 +- .../SetNetworkPolicy/main.go | 2 +- .../SetNodePoolAutoscaling/main.go | 2 +- .../SetNodePoolManagement/main.go | 2 +- .../SetNodePoolSize/main.go | 2 +- .../StartIPRotation/main.go | 2 +- .../UpdateCluster/main.go | 2 +- .../ClusterManagerClient/UpdateMaster/main.go | 2 +- .../UpdateNodePool/main.go | 2 +- .../snippet_metadata.google.container.v1.json | 2 +- .../ExportSBOM/main.go | 2 +- .../GeneratePackagesSummary/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../BatchCreateNotes/main.go | 2 +- .../BatchCreateOccurrences/main.go | 2 +- .../GrafeasV1Beta1Client/CreateNote/main.go | 2 +- .../CreateOccurrence/main.go | 2 +- .../GrafeasV1Beta1Client/DeleteNote/main.go | 2 +- .../DeleteOccurrence/main.go | 2 +- .../GrafeasV1Beta1Client/GetNote/main.go | 2 +- .../GetOccurrence/main.go | 2 +- .../GetOccurrenceNote/main.go | 2 +- .../main.go | 2 +- .../ListNoteOccurrences/main.go | 2 +- .../GrafeasV1Beta1Client/ListNotes/main.go | 2 +- .../ListOccurrences/main.go | 2 +- .../GrafeasV1Beta1Client/UpdateNote/main.go | 2 +- .../UpdateOccurrence/main.go | 2 +- ...le.devtools.containeranalysis.v1beta1.json | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apiv1/Client/CreateEntry/main.go | 2 +- .../apiv1/Client/CreateEntryGroup/main.go | 2 +- .../apiv1/Client/CreateTag/main.go | 2 +- .../apiv1/Client/CreateTagTemplate/main.go | 2 +- .../Client/CreateTagTemplateField/main.go | 2 +- .../apiv1/Client/DeleteEntry/main.go | 2 +- .../apiv1/Client/DeleteEntryGroup/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../apiv1/Client/DeleteTag/main.go | 2 +- .../apiv1/Client/DeleteTagTemplate/main.go | 2 +- .../Client/DeleteTagTemplateField/main.go | 2 +- .../datacatalog/apiv1/Client/GetEntry/main.go | 2 +- .../apiv1/Client/GetEntryGroup/main.go | 2 +- .../apiv1/Client/GetIamPolicy/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/GetTagTemplate/main.go | 2 +- .../apiv1/Client/ImportEntries/main.go | 2 +- .../apiv1/Client/ListEntries/main.go | 2 +- .../apiv1/Client/ListEntryGroups/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../datacatalog/apiv1/Client/ListTags/main.go | 2 +- .../apiv1/Client/LookupEntry/main.go | 2 +- .../apiv1/Client/ModifyEntryContacts/main.go | 2 +- .../apiv1/Client/ModifyEntryOverview/main.go | 2 +- .../apiv1/Client/ReconcileTags/main.go | 2 +- .../Client/RenameTagTemplateField/main.go | 2 +- .../RenameTagTemplateFieldEnumValue/main.go | 2 +- .../apiv1/Client/RetrieveConfig/main.go | 2 +- .../Client/RetrieveEffectiveConfig/main.go | 2 +- .../apiv1/Client/SearchCatalog/main.go | 2 +- .../apiv1/Client/SetConfig/main.go | 2 +- .../apiv1/Client/SetIamPolicy/main.go | 2 +- .../apiv1/Client/StarEntry/main.go | 2 +- .../apiv1/Client/TestIamPermissions/main.go | 2 +- .../apiv1/Client/UnstarEntry/main.go | 2 +- .../apiv1/Client/UpdateEntry/main.go | 2 +- .../apiv1/Client/UpdateEntryGroup/main.go | 2 +- .../apiv1/Client/UpdateTag/main.go | 2 +- .../apiv1/Client/UpdateTagTemplate/main.go | 2 +- .../Client/UpdateTagTemplateField/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreatePolicyTag/main.go | 2 +- .../CreateTaxonomy/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../DeletePolicyTag/main.go | 2 +- .../DeleteTaxonomy/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetPolicyTag/main.go | 2 +- .../GetTaxonomy/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListPolicyTags/main.go | 2 +- .../ListTaxonomies/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdatePolicyTag/main.go | 2 +- .../UpdateTaxonomy/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../ExportTaxonomies/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ImportTaxonomies/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ReplaceTaxonomy/main.go | 2 +- ..._metadata.google.cloud.datacatalog.v1.json | 2 +- .../apiv1beta1/Client/CreateEntry/main.go | 2 +- .../Client/CreateEntryGroup/main.go | 2 +- .../apiv1beta1/Client/CreateTag/main.go | 2 +- .../Client/CreateTagTemplate/main.go | 2 +- .../Client/CreateTagTemplateField/main.go | 2 +- .../apiv1beta1/Client/DeleteEntry/main.go | 2 +- .../Client/DeleteEntryGroup/main.go | 2 +- .../apiv1beta1/Client/DeleteTag/main.go | 2 +- .../Client/DeleteTagTemplate/main.go | 2 +- .../Client/DeleteTagTemplateField/main.go | 2 +- .../apiv1beta1/Client/GetEntry/main.go | 2 +- .../apiv1beta1/Client/GetEntryGroup/main.go | 2 +- .../apiv1beta1/Client/GetIamPolicy/main.go | 2 +- .../apiv1beta1/Client/GetTagTemplate/main.go | 2 +- .../apiv1beta1/Client/ListEntries/main.go | 2 +- .../apiv1beta1/Client/ListEntryGroups/main.go | 2 +- .../apiv1beta1/Client/ListTags/main.go | 2 +- .../apiv1beta1/Client/LookupEntry/main.go | 2 +- .../Client/RenameTagTemplateField/main.go | 2 +- .../RenameTagTemplateFieldEnumValue/main.go | 2 +- .../apiv1beta1/Client/SearchCatalog/main.go | 2 +- .../apiv1beta1/Client/SetIamPolicy/main.go | 2 +- .../Client/TestIamPermissions/main.go | 2 +- .../apiv1beta1/Client/UpdateEntry/main.go | 2 +- .../Client/UpdateEntryGroup/main.go | 2 +- .../apiv1beta1/Client/UpdateTag/main.go | 2 +- .../Client/UpdateTagTemplate/main.go | 2 +- .../Client/UpdateTagTemplateField/main.go | 2 +- .../CreatePolicyTag/main.go | 2 +- .../CreateTaxonomy/main.go | 2 +- .../DeletePolicyTag/main.go | 2 +- .../DeleteTaxonomy/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetPolicyTag/main.go | 2 +- .../GetTaxonomy/main.go | 2 +- .../ListPolicyTags/main.go | 2 +- .../ListTaxonomies/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdatePolicyTag/main.go | 2 +- .../UpdateTaxonomy/main.go | 2 +- .../ExportTaxonomies/main.go | 2 +- .../ImportTaxonomies/main.go | 2 +- ...data.google.cloud.datacatalog.v1beta1.json | 2 +- .../Client/BatchSearchLinkProcesses/main.go | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apiv1/Client/CreateLineageEvent/main.go | 2 +- .../apiv1/Client/CreateProcess/main.go | 2 +- .../lineage/apiv1/Client/CreateRun/main.go | 2 +- .../apiv1/Client/DeleteLineageEvent/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../apiv1/Client/DeleteProcess/main.go | 2 +- .../lineage/apiv1/Client/DeleteRun/main.go | 2 +- .../apiv1/Client/GetLineageEvent/main.go | 2 +- .../lineage/apiv1/Client/GetOperation/main.go | 2 +- .../lineage/apiv1/Client/GetProcess/main.go | 2 +- .../lineage/apiv1/Client/GetRun/main.go | 2 +- .../apiv1/Client/ListLineageEvents/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/ListProcesses/main.go | 2 +- .../lineage/apiv1/Client/ListRuns/main.go | 2 +- .../Client/ProcessOpenLineageRunEvent/main.go | 2 +- .../lineage/apiv1/Client/SearchLinks/main.go | 2 +- .../apiv1/Client/UpdateProcess/main.go | 2 +- .../lineage/apiv1/Client/UpdateRun/main.go | 2 +- ...a.google.cloud.datacatalog.lineage.v1.json | 2 +- .../LaunchFlexTemplate/main.go | 2 +- .../AggregatedListJobs/main.go | 2 +- .../JobsV1Beta3Client/CheckActiveJobs/main.go | 2 +- .../JobsV1Beta3Client/CreateJob/main.go | 2 +- .../JobsV1Beta3Client/GetJob/main.go | 2 +- .../JobsV1Beta3Client/ListJobs/main.go | 2 +- .../JobsV1Beta3Client/SnapshotJob/main.go | 2 +- .../JobsV1Beta3Client/UpdateJob/main.go | 2 +- .../ListJobMessages/main.go | 2 +- .../GetJobExecutionDetails/main.go | 2 +- .../GetJobMetrics/main.go | 2 +- .../GetStageExecutionDetails/main.go | 2 +- .../DeleteSnapshot/main.go | 2 +- .../GetSnapshot/main.go | 2 +- .../ListSnapshots/main.go | 2 +- .../CreateJobFromTemplate/main.go | 2 +- .../TemplatesClient/GetTemplate/main.go | 2 +- .../TemplatesClient/LaunchTemplate/main.go | 2 +- .../Client/CancelWorkflowInvocation/main.go | 2 +- .../Client/CommitWorkspaceChanges/main.go | 2 +- .../Client/CreateCompilationResult/main.go | 2 +- .../Client/CreateRepository/main.go | 2 +- .../Client/CreateWorkflowInvocation/main.go | 2 +- .../Client/CreateWorkspace/main.go | 2 +- .../Client/DeleteRepository/main.go | 2 +- .../Client/DeleteWorkflowInvocation/main.go | 2 +- .../Client/DeleteWorkspace/main.go | 2 +- .../apiv1alpha2/Client/FetchFileDiff/main.go | 2 +- .../Client/FetchFileGitStatuses/main.go | 2 +- .../Client/FetchGitAheadBehind/main.go | 2 +- .../Client/FetchRemoteBranches/main.go | 2 +- .../Client/GetCompilationResult/main.go | 2 +- .../apiv1alpha2/Client/GetIamPolicy/main.go | 2 +- .../apiv1alpha2/Client/GetLocation/main.go | 2 +- .../apiv1alpha2/Client/GetRepository/main.go | 2 +- .../Client/GetWorkflowInvocation/main.go | 2 +- .../apiv1alpha2/Client/GetWorkspace/main.go | 2 +- .../Client/InstallNpmPackages/main.go | 2 +- .../Client/ListCompilationResults/main.go | 2 +- .../apiv1alpha2/Client/ListLocations/main.go | 2 +- .../Client/ListRepositories/main.go | 2 +- .../Client/ListWorkflowInvocations/main.go | 2 +- .../apiv1alpha2/Client/ListWorkspaces/main.go | 2 +- .../apiv1alpha2/Client/MakeDirectory/main.go | 2 +- .../apiv1alpha2/Client/MoveDirectory/main.go | 2 +- .../apiv1alpha2/Client/MoveFile/main.go | 2 +- .../apiv1alpha2/Client/PullGitCommits/main.go | 2 +- .../apiv1alpha2/Client/PushGitCommits/main.go | 2 +- .../QueryCompilationResultActions/main.go | 2 +- .../Client/QueryDirectoryContents/main.go | 2 +- .../QueryWorkflowInvocationActions/main.go | 2 +- .../apiv1alpha2/Client/ReadFile/main.go | 2 +- .../Client/RemoveDirectory/main.go | 2 +- .../apiv1alpha2/Client/RemoveFile/main.go | 2 +- .../Client/ResetWorkspaceChanges/main.go | 2 +- .../apiv1alpha2/Client/SetIamPolicy/main.go | 2 +- .../Client/TestIamPermissions/main.go | 2 +- .../Client/UpdateRepository/main.go | 2 +- .../apiv1alpha2/Client/WriteFile/main.go | 2 +- ...tadata.google.cloud.dataform.v1alpha2.json | 2 +- .../Client/CancelWorkflowInvocation/main.go | 2 +- .../Client/CommitRepositoryChanges/main.go | 2 +- .../Client/CommitWorkspaceChanges/main.go | 2 +- .../main.go | 2 +- .../Client/CreateCompilationResult/main.go | 2 +- .../Client/CreateReleaseConfig/main.go | 2 +- .../Client/CreateRepository/main.go | 2 +- .../Client/CreateWorkflowConfig/main.go | 2 +- .../Client/CreateWorkflowInvocation/main.go | 2 +- .../apiv1beta1/Client/CreateWorkspace/main.go | 2 +- .../Client/DeleteReleaseConfig/main.go | 2 +- .../Client/DeleteRepository/main.go | 2 +- .../Client/DeleteWorkflowConfig/main.go | 2 +- .../Client/DeleteWorkflowInvocation/main.go | 2 +- .../apiv1beta1/Client/DeleteWorkspace/main.go | 2 +- .../apiv1beta1/Client/FetchFileDiff/main.go | 2 +- .../Client/FetchFileGitStatuses/main.go | 2 +- .../Client/FetchGitAheadBehind/main.go | 2 +- .../Client/FetchRemoteBranches/main.go | 2 +- .../Client/FetchRepositoryHistory/main.go | 2 +- .../Client/GetCompilationResult/main.go | 2 +- .../apiv1beta1/Client/GetIamPolicy/main.go | 2 +- .../apiv1beta1/Client/GetLocation/main.go | 2 +- .../Client/GetReleaseConfig/main.go | 2 +- .../apiv1beta1/Client/GetRepository/main.go | 2 +- .../Client/GetWorkflowConfig/main.go | 2 +- .../Client/GetWorkflowInvocation/main.go | 2 +- .../apiv1beta1/Client/GetWorkspace/main.go | 2 +- .../Client/InstallNpmPackages/main.go | 2 +- .../Client/ListCompilationResults/main.go | 2 +- .../apiv1beta1/Client/ListLocations/main.go | 2 +- .../Client/ListReleaseConfigs/main.go | 2 +- .../Client/ListRepositories/main.go | 2 +- .../Client/ListWorkflowConfigs/main.go | 2 +- .../Client/ListWorkflowInvocations/main.go | 2 +- .../apiv1beta1/Client/ListWorkspaces/main.go | 2 +- .../apiv1beta1/Client/MakeDirectory/main.go | 2 +- .../apiv1beta1/Client/MoveDirectory/main.go | 2 +- .../apiv1beta1/Client/MoveFile/main.go | 2 +- .../apiv1beta1/Client/PullGitCommits/main.go | 2 +- .../apiv1beta1/Client/PushGitCommits/main.go | 2 +- .../QueryCompilationResultActions/main.go | 2 +- .../Client/QueryDirectoryContents/main.go | 2 +- .../QueryRepositoryDirectoryContents/main.go | 2 +- .../QueryWorkflowInvocationActions/main.go | 2 +- .../apiv1beta1/Client/ReadFile/main.go | 2 +- .../Client/ReadRepositoryFile/main.go | 2 +- .../apiv1beta1/Client/RemoveDirectory/main.go | 2 +- .../apiv1beta1/Client/RemoveFile/main.go | 2 +- .../Client/ResetWorkspaceChanges/main.go | 2 +- .../apiv1beta1/Client/SetIamPolicy/main.go | 2 +- .../Client/TestIamPermissions/main.go | 2 +- .../Client/UpdateReleaseConfig/main.go | 2 +- .../Client/UpdateRepository/main.go | 2 +- .../Client/UpdateWorkflowConfig/main.go | 2 +- .../apiv1beta1/Client/WriteFile/main.go | 2 +- ...etadata.google.cloud.dataform.v1beta1.json | 2 +- .../apiv1/Client/CreateInstance/main.go | 2 +- .../apiv1/Client/DeleteInstance/main.go | 2 +- .../apiv1/Client/GetInstance/main.go | 2 +- .../Client/ListAvailableVersions/main.go | 2 +- .../apiv1/Client/ListInstances/main.go | 2 +- .../apiv1/Client/RestartInstance/main.go | 2 +- .../apiv1/Client/UpdateInstance/main.go | 2 +- .../Client/CreateAnnotationSpecSet/main.go | 2 +- .../apiv1beta1/Client/CreateDataset/main.go | 2 +- .../Client/CreateEvaluationJob/main.go | 2 +- .../Client/CreateInstruction/main.go | 2 +- .../Client/DeleteAnnotatedDataset/main.go | 2 +- .../Client/DeleteAnnotationSpecSet/main.go | 2 +- .../apiv1beta1/Client/DeleteDataset/main.go | 2 +- .../Client/DeleteEvaluationJob/main.go | 2 +- .../Client/DeleteInstruction/main.go | 2 +- .../apiv1beta1/Client/ExportData/main.go | 2 +- .../Client/GetAnnotatedDataset/main.go | 2 +- .../Client/GetAnnotationSpecSet/main.go | 2 +- .../apiv1beta1/Client/GetDataItem/main.go | 2 +- .../apiv1beta1/Client/GetDataset/main.go | 2 +- .../apiv1beta1/Client/GetEvaluation/main.go | 2 +- .../Client/GetEvaluationJob/main.go | 2 +- .../apiv1beta1/Client/GetExample/main.go | 2 +- .../apiv1beta1/Client/GetInstruction/main.go | 2 +- .../apiv1beta1/Client/ImportData/main.go | 2 +- .../apiv1beta1/Client/LabelImage/main.go | 2 +- .../apiv1beta1/Client/LabelText/main.go | 2 +- .../apiv1beta1/Client/LabelVideo/main.go | 2 +- .../Client/ListAnnotatedDatasets/main.go | 2 +- .../Client/ListAnnotationSpecSets/main.go | 2 +- .../apiv1beta1/Client/ListDataItems/main.go | 2 +- .../apiv1beta1/Client/ListDatasets/main.go | 2 +- .../Client/ListEvaluationJobs/main.go | 2 +- .../apiv1beta1/Client/ListExamples/main.go | 2 +- .../Client/ListInstructions/main.go | 2 +- .../Client/PauseEvaluationJob/main.go | 2 +- .../Client/ResumeEvaluationJob/main.go | 2 +- .../Client/SearchEvaluations/main.go | 2 +- .../Client/SearchExampleComparisons/main.go | 2 +- .../Client/UpdateEvaluationJob/main.go | 2 +- .../CatalogClient/CancelMetadataJob/main.go | 2 +- .../CatalogClient/CancelOperation/main.go | 2 +- .../CatalogClient/CreateAspectType/main.go | 2 +- .../apiv1/CatalogClient/CreateEntry/main.go | 2 +- .../CatalogClient/CreateEntryGroup/main.go | 2 +- .../CatalogClient/CreateEntryType/main.go | 2 +- .../CatalogClient/CreateMetadataJob/main.go | 2 +- .../CatalogClient/DeleteAspectType/main.go | 2 +- .../apiv1/CatalogClient/DeleteEntry/main.go | 2 +- .../CatalogClient/DeleteEntryGroup/main.go | 2 +- .../CatalogClient/DeleteEntryType/main.go | 2 +- .../CatalogClient/DeleteOperation/main.go | 2 +- .../apiv1/CatalogClient/GetAspectType/main.go | 2 +- .../apiv1/CatalogClient/GetEntry/main.go | 2 +- .../apiv1/CatalogClient/GetEntryGroup/main.go | 2 +- .../apiv1/CatalogClient/GetEntryType/main.go | 2 +- .../apiv1/CatalogClient/GetLocation/main.go | 2 +- .../CatalogClient/GetMetadataJob/main.go | 2 +- .../apiv1/CatalogClient/GetOperation/main.go | 2 +- .../CatalogClient/ListAspectTypes/main.go | 2 +- .../apiv1/CatalogClient/ListEntries/main.go | 2 +- .../CatalogClient/ListEntryGroups/main.go | 2 +- .../CatalogClient/ListEntryTypes/main.go | 2 +- .../apiv1/CatalogClient/ListLocations/main.go | 2 +- .../CatalogClient/ListMetadataJobs/main.go | 2 +- .../CatalogClient/ListOperations/main.go | 2 +- .../apiv1/CatalogClient/LookupEntry/main.go | 2 +- .../apiv1/CatalogClient/SearchEntries/main.go | 2 +- .../CatalogClient/UpdateAspectType/main.go | 2 +- .../apiv1/CatalogClient/UpdateEntry/main.go | 2 +- .../CatalogClient/UpdateEntryGroup/main.go | 2 +- .../CatalogClient/UpdateEntryType/main.go | 2 +- .../dataplex/apiv1/Client/CancelJob/main.go | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../dataplex/apiv1/Client/CreateAsset/main.go | 2 +- .../apiv1/Client/CreateEnvironment/main.go | 2 +- .../dataplex/apiv1/Client/CreateLake/main.go | 2 +- .../dataplex/apiv1/Client/CreateTask/main.go | 2 +- .../dataplex/apiv1/Client/CreateZone/main.go | 2 +- .../dataplex/apiv1/Client/DeleteAsset/main.go | 2 +- .../apiv1/Client/DeleteEnvironment/main.go | 2 +- .../dataplex/apiv1/Client/DeleteLake/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../dataplex/apiv1/Client/DeleteTask/main.go | 2 +- .../dataplex/apiv1/Client/DeleteZone/main.go | 2 +- .../dataplex/apiv1/Client/GetAsset/main.go | 2 +- .../apiv1/Client/GetEnvironment/main.go | 2 +- .../dataplex/apiv1/Client/GetJob/main.go | 2 +- .../dataplex/apiv1/Client/GetLake/main.go | 2 +- .../dataplex/apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../dataplex/apiv1/Client/GetTask/main.go | 2 +- .../dataplex/apiv1/Client/GetZone/main.go | 2 +- .../apiv1/Client/ListAssetActions/main.go | 2 +- .../dataplex/apiv1/Client/ListAssets/main.go | 2 +- .../apiv1/Client/ListEnvironments/main.go | 2 +- .../dataplex/apiv1/Client/ListJobs/main.go | 2 +- .../apiv1/Client/ListLakeActions/main.go | 2 +- .../dataplex/apiv1/Client/ListLakes/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/ListSessions/main.go | 2 +- .../dataplex/apiv1/Client/ListTasks/main.go | 2 +- .../apiv1/Client/ListZoneActions/main.go | 2 +- .../dataplex/apiv1/Client/ListZones/main.go | 2 +- .../dataplex/apiv1/Client/RunTask/main.go | 2 +- .../dataplex/apiv1/Client/UpdateAsset/main.go | 2 +- .../apiv1/Client/UpdateEnvironment/main.go | 2 +- .../dataplex/apiv1/Client/UpdateLake/main.go | 2 +- .../dataplex/apiv1/Client/UpdateTask/main.go | 2 +- .../dataplex/apiv1/Client/UpdateZone/main.go | 2 +- .../ContentClient/CancelOperation/main.go | 2 +- .../apiv1/ContentClient/CreateContent/main.go | 2 +- .../apiv1/ContentClient/DeleteContent/main.go | 2 +- .../ContentClient/DeleteOperation/main.go | 2 +- .../apiv1/ContentClient/GetContent/main.go | 2 +- .../apiv1/ContentClient/GetIamPolicy/main.go | 2 +- .../apiv1/ContentClient/GetLocation/main.go | 2 +- .../apiv1/ContentClient/GetOperation/main.go | 2 +- .../apiv1/ContentClient/ListContent/main.go | 2 +- .../apiv1/ContentClient/ListLocations/main.go | 2 +- .../ContentClient/ListOperations/main.go | 2 +- .../apiv1/ContentClient/SetIamPolicy/main.go | 2 +- .../ContentClient/TestIamPermissions/main.go | 2 +- .../apiv1/ContentClient/UpdateContent/main.go | 2 +- .../DataScanClient/CancelOperation/main.go | 2 +- .../DataScanClient/CreateDataScan/main.go | 2 +- .../DataScanClient/DeleteDataScan/main.go | 2 +- .../DataScanClient/DeleteOperation/main.go | 2 +- .../GenerateDataQualityRules/main.go | 2 +- .../apiv1/DataScanClient/GetDataScan/main.go | 2 +- .../DataScanClient/GetDataScanJob/main.go | 2 +- .../apiv1/DataScanClient/GetLocation/main.go | 2 +- .../apiv1/DataScanClient/GetOperation/main.go | 2 +- .../DataScanClient/ListDataScanJobs/main.go | 2 +- .../DataScanClient/ListDataScans/main.go | 2 +- .../DataScanClient/ListLocations/main.go | 2 +- .../DataScanClient/ListOperations/main.go | 2 +- .../apiv1/DataScanClient/RunDataScan/main.go | 2 +- .../DataScanClient/UpdateDataScan/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateDataAttribute/main.go | 2 +- .../CreateDataAttributeBinding/main.go | 2 +- .../CreateDataTaxonomy/main.go | 2 +- .../DeleteDataAttribute/main.go | 2 +- .../DeleteDataAttributeBinding/main.go | 2 +- .../DeleteDataTaxonomy/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../GetDataAttribute/main.go | 2 +- .../GetDataAttributeBinding/main.go | 2 +- .../GetDataTaxonomy/main.go | 2 +- .../DataTaxonomyClient/GetLocation/main.go | 2 +- .../DataTaxonomyClient/GetOperation/main.go | 2 +- .../ListDataAttributeBindings/main.go | 2 +- .../ListDataAttributes/main.go | 2 +- .../ListDataTaxonomies/main.go | 2 +- .../DataTaxonomyClient/ListLocations/main.go | 2 +- .../DataTaxonomyClient/ListOperations/main.go | 2 +- .../UpdateDataAttribute/main.go | 2 +- .../UpdateDataAttributeBinding/main.go | 2 +- .../UpdateDataTaxonomy/main.go | 2 +- .../MetadataClient/CancelOperation/main.go | 2 +- .../apiv1/MetadataClient/CreateEntity/main.go | 2 +- .../MetadataClient/CreatePartition/main.go | 2 +- .../apiv1/MetadataClient/DeleteEntity/main.go | 2 +- .../MetadataClient/DeleteOperation/main.go | 2 +- .../MetadataClient/DeletePartition/main.go | 2 +- .../apiv1/MetadataClient/GetEntity/main.go | 2 +- .../apiv1/MetadataClient/GetLocation/main.go | 2 +- .../apiv1/MetadataClient/GetOperation/main.go | 2 +- .../apiv1/MetadataClient/GetPartition/main.go | 2 +- .../apiv1/MetadataClient/ListEntities/main.go | 2 +- .../MetadataClient/ListLocations/main.go | 2 +- .../MetadataClient/ListOperations/main.go | 2 +- .../MetadataClient/ListPartitions/main.go | 2 +- .../apiv1/MetadataClient/UpdateEntity/main.go | 2 +- ...pet_metadata.google.cloud.dataplex.v1.json | 2 +- .../CancelOperation/main.go | 2 +- .../CreateAutoscalingPolicy/main.go | 2 +- .../DeleteAutoscalingPolicy/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../GetAutoscalingPolicy/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListAutoscalingPolicies/main.go | 2 +- .../ListOperations/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateAutoscalingPolicy/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../BatchControllerClient/CreateBatch/main.go | 2 +- .../BatchControllerClient/DeleteBatch/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../BatchControllerClient/GetBatch/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetOperation/main.go | 2 +- .../BatchControllerClient/ListBatches/main.go | 2 +- .../ListOperations/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateCluster/main.go | 2 +- .../DeleteCluster/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../DiagnoseCluster/main.go | 2 +- .../GetCluster/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListClusters/main.go | 2 +- .../ListOperations/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../StartCluster/main.go | 2 +- .../StopCluster/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateCluster/main.go | 2 +- .../JobControllerClient/CancelJob/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../JobControllerClient/DeleteJob/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../JobControllerClient/GetIamPolicy/main.go | 2 +- .../apiv1/JobControllerClient/GetJob/main.go | 2 +- .../JobControllerClient/GetOperation/main.go | 2 +- .../JobControllerClient/ListJobs/main.go | 2 +- .../ListOperations/main.go | 2 +- .../JobControllerClient/SetIamPolicy/main.go | 2 +- .../JobControllerClient/SubmitJob/main.go | 2 +- .../SubmitJobAsOperation/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../JobControllerClient/UpdateJob/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateNodeGroup/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetNodeGroup/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ResizeNodeGroup/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateSession/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../DeleteSession/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetSession/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListSessions/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TerminateSession/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateSessionTemplate/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../DeleteSessionTemplate/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetSessionTemplate/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListSessionTemplates/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateSessionTemplate/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateWorkflowTemplate/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../DeleteWorkflowTemplate/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetWorkflowTemplate/main.go | 2 +- .../InstantiateInlineWorkflowTemplate/main.go | 2 +- .../InstantiateWorkflowTemplate/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListWorkflowTemplates/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateWorkflowTemplate/main.go | 2 +- ...pet_metadata.google.cloud.dataproc.v1.json | 2 +- .../SuggestQueries/main.go | 2 +- .../QuestionClient/CreateQuestion/main.go | 2 +- .../QuestionClient/ExecuteQuestion/main.go | 2 +- .../QuestionClient/GetQuestion/main.go | 2 +- .../QuestionClient/GetUserFeedback/main.go | 2 +- .../QuestionClient/UpdateUserFeedback/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../DatastoreAdminClient/CreateIndex/main.go | 2 +- .../DatastoreAdminClient/DeleteIndex/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../ExportEntities/main.go | 2 +- .../DatastoreAdminClient/GetIndex/main.go | 2 +- .../DatastoreAdminClient/GetOperation/main.go | 2 +- .../ImportEntities/main.go | 2 +- .../DatastoreAdminClient/ListIndexes/main.go | 2 +- .../ListOperations/main.go | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../Client/CreateConnectionProfile/main.go | 2 +- .../Client/CreatePrivateConnection/main.go | 2 +- .../apiv1/Client/CreateRoute/main.go | 2 +- .../apiv1/Client/CreateStream/main.go | 2 +- .../Client/DeleteConnectionProfile/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../Client/DeletePrivateConnection/main.go | 2 +- .../apiv1/Client/DeleteRoute/main.go | 2 +- .../apiv1/Client/DeleteStream/main.go | 2 +- .../Client/DiscoverConnectionProfile/main.go | 2 +- .../apiv1/Client/FetchStaticIps/main.go | 2 +- .../apiv1/Client/GetConnectionProfile/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/GetPrivateConnection/main.go | 2 +- .../datastream/apiv1/Client/GetRoute/main.go | 2 +- .../datastream/apiv1/Client/GetStream/main.go | 2 +- .../apiv1/Client/GetStreamObject/main.go | 2 +- .../Client/ListConnectionProfiles/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../Client/ListPrivateConnections/main.go | 2 +- .../apiv1/Client/ListRoutes/main.go | 2 +- .../apiv1/Client/ListStreamObjects/main.go | 2 +- .../apiv1/Client/ListStreams/main.go | 2 +- .../apiv1/Client/LookupStreamObject/main.go | 2 +- .../datastream/apiv1/Client/RunStream/main.go | 2 +- .../apiv1/Client/StartBackfillJob/main.go | 2 +- .../apiv1/Client/StopBackfillJob/main.go | 2 +- .../Client/UpdateConnectionProfile/main.go | 2 +- .../apiv1/Client/UpdateStream/main.go | 2 +- .../Client/CreateConnectionProfile/main.go | 2 +- .../Client/CreatePrivateConnection/main.go | 2 +- .../apiv1alpha1/Client/CreateRoute/main.go | 2 +- .../apiv1alpha1/Client/CreateStream/main.go | 2 +- .../Client/DeleteConnectionProfile/main.go | 2 +- .../Client/DeletePrivateConnection/main.go | 2 +- .../apiv1alpha1/Client/DeleteRoute/main.go | 2 +- .../apiv1alpha1/Client/DeleteStream/main.go | 2 +- .../Client/DiscoverConnectionProfile/main.go | 2 +- .../apiv1alpha1/Client/FetchErrors/main.go | 2 +- .../apiv1alpha1/Client/FetchStaticIps/main.go | 2 +- .../Client/GetConnectionProfile/main.go | 2 +- .../Client/GetPrivateConnection/main.go | 2 +- .../apiv1alpha1/Client/GetRoute/main.go | 2 +- .../apiv1alpha1/Client/GetStream/main.go | 2 +- .../Client/ListConnectionProfiles/main.go | 2 +- .../Client/ListPrivateConnections/main.go | 2 +- .../apiv1alpha1/Client/ListRoutes/main.go | 2 +- .../apiv1alpha1/Client/ListStreams/main.go | 2 +- .../Client/UpdateConnectionProfile/main.go | 2 +- .../apiv1alpha1/Client/UpdateStream/main.go | 2 +- .../CloudDeployClient/AbandonRelease/main.go | 2 +- .../CloudDeployClient/AdvanceRollout/main.go | 2 +- .../CloudDeployClient/ApproveRollout/main.go | 2 +- .../CancelAutomationRun/main.go | 2 +- .../CloudDeployClient/CancelOperation/main.go | 2 +- .../CloudDeployClient/CancelRollout/main.go | 2 +- .../CreateAutomation/main.go | 2 +- .../CreateCustomTargetType/main.go | 2 +- .../CreateDeliveryPipeline/main.go | 2 +- .../CreateDeployPolicy/main.go | 2 +- .../CloudDeployClient/CreateRelease/main.go | 2 +- .../CloudDeployClient/CreateRollout/main.go | 2 +- .../CloudDeployClient/CreateTarget/main.go | 2 +- .../DeleteAutomation/main.go | 2 +- .../DeleteCustomTargetType/main.go | 2 +- .../DeleteDeliveryPipeline/main.go | 2 +- .../DeleteDeployPolicy/main.go | 2 +- .../CloudDeployClient/DeleteOperation/main.go | 2 +- .../CloudDeployClient/DeleteTarget/main.go | 2 +- .../CloudDeployClient/GetAutomation/main.go | 2 +- .../GetAutomationRun/main.go | 2 +- .../apiv1/CloudDeployClient/GetConfig/main.go | 2 +- .../GetCustomTargetType/main.go | 2 +- .../GetDeliveryPipeline/main.go | 2 +- .../CloudDeployClient/GetDeployPolicy/main.go | 2 +- .../CloudDeployClient/GetIamPolicy/main.go | 2 +- .../apiv1/CloudDeployClient/GetJobRun/main.go | 2 +- .../CloudDeployClient/GetLocation/main.go | 2 +- .../CloudDeployClient/GetOperation/main.go | 2 +- .../CloudDeployClient/GetRelease/main.go | 2 +- .../CloudDeployClient/GetRollout/main.go | 2 +- .../apiv1/CloudDeployClient/GetTarget/main.go | 2 +- .../apiv1/CloudDeployClient/IgnoreJob/main.go | 2 +- .../ListAutomationRuns/main.go | 2 +- .../CloudDeployClient/ListAutomations/main.go | 2 +- .../ListCustomTargetTypes/main.go | 2 +- .../ListDeliveryPipelines/main.go | 2 +- .../ListDeployPolicies/main.go | 2 +- .../CloudDeployClient/ListJobRuns/main.go | 2 +- .../CloudDeployClient/ListLocations/main.go | 2 +- .../CloudDeployClient/ListOperations/main.go | 2 +- .../CloudDeployClient/ListReleases/main.go | 2 +- .../CloudDeployClient/ListRollouts/main.go | 2 +- .../CloudDeployClient/ListTargets/main.go | 2 +- .../apiv1/CloudDeployClient/RetryJob/main.go | 2 +- .../CloudDeployClient/RollbackTarget/main.go | 2 +- .../CloudDeployClient/SetIamPolicy/main.go | 2 +- .../CloudDeployClient/TerminateJobRun/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateAutomation/main.go | 2 +- .../UpdateCustomTargetType/main.go | 2 +- .../UpdateDeliveryPipeline/main.go | 2 +- .../UpdateDeployPolicy/main.go | 2 +- .../CloudDeployClient/UpdateTarget/main.go | 2 +- ...ippet_metadata.google.cloud.deploy.v1.json | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apiv1/Client/CreateConnection/main.go | 2 +- .../Client/CreateGitRepositoryLink/main.go | 2 +- .../apiv1/Client/DeleteConnection/main.go | 2 +- .../Client/DeleteGitRepositoryLink/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../Client/FetchGitHubInstallations/main.go | 2 +- .../apiv1/Client/FetchGitRefs/main.go | 2 +- .../FetchLinkableGitRepositories/main.go | 2 +- .../apiv1/Client/FetchReadToken/main.go | 2 +- .../apiv1/Client/FetchReadWriteToken/main.go | 2 +- .../apiv1/Client/GetConnection/main.go | 2 +- .../apiv1/Client/GetGitRepositoryLink/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/ListConnections/main.go | 2 +- .../Client/ListGitRepositoryLinks/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/UpdateConnection/main.go | 2 +- ...data.google.cloud.developerconnect.v1.json | 2 +- .../AgentsClient/CancelOperation/main.go | 2 +- .../apiv2/AgentsClient/DeleteAgent/main.go | 2 +- .../apiv2/AgentsClient/ExportAgent/main.go | 2 +- .../apiv2/AgentsClient/GetAgent/main.go | 2 +- .../apiv2/AgentsClient/GetLocation/main.go | 2 +- .../apiv2/AgentsClient/GetOperation/main.go | 2 +- .../AgentsClient/GetValidationResult/main.go | 2 +- .../apiv2/AgentsClient/ImportAgent/main.go | 2 +- .../apiv2/AgentsClient/ListLocations/main.go | 2 +- .../apiv2/AgentsClient/ListOperations/main.go | 2 +- .../apiv2/AgentsClient/RestoreAgent/main.go | 2 +- .../apiv2/AgentsClient/SearchAgents/main.go | 2 +- .../apiv2/AgentsClient/SetAgent/main.go | 2 +- .../apiv2/AgentsClient/TrainAgent/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../AnswerRecordsClient/GetLocation/main.go | 2 +- .../AnswerRecordsClient/GetOperation/main.go | 2 +- .../ListAnswerRecords/main.go | 2 +- .../AnswerRecordsClient/ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../UpdateAnswerRecord/main.go | 2 +- .../ContextsClient/CancelOperation/main.go | 2 +- .../ContextsClient/CreateContext/main.go | 2 +- .../ContextsClient/DeleteAllContexts/main.go | 2 +- .../ContextsClient/DeleteContext/main.go | 2 +- .../apiv2/ContextsClient/GetContext/main.go | 2 +- .../apiv2/ContextsClient/GetLocation/main.go | 2 +- .../apiv2/ContextsClient/GetOperation/main.go | 2 +- .../apiv2/ContextsClient/ListContexts/main.go | 2 +- .../ContextsClient/ListLocations/main.go | 2 +- .../ContextsClient/ListOperations/main.go | 2 +- .../ContextsClient/UpdateContext/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateConversationDataset/main.go | 2 +- .../DeleteConversationDataset/main.go | 2 +- .../GetConversationDataset/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ImportConversationData/main.go | 2 +- .../ListConversationDatasets/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateConversationModel/main.go | 2 +- .../CreateConversationModelEvaluation/main.go | 2 +- .../DeleteConversationModel/main.go | 2 +- .../DeployConversationModel/main.go | 2 +- .../GetConversationModel/main.go | 2 +- .../GetConversationModelEvaluation/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListConversationModelEvaluations/main.go | 2 +- .../ListConversationModels/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../UndeployConversationModel/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../ClearSuggestionFeatureConfig/main.go | 2 +- .../CreateConversationProfile/main.go | 2 +- .../DeleteConversationProfile/main.go | 2 +- .../GetConversationProfile/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListConversationProfiles/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../SetSuggestionFeatureConfig/main.go | 2 +- .../UpdateConversationProfile/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CompleteConversation/main.go | 2 +- .../CreateConversation/main.go | 2 +- .../GenerateStatelessSuggestion/main.go | 2 +- .../GenerateStatelessSummary/main.go | 2 +- .../GetConversation/main.go | 2 +- .../ConversationsClient/GetLocation/main.go | 2 +- .../ConversationsClient/GetOperation/main.go | 2 +- .../ListConversations/main.go | 2 +- .../ConversationsClient/ListLocations/main.go | 2 +- .../ConversationsClient/ListMessages/main.go | 2 +- .../ListOperations/main.go | 2 +- .../SearchKnowledge/main.go | 2 +- .../SuggestConversationSummary/main.go | 2 +- .../DocumentsClient/CancelOperation/main.go | 2 +- .../DocumentsClient/CreateDocument/main.go | 2 +- .../DocumentsClient/DeleteDocument/main.go | 2 +- .../DocumentsClient/ExportDocument/main.go | 2 +- .../apiv2/DocumentsClient/GetDocument/main.go | 2 +- .../apiv2/DocumentsClient/GetLocation/main.go | 2 +- .../DocumentsClient/GetOperation/main.go | 2 +- .../DocumentsClient/ImportDocuments/main.go | 2 +- .../DocumentsClient/ListDocuments/main.go | 2 +- .../DocumentsClient/ListLocations/main.go | 2 +- .../DocumentsClient/ListOperations/main.go | 2 +- .../DocumentsClient/ReloadDocument/main.go | 2 +- .../DocumentsClient/UpdateDocument/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../GetEncryptionSpec/main.go | 2 +- .../EncryptionSpecClient/GetLocation/main.go | 2 +- .../EncryptionSpecClient/GetOperation/main.go | 2 +- .../InitializeEncryptionSpec/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../BatchCreateEntities/main.go | 2 +- .../BatchDeleteEntities/main.go | 2 +- .../BatchDeleteEntityTypes/main.go | 2 +- .../BatchUpdateEntities/main.go | 2 +- .../BatchUpdateEntityTypes/main.go | 2 +- .../EntityTypesClient/CancelOperation/main.go | 2 +- .../CreateEntityType/main.go | 2 +- .../DeleteEntityType/main.go | 2 +- .../EntityTypesClient/GetEntityType/main.go | 2 +- .../EntityTypesClient/GetLocation/main.go | 2 +- .../EntityTypesClient/GetOperation/main.go | 2 +- .../EntityTypesClient/ListEntityTypes/main.go | 2 +- .../EntityTypesClient/ListLocations/main.go | 2 +- .../EntityTypesClient/ListOperations/main.go | 2 +- .../UpdateEntityType/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateEnvironment/main.go | 2 +- .../DeleteEnvironment/main.go | 2 +- .../EnvironmentsClient/GetEnvironment/main.go | 2 +- .../GetEnvironmentHistory/main.go | 2 +- .../EnvironmentsClient/GetLocation/main.go | 2 +- .../EnvironmentsClient/GetOperation/main.go | 2 +- .../ListEnvironments/main.go | 2 +- .../EnvironmentsClient/ListLocations/main.go | 2 +- .../EnvironmentsClient/ListOperations/main.go | 2 +- .../UpdateEnvironment/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../FulfillmentsClient/GetFulfillment/main.go | 2 +- .../FulfillmentsClient/GetLocation/main.go | 2 +- .../FulfillmentsClient/GetOperation/main.go | 2 +- .../FulfillmentsClient/ListLocations/main.go | 2 +- .../FulfillmentsClient/ListOperations/main.go | 2 +- .../UpdateFulfillment/main.go | 2 +- .../GeneratorsClient/CancelOperation/main.go | 2 +- .../GeneratorsClient/CreateGenerator/main.go | 2 +- .../GeneratorsClient/DeleteGenerator/main.go | 2 +- .../GeneratorsClient/GetGenerator/main.go | 2 +- .../GeneratorsClient/GetLocation/main.go | 2 +- .../GeneratorsClient/GetOperation/main.go | 2 +- .../GeneratorsClient/ListGenerators/main.go | 2 +- .../GeneratorsClient/ListLocations/main.go | 2 +- .../GeneratorsClient/ListOperations/main.go | 2 +- .../GeneratorsClient/UpdateGenerator/main.go | 2 +- .../IntentsClient/BatchDeleteIntents/main.go | 2 +- .../IntentsClient/BatchUpdateIntents/main.go | 2 +- .../IntentsClient/CancelOperation/main.go | 2 +- .../apiv2/IntentsClient/CreateIntent/main.go | 2 +- .../apiv2/IntentsClient/DeleteIntent/main.go | 2 +- .../apiv2/IntentsClient/GetIntent/main.go | 2 +- .../apiv2/IntentsClient/GetLocation/main.go | 2 +- .../apiv2/IntentsClient/GetOperation/main.go | 2 +- .../apiv2/IntentsClient/ListIntents/main.go | 2 +- .../apiv2/IntentsClient/ListLocations/main.go | 2 +- .../IntentsClient/ListOperations/main.go | 2 +- .../apiv2/IntentsClient/UpdateIntent/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateKnowledgeBase/main.go | 2 +- .../DeleteKnowledgeBase/main.go | 2 +- .../GetKnowledgeBase/main.go | 2 +- .../KnowledgeBasesClient/GetLocation/main.go | 2 +- .../KnowledgeBasesClient/GetOperation/main.go | 2 +- .../ListKnowledgeBases/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../UpdateKnowledgeBase/main.go | 2 +- .../ParticipantsClient/AnalyzeContent/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateParticipant/main.go | 2 +- .../ParticipantsClient/GetLocation/main.go | 2 +- .../ParticipantsClient/GetOperation/main.go | 2 +- .../ParticipantsClient/GetParticipant/main.go | 2 +- .../ParticipantsClient/ListLocations/main.go | 2 +- .../ParticipantsClient/ListOperations/main.go | 2 +- .../ListParticipants/main.go | 2 +- .../StreamingAnalyzeContent/main.go | 2 +- .../SuggestArticles/main.go | 2 +- .../SuggestFaqAnswers/main.go | 2 +- .../SuggestKnowledgeAssist/main.go | 2 +- .../SuggestSmartReplies/main.go | 2 +- .../UpdateParticipant/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateSessionEntityType/main.go | 2 +- .../DeleteSessionEntityType/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetSessionEntityType/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListSessionEntityTypes/main.go | 2 +- .../UpdateSessionEntityType/main.go | 2 +- .../SessionsClient/CancelOperation/main.go | 2 +- .../apiv2/SessionsClient/DetectIntent/main.go | 2 +- .../apiv2/SessionsClient/GetLocation/main.go | 2 +- .../apiv2/SessionsClient/GetOperation/main.go | 2 +- .../SessionsClient/ListLocations/main.go | 2 +- .../SessionsClient/ListOperations/main.go | 2 +- .../StreamingDetectIntent/main.go | 2 +- .../VersionsClient/CancelOperation/main.go | 2 +- .../VersionsClient/CreateVersion/main.go | 2 +- .../VersionsClient/DeleteVersion/main.go | 2 +- .../apiv2/VersionsClient/GetLocation/main.go | 2 +- .../apiv2/VersionsClient/GetOperation/main.go | 2 +- .../apiv2/VersionsClient/GetVersion/main.go | 2 +- .../VersionsClient/ListLocations/main.go | 2 +- .../VersionsClient/ListOperations/main.go | 2 +- .../apiv2/VersionsClient/ListVersions/main.go | 2 +- .../VersionsClient/UpdateVersion/main.go | 2 +- ...t_metadata.google.cloud.dialogflow.v2.json | 2 +- .../AgentsClient/CancelOperation/main.go | 2 +- .../AgentsClient/DeleteAgent/main.go | 2 +- .../AgentsClient/ExportAgent/main.go | 2 +- .../apiv2beta1/AgentsClient/GetAgent/main.go | 2 +- .../AgentsClient/GetLocation/main.go | 2 +- .../AgentsClient/GetOperation/main.go | 2 +- .../AgentsClient/GetValidationResult/main.go | 2 +- .../AgentsClient/ImportAgent/main.go | 2 +- .../AgentsClient/ListLocations/main.go | 2 +- .../AgentsClient/ListOperations/main.go | 2 +- .../AgentsClient/RestoreAgent/main.go | 2 +- .../AgentsClient/SearchAgents/main.go | 2 +- .../apiv2beta1/AgentsClient/SetAgent/main.go | 2 +- .../AgentsClient/TrainAgent/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../GetAnswerRecord/main.go | 2 +- .../AnswerRecordsClient/GetLocation/main.go | 2 +- .../AnswerRecordsClient/GetOperation/main.go | 2 +- .../ListAnswerRecords/main.go | 2 +- .../AnswerRecordsClient/ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../UpdateAnswerRecord/main.go | 2 +- .../ContextsClient/CancelOperation/main.go | 2 +- .../ContextsClient/CreateContext/main.go | 2 +- .../ContextsClient/DeleteAllContexts/main.go | 2 +- .../ContextsClient/DeleteContext/main.go | 2 +- .../ContextsClient/GetContext/main.go | 2 +- .../ContextsClient/GetLocation/main.go | 2 +- .../ContextsClient/GetOperation/main.go | 2 +- .../ContextsClient/ListContexts/main.go | 2 +- .../ContextsClient/ListLocations/main.go | 2 +- .../ContextsClient/ListOperations/main.go | 2 +- .../ContextsClient/UpdateContext/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../ClearSuggestionFeatureConfig/main.go | 2 +- .../CreateConversationProfile/main.go | 2 +- .../DeleteConversationProfile/main.go | 2 +- .../GetConversationProfile/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListConversationProfiles/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../SetSuggestionFeatureConfig/main.go | 2 +- .../UpdateConversationProfile/main.go | 2 +- .../BatchCreateMessages/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CompleteConversation/main.go | 2 +- .../CreateConversation/main.go | 2 +- .../GenerateStatelessSuggestion/main.go | 2 +- .../GenerateStatelessSummary/main.go | 2 +- .../GetConversation/main.go | 2 +- .../ConversationsClient/GetLocation/main.go | 2 +- .../ConversationsClient/GetOperation/main.go | 2 +- .../ListConversations/main.go | 2 +- .../ConversationsClient/ListLocations/main.go | 2 +- .../ConversationsClient/ListMessages/main.go | 2 +- .../ListOperations/main.go | 2 +- .../SearchKnowledge/main.go | 2 +- .../SuggestConversationSummary/main.go | 2 +- .../DocumentsClient/CancelOperation/main.go | 2 +- .../DocumentsClient/CreateDocument/main.go | 2 +- .../DocumentsClient/DeleteDocument/main.go | 2 +- .../DocumentsClient/GetDocument/main.go | 2 +- .../DocumentsClient/GetLocation/main.go | 2 +- .../DocumentsClient/GetOperation/main.go | 2 +- .../DocumentsClient/ImportDocuments/main.go | 2 +- .../DocumentsClient/ListDocuments/main.go | 2 +- .../DocumentsClient/ListLocations/main.go | 2 +- .../DocumentsClient/ListOperations/main.go | 2 +- .../DocumentsClient/ReloadDocument/main.go | 2 +- .../DocumentsClient/UpdateDocument/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../GetEncryptionSpec/main.go | 2 +- .../EncryptionSpecClient/GetLocation/main.go | 2 +- .../EncryptionSpecClient/GetOperation/main.go | 2 +- .../InitializeEncryptionSpec/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../BatchCreateEntities/main.go | 2 +- .../BatchDeleteEntities/main.go | 2 +- .../BatchDeleteEntityTypes/main.go | 2 +- .../BatchUpdateEntities/main.go | 2 +- .../BatchUpdateEntityTypes/main.go | 2 +- .../EntityTypesClient/CancelOperation/main.go | 2 +- .../CreateEntityType/main.go | 2 +- .../DeleteEntityType/main.go | 2 +- .../EntityTypesClient/GetEntityType/main.go | 2 +- .../EntityTypesClient/GetLocation/main.go | 2 +- .../EntityTypesClient/GetOperation/main.go | 2 +- .../EntityTypesClient/ListEntityTypes/main.go | 2 +- .../EntityTypesClient/ListLocations/main.go | 2 +- .../EntityTypesClient/ListOperations/main.go | 2 +- .../UpdateEntityType/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateEnvironment/main.go | 2 +- .../DeleteEnvironment/main.go | 2 +- .../EnvironmentsClient/GetEnvironment/main.go | 2 +- .../GetEnvironmentHistory/main.go | 2 +- .../EnvironmentsClient/GetLocation/main.go | 2 +- .../EnvironmentsClient/GetOperation/main.go | 2 +- .../ListEnvironments/main.go | 2 +- .../EnvironmentsClient/ListLocations/main.go | 2 +- .../EnvironmentsClient/ListOperations/main.go | 2 +- .../UpdateEnvironment/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../FulfillmentsClient/GetFulfillment/main.go | 2 +- .../FulfillmentsClient/GetLocation/main.go | 2 +- .../FulfillmentsClient/GetOperation/main.go | 2 +- .../FulfillmentsClient/ListLocations/main.go | 2 +- .../FulfillmentsClient/ListOperations/main.go | 2 +- .../UpdateFulfillment/main.go | 2 +- .../GeneratorsClient/CancelOperation/main.go | 2 +- .../GeneratorsClient/CreateGenerator/main.go | 2 +- .../GeneratorsClient/DeleteGenerator/main.go | 2 +- .../GeneratorsClient/GetGenerator/main.go | 2 +- .../GeneratorsClient/GetLocation/main.go | 2 +- .../GeneratorsClient/GetOperation/main.go | 2 +- .../GeneratorsClient/ListGenerators/main.go | 2 +- .../GeneratorsClient/ListLocations/main.go | 2 +- .../GeneratorsClient/ListOperations/main.go | 2 +- .../GeneratorsClient/UpdateGenerator/main.go | 2 +- .../IntentsClient/BatchDeleteIntents/main.go | 2 +- .../IntentsClient/BatchUpdateIntents/main.go | 2 +- .../IntentsClient/CancelOperation/main.go | 2 +- .../IntentsClient/CreateIntent/main.go | 2 +- .../IntentsClient/DeleteIntent/main.go | 2 +- .../IntentsClient/GetIntent/main.go | 2 +- .../IntentsClient/GetLocation/main.go | 2 +- .../IntentsClient/GetOperation/main.go | 2 +- .../IntentsClient/ListIntents/main.go | 2 +- .../IntentsClient/ListLocations/main.go | 2 +- .../IntentsClient/ListOperations/main.go | 2 +- .../IntentsClient/UpdateIntent/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateKnowledgeBase/main.go | 2 +- .../DeleteKnowledgeBase/main.go | 2 +- .../GetKnowledgeBase/main.go | 2 +- .../KnowledgeBasesClient/GetLocation/main.go | 2 +- .../KnowledgeBasesClient/GetOperation/main.go | 2 +- .../ListKnowledgeBases/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../UpdateKnowledgeBase/main.go | 2 +- .../ParticipantsClient/AnalyzeContent/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CompileSuggestion/main.go | 2 +- .../CreateParticipant/main.go | 2 +- .../ParticipantsClient/GetLocation/main.go | 2 +- .../ParticipantsClient/GetOperation/main.go | 2 +- .../ParticipantsClient/GetParticipant/main.go | 2 +- .../ParticipantsClient/ListLocations/main.go | 2 +- .../ParticipantsClient/ListOperations/main.go | 2 +- .../ListParticipants/main.go | 2 +- .../ListSuggestions/main.go | 2 +- .../StreamingAnalyzeContent/main.go | 2 +- .../SuggestArticles/main.go | 2 +- .../SuggestFaqAnswers/main.go | 2 +- .../SuggestKnowledgeAssist/main.go | 2 +- .../SuggestSmartReplies/main.go | 2 +- .../UpdateParticipant/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateSessionEntityType/main.go | 2 +- .../DeleteSessionEntityType/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetSessionEntityType/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListSessionEntityTypes/main.go | 2 +- .../UpdateSessionEntityType/main.go | 2 +- .../SessionsClient/CancelOperation/main.go | 2 +- .../SessionsClient/DetectIntent/main.go | 2 +- .../SessionsClient/GetLocation/main.go | 2 +- .../SessionsClient/GetOperation/main.go | 2 +- .../SessionsClient/ListLocations/main.go | 2 +- .../SessionsClient/ListOperations/main.go | 2 +- .../StreamingDetectIntent/main.go | 2 +- .../SipTrunksClient/CancelOperation/main.go | 2 +- .../SipTrunksClient/CreateSipTrunk/main.go | 2 +- .../SipTrunksClient/DeleteSipTrunk/main.go | 2 +- .../SipTrunksClient/GetLocation/main.go | 2 +- .../SipTrunksClient/GetOperation/main.go | 2 +- .../SipTrunksClient/GetSipTrunk/main.go | 2 +- .../SipTrunksClient/ListLocations/main.go | 2 +- .../SipTrunksClient/ListOperations/main.go | 2 +- .../SipTrunksClient/ListSipTrunks/main.go | 2 +- .../SipTrunksClient/UpdateSipTrunk/main.go | 2 +- .../VersionsClient/CancelOperation/main.go | 2 +- .../VersionsClient/CreateVersion/main.go | 2 +- .../VersionsClient/DeleteVersion/main.go | 2 +- .../VersionsClient/GetLocation/main.go | 2 +- .../VersionsClient/GetOperation/main.go | 2 +- .../VersionsClient/GetVersion/main.go | 2 +- .../VersionsClient/ListLocations/main.go | 2 +- .../VersionsClient/ListOperations/main.go | 2 +- .../VersionsClient/ListVersions/main.go | 2 +- .../VersionsClient/UpdateVersion/main.go | 2 +- ...adata.google.cloud.dialogflow.v2beta1.json | 2 +- .../AgentsClient/CancelOperation/main.go | 2 +- .../cx/apiv3/AgentsClient/CreateAgent/main.go | 2 +- .../cx/apiv3/AgentsClient/DeleteAgent/main.go | 2 +- .../cx/apiv3/AgentsClient/ExportAgent/main.go | 2 +- .../cx/apiv3/AgentsClient/GetAgent/main.go | 2 +- .../GetAgentValidationResult/main.go | 2 +- .../GetGenerativeSettings/main.go | 2 +- .../cx/apiv3/AgentsClient/GetLocation/main.go | 2 +- .../apiv3/AgentsClient/GetOperation/main.go | 2 +- .../cx/apiv3/AgentsClient/ListAgents/main.go | 2 +- .../apiv3/AgentsClient/ListLocations/main.go | 2 +- .../apiv3/AgentsClient/ListOperations/main.go | 2 +- .../apiv3/AgentsClient/RestoreAgent/main.go | 2 +- .../cx/apiv3/AgentsClient/UpdateAgent/main.go | 2 +- .../UpdateGenerativeSettings/main.go | 2 +- .../apiv3/AgentsClient/ValidateAgent/main.go | 2 +- .../ChangelogsClient/CancelOperation/main.go | 2 +- .../ChangelogsClient/GetChangelog/main.go | 2 +- .../ChangelogsClient/GetLocation/main.go | 2 +- .../ChangelogsClient/GetOperation/main.go | 2 +- .../ChangelogsClient/ListChangelogs/main.go | 2 +- .../ChangelogsClient/ListLocations/main.go | 2 +- .../ChangelogsClient/ListOperations/main.go | 2 +- .../DeploymentsClient/CancelOperation/main.go | 2 +- .../DeploymentsClient/GetDeployment/main.go | 2 +- .../DeploymentsClient/GetLocation/main.go | 2 +- .../DeploymentsClient/GetOperation/main.go | 2 +- .../DeploymentsClient/ListDeployments/main.go | 2 +- .../DeploymentsClient/ListLocations/main.go | 2 +- .../DeploymentsClient/ListOperations/main.go | 2 +- .../EntityTypesClient/CancelOperation/main.go | 2 +- .../CreateEntityType/main.go | 2 +- .../DeleteEntityType/main.go | 2 +- .../ExportEntityTypes/main.go | 2 +- .../EntityTypesClient/GetEntityType/main.go | 2 +- .../EntityTypesClient/GetLocation/main.go | 2 +- .../EntityTypesClient/GetOperation/main.go | 2 +- .../ImportEntityTypes/main.go | 2 +- .../EntityTypesClient/ListEntityTypes/main.go | 2 +- .../EntityTypesClient/ListLocations/main.go | 2 +- .../EntityTypesClient/ListOperations/main.go | 2 +- .../UpdateEntityType/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateEnvironment/main.go | 2 +- .../DeleteEnvironment/main.go | 2 +- .../EnvironmentsClient/DeployFlow/main.go | 2 +- .../EnvironmentsClient/GetEnvironment/main.go | 2 +- .../EnvironmentsClient/GetLocation/main.go | 2 +- .../EnvironmentsClient/GetOperation/main.go | 2 +- .../ListContinuousTestResults/main.go | 2 +- .../ListEnvironments/main.go | 2 +- .../EnvironmentsClient/ListLocations/main.go | 2 +- .../EnvironmentsClient/ListOperations/main.go | 2 +- .../LookupEnvironmentHistory/main.go | 2 +- .../RunContinuousTest/main.go | 2 +- .../UpdateEnvironment/main.go | 2 +- .../ExperimentsClient/CancelOperation/main.go | 2 +- .../CreateExperiment/main.go | 2 +- .../DeleteExperiment/main.go | 2 +- .../ExperimentsClient/GetExperiment/main.go | 2 +- .../ExperimentsClient/GetLocation/main.go | 2 +- .../ExperimentsClient/GetOperation/main.go | 2 +- .../ExperimentsClient/ListExperiments/main.go | 2 +- .../ExperimentsClient/ListLocations/main.go | 2 +- .../ExperimentsClient/ListOperations/main.go | 2 +- .../ExperimentsClient/StartExperiment/main.go | 2 +- .../ExperimentsClient/StopExperiment/main.go | 2 +- .../UpdateExperiment/main.go | 2 +- .../apiv3/FlowsClient/CancelOperation/main.go | 2 +- .../cx/apiv3/FlowsClient/CreateFlow/main.go | 2 +- .../cx/apiv3/FlowsClient/DeleteFlow/main.go | 2 +- .../cx/apiv3/FlowsClient/ExportFlow/main.go | 2 +- .../cx/apiv3/FlowsClient/GetFlow/main.go | 2 +- .../GetFlowValidationResult/main.go | 2 +- .../cx/apiv3/FlowsClient/GetLocation/main.go | 2 +- .../cx/apiv3/FlowsClient/GetOperation/main.go | 2 +- .../cx/apiv3/FlowsClient/ImportFlow/main.go | 2 +- .../cx/apiv3/FlowsClient/ListFlows/main.go | 2 +- .../apiv3/FlowsClient/ListLocations/main.go | 2 +- .../apiv3/FlowsClient/ListOperations/main.go | 2 +- .../cx/apiv3/FlowsClient/TrainFlow/main.go | 2 +- .../cx/apiv3/FlowsClient/UpdateFlow/main.go | 2 +- .../cx/apiv3/FlowsClient/ValidateFlow/main.go | 2 +- .../GeneratorsClient/CancelOperation/main.go | 2 +- .../GeneratorsClient/CreateGenerator/main.go | 2 +- .../GeneratorsClient/DeleteGenerator/main.go | 2 +- .../GeneratorsClient/GetGenerator/main.go | 2 +- .../GeneratorsClient/GetLocation/main.go | 2 +- .../GeneratorsClient/GetOperation/main.go | 2 +- .../GeneratorsClient/ListGenerators/main.go | 2 +- .../GeneratorsClient/ListLocations/main.go | 2 +- .../GeneratorsClient/ListOperations/main.go | 2 +- .../GeneratorsClient/UpdateGenerator/main.go | 2 +- .../IntentsClient/CancelOperation/main.go | 2 +- .../apiv3/IntentsClient/CreateIntent/main.go | 2 +- .../apiv3/IntentsClient/DeleteIntent/main.go | 2 +- .../apiv3/IntentsClient/ExportIntents/main.go | 2 +- .../cx/apiv3/IntentsClient/GetIntent/main.go | 2 +- .../apiv3/IntentsClient/GetLocation/main.go | 2 +- .../apiv3/IntentsClient/GetOperation/main.go | 2 +- .../apiv3/IntentsClient/ImportIntents/main.go | 2 +- .../apiv3/IntentsClient/ListIntents/main.go | 2 +- .../apiv3/IntentsClient/ListLocations/main.go | 2 +- .../IntentsClient/ListOperations/main.go | 2 +- .../apiv3/IntentsClient/UpdateIntent/main.go | 2 +- .../apiv3/PagesClient/CancelOperation/main.go | 2 +- .../cx/apiv3/PagesClient/CreatePage/main.go | 2 +- .../cx/apiv3/PagesClient/DeletePage/main.go | 2 +- .../cx/apiv3/PagesClient/GetLocation/main.go | 2 +- .../cx/apiv3/PagesClient/GetOperation/main.go | 2 +- .../cx/apiv3/PagesClient/GetPage/main.go | 2 +- .../apiv3/PagesClient/ListLocations/main.go | 2 +- .../apiv3/PagesClient/ListOperations/main.go | 2 +- .../cx/apiv3/PagesClient/ListPages/main.go | 2 +- .../cx/apiv3/PagesClient/UpdatePage/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateSecuritySettings/main.go | 2 +- .../DeleteSecuritySettings/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetSecuritySettings/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListSecuritySettings/main.go | 2 +- .../UpdateSecuritySettings/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateSessionEntityType/main.go | 2 +- .../DeleteSessionEntityType/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetSessionEntityType/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListSessionEntityTypes/main.go | 2 +- .../UpdateSessionEntityType/main.go | 2 +- .../SessionsClient/CancelOperation/main.go | 2 +- .../apiv3/SessionsClient/DetectIntent/main.go | 2 +- .../SessionsClient/FulfillIntent/main.go | 2 +- .../apiv3/SessionsClient/GetLocation/main.go | 2 +- .../apiv3/SessionsClient/GetOperation/main.go | 2 +- .../SessionsClient/ListLocations/main.go | 2 +- .../SessionsClient/ListOperations/main.go | 2 +- .../apiv3/SessionsClient/MatchIntent/main.go | 2 +- .../StreamingDetectIntent/main.go | 2 +- .../SubmitAnswerFeedback/main.go | 2 +- .../BatchDeleteTestCases/main.go | 2 +- .../TestCasesClient/BatchRunTestCases/main.go | 2 +- .../TestCasesClient/CalculateCoverage/main.go | 2 +- .../TestCasesClient/CancelOperation/main.go | 2 +- .../TestCasesClient/CreateTestCase/main.go | 2 +- .../TestCasesClient/ExportTestCases/main.go | 2 +- .../apiv3/TestCasesClient/GetLocation/main.go | 2 +- .../TestCasesClient/GetOperation/main.go | 2 +- .../apiv3/TestCasesClient/GetTestCase/main.go | 2 +- .../TestCasesClient/GetTestCaseResult/main.go | 2 +- .../TestCasesClient/ImportTestCases/main.go | 2 +- .../TestCasesClient/ListLocations/main.go | 2 +- .../TestCasesClient/ListOperations/main.go | 2 +- .../ListTestCaseResults/main.go | 2 +- .../TestCasesClient/ListTestCases/main.go | 2 +- .../apiv3/TestCasesClient/RunTestCase/main.go | 2 +- .../TestCasesClient/UpdateTestCase/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateTransitionRouteGroup/main.go | 2 +- .../DeleteTransitionRouteGroup/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetTransitionRouteGroup/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListTransitionRouteGroups/main.go | 2 +- .../UpdateTransitionRouteGroup/main.go | 2 +- .../VersionsClient/CancelOperation/main.go | 2 +- .../VersionsClient/CompareVersions/main.go | 2 +- .../VersionsClient/CreateVersion/main.go | 2 +- .../VersionsClient/DeleteVersion/main.go | 2 +- .../apiv3/VersionsClient/GetLocation/main.go | 2 +- .../apiv3/VersionsClient/GetOperation/main.go | 2 +- .../apiv3/VersionsClient/GetVersion/main.go | 2 +- .../VersionsClient/ListLocations/main.go | 2 +- .../VersionsClient/ListOperations/main.go | 2 +- .../apiv3/VersionsClient/ListVersions/main.go | 2 +- .../apiv3/VersionsClient/LoadVersion/main.go | 2 +- .../VersionsClient/UpdateVersion/main.go | 2 +- .../WebhooksClient/CancelOperation/main.go | 2 +- .../WebhooksClient/CreateWebhook/main.go | 2 +- .../WebhooksClient/DeleteWebhook/main.go | 2 +- .../apiv3/WebhooksClient/GetLocation/main.go | 2 +- .../apiv3/WebhooksClient/GetOperation/main.go | 2 +- .../apiv3/WebhooksClient/GetWebhook/main.go | 2 +- .../WebhooksClient/ListLocations/main.go | 2 +- .../WebhooksClient/ListOperations/main.go | 2 +- .../apiv3/WebhooksClient/ListWebhooks/main.go | 2 +- .../WebhooksClient/UpdateWebhook/main.go | 2 +- ...etadata.google.cloud.dialogflow.cx.v3.json | 2 +- .../AgentsClient/CancelOperation/main.go | 2 +- .../AgentsClient/CreateAgent/main.go | 2 +- .../AgentsClient/DeleteAgent/main.go | 2 +- .../AgentsClient/ExportAgent/main.go | 2 +- .../apiv3beta1/AgentsClient/GetAgent/main.go | 2 +- .../GetAgentValidationResult/main.go | 2 +- .../GetGenerativeSettings/main.go | 2 +- .../AgentsClient/GetLocation/main.go | 2 +- .../AgentsClient/GetOperation/main.go | 2 +- .../AgentsClient/ListAgents/main.go | 2 +- .../AgentsClient/ListLocations/main.go | 2 +- .../AgentsClient/ListOperations/main.go | 2 +- .../AgentsClient/RestoreAgent/main.go | 2 +- .../AgentsClient/UpdateAgent/main.go | 2 +- .../UpdateGenerativeSettings/main.go | 2 +- .../AgentsClient/ValidateAgent/main.go | 2 +- .../ChangelogsClient/CancelOperation/main.go | 2 +- .../ChangelogsClient/GetChangelog/main.go | 2 +- .../ChangelogsClient/GetLocation/main.go | 2 +- .../ChangelogsClient/GetOperation/main.go | 2 +- .../ChangelogsClient/ListChangelogs/main.go | 2 +- .../ChangelogsClient/ListLocations/main.go | 2 +- .../ChangelogsClient/ListOperations/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../DeleteConversation/main.go | 2 +- .../GetConversation/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListConversations/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../DeploymentsClient/CancelOperation/main.go | 2 +- .../DeploymentsClient/GetDeployment/main.go | 2 +- .../DeploymentsClient/GetLocation/main.go | 2 +- .../DeploymentsClient/GetOperation/main.go | 2 +- .../DeploymentsClient/ListDeployments/main.go | 2 +- .../DeploymentsClient/ListLocations/main.go | 2 +- .../DeploymentsClient/ListOperations/main.go | 2 +- .../EntityTypesClient/CancelOperation/main.go | 2 +- .../CreateEntityType/main.go | 2 +- .../DeleteEntityType/main.go | 2 +- .../ExportEntityTypes/main.go | 2 +- .../EntityTypesClient/GetEntityType/main.go | 2 +- .../EntityTypesClient/GetLocation/main.go | 2 +- .../EntityTypesClient/GetOperation/main.go | 2 +- .../ImportEntityTypes/main.go | 2 +- .../EntityTypesClient/ListEntityTypes/main.go | 2 +- .../EntityTypesClient/ListLocations/main.go | 2 +- .../EntityTypesClient/ListOperations/main.go | 2 +- .../UpdateEntityType/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateEnvironment/main.go | 2 +- .../DeleteEnvironment/main.go | 2 +- .../EnvironmentsClient/DeployFlow/main.go | 2 +- .../EnvironmentsClient/GetEnvironment/main.go | 2 +- .../EnvironmentsClient/GetLocation/main.go | 2 +- .../EnvironmentsClient/GetOperation/main.go | 2 +- .../ListContinuousTestResults/main.go | 2 +- .../ListEnvironments/main.go | 2 +- .../EnvironmentsClient/ListLocations/main.go | 2 +- .../EnvironmentsClient/ListOperations/main.go | 2 +- .../LookupEnvironmentHistory/main.go | 2 +- .../RunContinuousTest/main.go | 2 +- .../UpdateEnvironment/main.go | 2 +- .../ExamplesClient/CancelOperation/main.go | 2 +- .../ExamplesClient/CreateExample/main.go | 2 +- .../ExamplesClient/DeleteExample/main.go | 2 +- .../ExamplesClient/GetExample/main.go | 2 +- .../ExamplesClient/GetLocation/main.go | 2 +- .../ExamplesClient/GetOperation/main.go | 2 +- .../ExamplesClient/ListExamples/main.go | 2 +- .../ExamplesClient/ListLocations/main.go | 2 +- .../ExamplesClient/ListOperations/main.go | 2 +- .../ExamplesClient/UpdateExample/main.go | 2 +- .../ExperimentsClient/CancelOperation/main.go | 2 +- .../CreateExperiment/main.go | 2 +- .../DeleteExperiment/main.go | 2 +- .../ExperimentsClient/GetExperiment/main.go | 2 +- .../ExperimentsClient/GetLocation/main.go | 2 +- .../ExperimentsClient/GetOperation/main.go | 2 +- .../ExperimentsClient/ListExperiments/main.go | 2 +- .../ExperimentsClient/ListLocations/main.go | 2 +- .../ExperimentsClient/ListOperations/main.go | 2 +- .../ExperimentsClient/StartExperiment/main.go | 2 +- .../ExperimentsClient/StopExperiment/main.go | 2 +- .../UpdateExperiment/main.go | 2 +- .../FlowsClient/CancelOperation/main.go | 2 +- .../apiv3beta1/FlowsClient/CreateFlow/main.go | 2 +- .../apiv3beta1/FlowsClient/DeleteFlow/main.go | 2 +- .../apiv3beta1/FlowsClient/ExportFlow/main.go | 2 +- .../cx/apiv3beta1/FlowsClient/GetFlow/main.go | 2 +- .../GetFlowValidationResult/main.go | 2 +- .../FlowsClient/GetLocation/main.go | 2 +- .../FlowsClient/GetOperation/main.go | 2 +- .../apiv3beta1/FlowsClient/ImportFlow/main.go | 2 +- .../apiv3beta1/FlowsClient/ListFlows/main.go | 2 +- .../FlowsClient/ListLocations/main.go | 2 +- .../FlowsClient/ListOperations/main.go | 2 +- .../apiv3beta1/FlowsClient/TrainFlow/main.go | 2 +- .../apiv3beta1/FlowsClient/UpdateFlow/main.go | 2 +- .../FlowsClient/ValidateFlow/main.go | 2 +- .../GeneratorsClient/CancelOperation/main.go | 2 +- .../GeneratorsClient/CreateGenerator/main.go | 2 +- .../GeneratorsClient/DeleteGenerator/main.go | 2 +- .../GeneratorsClient/GetGenerator/main.go | 2 +- .../GeneratorsClient/GetLocation/main.go | 2 +- .../GeneratorsClient/GetOperation/main.go | 2 +- .../GeneratorsClient/ListGenerators/main.go | 2 +- .../GeneratorsClient/ListLocations/main.go | 2 +- .../GeneratorsClient/ListOperations/main.go | 2 +- .../GeneratorsClient/UpdateGenerator/main.go | 2 +- .../IntentsClient/CancelOperation/main.go | 2 +- .../IntentsClient/CreateIntent/main.go | 2 +- .../IntentsClient/DeleteIntent/main.go | 2 +- .../IntentsClient/ExportIntents/main.go | 2 +- .../IntentsClient/GetIntent/main.go | 2 +- .../IntentsClient/GetLocation/main.go | 2 +- .../IntentsClient/GetOperation/main.go | 2 +- .../IntentsClient/ImportIntents/main.go | 2 +- .../IntentsClient/ListIntents/main.go | 2 +- .../IntentsClient/ListLocations/main.go | 2 +- .../IntentsClient/ListOperations/main.go | 2 +- .../IntentsClient/UpdateIntent/main.go | 2 +- .../PagesClient/CancelOperation/main.go | 2 +- .../apiv3beta1/PagesClient/CreatePage/main.go | 2 +- .../apiv3beta1/PagesClient/DeletePage/main.go | 2 +- .../PagesClient/GetLocation/main.go | 2 +- .../PagesClient/GetOperation/main.go | 2 +- .../cx/apiv3beta1/PagesClient/GetPage/main.go | 2 +- .../PagesClient/ListLocations/main.go | 2 +- .../PagesClient/ListOperations/main.go | 2 +- .../apiv3beta1/PagesClient/ListPages/main.go | 2 +- .../apiv3beta1/PagesClient/UpdatePage/main.go | 2 +- .../PlaybooksClient/CancelOperation/main.go | 2 +- .../PlaybooksClient/CreatePlaybook/main.go | 2 +- .../CreatePlaybookVersion/main.go | 2 +- .../PlaybooksClient/DeletePlaybook/main.go | 2 +- .../DeletePlaybookVersion/main.go | 2 +- .../PlaybooksClient/GetLocation/main.go | 2 +- .../PlaybooksClient/GetOperation/main.go | 2 +- .../PlaybooksClient/GetPlaybook/main.go | 2 +- .../GetPlaybookVersion/main.go | 2 +- .../PlaybooksClient/ListLocations/main.go | 2 +- .../PlaybooksClient/ListOperations/main.go | 2 +- .../ListPlaybookVersions/main.go | 2 +- .../PlaybooksClient/ListPlaybooks/main.go | 2 +- .../PlaybooksClient/UpdatePlaybook/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateSecuritySettings/main.go | 2 +- .../DeleteSecuritySettings/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetSecuritySettings/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListSecuritySettings/main.go | 2 +- .../UpdateSecuritySettings/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateSessionEntityType/main.go | 2 +- .../DeleteSessionEntityType/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetSessionEntityType/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListSessionEntityTypes/main.go | 2 +- .../UpdateSessionEntityType/main.go | 2 +- .../SessionsClient/CancelOperation/main.go | 2 +- .../SessionsClient/DetectIntent/main.go | 2 +- .../SessionsClient/FulfillIntent/main.go | 2 +- .../SessionsClient/GetLocation/main.go | 2 +- .../SessionsClient/GetOperation/main.go | 2 +- .../SessionsClient/ListLocations/main.go | 2 +- .../SessionsClient/ListOperations/main.go | 2 +- .../SessionsClient/MatchIntent/main.go | 2 +- .../StreamingDetectIntent/main.go | 2 +- .../SubmitAnswerFeedback/main.go | 2 +- .../BatchDeleteTestCases/main.go | 2 +- .../TestCasesClient/BatchRunTestCases/main.go | 2 +- .../TestCasesClient/CalculateCoverage/main.go | 2 +- .../TestCasesClient/CancelOperation/main.go | 2 +- .../TestCasesClient/CreateTestCase/main.go | 2 +- .../TestCasesClient/ExportTestCases/main.go | 2 +- .../TestCasesClient/GetLocation/main.go | 2 +- .../TestCasesClient/GetOperation/main.go | 2 +- .../TestCasesClient/GetTestCase/main.go | 2 +- .../TestCasesClient/GetTestCaseResult/main.go | 2 +- .../TestCasesClient/ImportTestCases/main.go | 2 +- .../TestCasesClient/ListLocations/main.go | 2 +- .../TestCasesClient/ListOperations/main.go | 2 +- .../ListTestCaseResults/main.go | 2 +- .../TestCasesClient/ListTestCases/main.go | 2 +- .../TestCasesClient/RunTestCase/main.go | 2 +- .../TestCasesClient/UpdateTestCase/main.go | 2 +- .../ToolsClient/CancelOperation/main.go | 2 +- .../apiv3beta1/ToolsClient/CreateTool/main.go | 2 +- .../apiv3beta1/ToolsClient/DeleteTool/main.go | 2 +- .../ToolsClient/ExportTools/main.go | 2 +- .../ToolsClient/GetLocation/main.go | 2 +- .../ToolsClient/GetOperation/main.go | 2 +- .../cx/apiv3beta1/ToolsClient/GetTool/main.go | 2 +- .../ToolsClient/ListLocations/main.go | 2 +- .../ToolsClient/ListOperations/main.go | 2 +- .../apiv3beta1/ToolsClient/ListTools/main.go | 2 +- .../apiv3beta1/ToolsClient/UpdateTool/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateTransitionRouteGroup/main.go | 2 +- .../DeleteTransitionRouteGroup/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetTransitionRouteGroup/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListTransitionRouteGroups/main.go | 2 +- .../UpdateTransitionRouteGroup/main.go | 2 +- .../VersionsClient/CancelOperation/main.go | 2 +- .../VersionsClient/CompareVersions/main.go | 2 +- .../VersionsClient/CreateVersion/main.go | 2 +- .../VersionsClient/DeleteVersion/main.go | 2 +- .../VersionsClient/GetLocation/main.go | 2 +- .../VersionsClient/GetOperation/main.go | 2 +- .../VersionsClient/GetVersion/main.go | 2 +- .../VersionsClient/ListLocations/main.go | 2 +- .../VersionsClient/ListOperations/main.go | 2 +- .../VersionsClient/ListVersions/main.go | 2 +- .../VersionsClient/LoadVersion/main.go | 2 +- .../VersionsClient/UpdateVersion/main.go | 2 +- .../WebhooksClient/CancelOperation/main.go | 2 +- .../WebhooksClient/CreateWebhook/main.go | 2 +- .../WebhooksClient/DeleteWebhook/main.go | 2 +- .../WebhooksClient/GetLocation/main.go | 2 +- .../WebhooksClient/GetOperation/main.go | 2 +- .../WebhooksClient/GetWebhook/main.go | 2 +- .../WebhooksClient/ListLocations/main.go | 2 +- .../WebhooksClient/ListOperations/main.go | 2 +- .../WebhooksClient/ListWebhooks/main.go | 2 +- .../WebhooksClient/UpdateWebhook/main.go | 2 +- ...ta.google.cloud.dialogflow.cx.v3beta1.json | 2 +- .../CompletionClient/CancelOperation/main.go | 2 +- .../CompletionClient/CompleteQuery/main.go | 2 +- .../CompletionClient/GetOperation/main.go | 2 +- .../ImportCompletionSuggestions/main.go | 2 +- .../ImportSuggestionDenyListEntries/main.go | 2 +- .../CompletionClient/ListOperations/main.go | 2 +- .../PurgeCompletionSuggestions/main.go | 2 +- .../PurgeSuggestionDenyListEntries/main.go | 2 +- .../ControlClient/CancelOperation/main.go | 2 +- .../apiv1/ControlClient/CreateControl/main.go | 2 +- .../apiv1/ControlClient/DeleteControl/main.go | 2 +- .../apiv1/ControlClient/GetControl/main.go | 2 +- .../apiv1/ControlClient/GetOperation/main.go | 2 +- .../apiv1/ControlClient/ListControls/main.go | 2 +- .../ControlClient/ListOperations/main.go | 2 +- .../apiv1/ControlClient/UpdateControl/main.go | 2 +- .../AnswerQuery/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../ConverseConversation/main.go | 2 +- .../CreateConversation/main.go | 2 +- .../CreateSession/main.go | 2 +- .../DeleteConversation/main.go | 2 +- .../DeleteSession/main.go | 2 +- .../GetAnswer/main.go | 2 +- .../GetConversation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetSession/main.go | 2 +- .../ListConversations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListSessions/main.go | 2 +- .../UpdateConversation/main.go | 2 +- .../UpdateSession/main.go | 2 +- .../DataStoreClient/CancelOperation/main.go | 2 +- .../DataStoreClient/CreateDataStore/main.go | 2 +- .../DataStoreClient/DeleteDataStore/main.go | 2 +- .../DataStoreClient/GetDataStore/main.go | 2 +- .../DataStoreClient/GetOperation/main.go | 2 +- .../DataStoreClient/ListDataStores/main.go | 2 +- .../DataStoreClient/ListOperations/main.go | 2 +- .../DataStoreClient/UpdateDataStore/main.go | 2 +- .../BatchGetDocumentsMetadata/main.go | 2 +- .../DocumentClient/CancelOperation/main.go | 2 +- .../DocumentClient/CreateDocument/main.go | 2 +- .../DocumentClient/DeleteDocument/main.go | 2 +- .../apiv1/DocumentClient/GetDocument/main.go | 2 +- .../apiv1/DocumentClient/GetOperation/main.go | 2 +- .../DocumentClient/ImportDocuments/main.go | 2 +- .../DocumentClient/ListDocuments/main.go | 2 +- .../DocumentClient/ListOperations/main.go | 2 +- .../DocumentClient/PurgeDocuments/main.go | 2 +- .../DocumentClient/UpdateDocument/main.go | 2 +- .../EngineClient/CancelOperation/main.go | 2 +- .../apiv1/EngineClient/CreateEngine/main.go | 2 +- .../apiv1/EngineClient/DeleteEngine/main.go | 2 +- .../apiv1/EngineClient/GetEngine/main.go | 2 +- .../apiv1/EngineClient/GetOperation/main.go | 2 +- .../apiv1/EngineClient/ListEngines/main.go | 2 +- .../apiv1/EngineClient/ListOperations/main.go | 2 +- .../apiv1/EngineClient/UpdateEngine/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CheckGrounding/main.go | 2 +- .../GenerateGroundedContent/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListOperations/main.go | 2 +- .../StreamGenerateGroundedContent/main.go | 2 +- .../ProjectClient/CancelOperation/main.go | 2 +- .../apiv1/ProjectClient/GetOperation/main.go | 2 +- .../ProjectClient/ListOperations/main.go | 2 +- .../ProjectClient/ProvisionProject/main.go | 2 +- .../apiv1/RankClient/CancelOperation/main.go | 2 +- .../apiv1/RankClient/GetOperation/main.go | 2 +- .../apiv1/RankClient/ListOperations/main.go | 2 +- .../apiv1/RankClient/Rank/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../RecommendationClient/GetOperation/main.go | 2 +- .../ListOperations/main.go | 2 +- .../RecommendationClient/Recommend/main.go | 2 +- .../SchemaClient/CancelOperation/main.go | 2 +- .../apiv1/SchemaClient/CreateSchema/main.go | 2 +- .../apiv1/SchemaClient/DeleteSchema/main.go | 2 +- .../apiv1/SchemaClient/GetOperation/main.go | 2 +- .../apiv1/SchemaClient/GetSchema/main.go | 2 +- .../apiv1/SchemaClient/ListOperations/main.go | 2 +- .../apiv1/SchemaClient/ListSchemas/main.go | 2 +- .../apiv1/SchemaClient/UpdateSchema/main.go | 2 +- .../SearchClient/CancelOperation/main.go | 2 +- .../apiv1/SearchClient/GetOperation/main.go | 2 +- .../apiv1/SearchClient/ListOperations/main.go | 2 +- .../apiv1/SearchClient/Search/main.go | 2 +- .../apiv1/SearchClient/SearchLite/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../SearchTuningClient/GetOperation/main.go | 2 +- .../ListCustomModels/main.go | 2 +- .../SearchTuningClient/ListOperations/main.go | 2 +- .../TrainCustomModel/main.go | 2 +- .../BatchCreateTargetSites/main.go | 2 +- .../BatchVerifyTargetSites/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateTargetSite/main.go | 2 +- .../DeleteTargetSite/main.go | 2 +- .../DisableAdvancedSiteSearch/main.go | 2 +- .../EnableAdvancedSiteSearch/main.go | 2 +- .../FetchDomainVerificationStatus/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetSiteSearchEngine/main.go | 2 +- .../GetTargetSite/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListTargetSites/main.go | 2 +- .../RecrawlUris/main.go | 2 +- .../UpdateTargetSite/main.go | 2 +- .../UserEventClient/CancelOperation/main.go | 2 +- .../UserEventClient/CollectUserEvent/main.go | 2 +- .../UserEventClient/GetOperation/main.go | 2 +- .../UserEventClient/ImportUserEvents/main.go | 2 +- .../UserEventClient/ListOperations/main.go | 2 +- .../UserEventClient/PurgeUserEvents/main.go | 2 +- .../UserEventClient/WriteUserEvent/main.go | 2 +- ...adata.google.cloud.discoveryengine.v1.json | 2 +- .../AclConfigClient/CancelOperation/main.go | 2 +- .../AclConfigClient/GetAclConfig/main.go | 2 +- .../AclConfigClient/GetOperation/main.go | 2 +- .../AclConfigClient/ListOperations/main.go | 2 +- .../AclConfigClient/UpdateAclConfig/main.go | 2 +- .../ChunkClient/CancelOperation/main.go | 2 +- .../apiv1alpha/ChunkClient/GetChunk/main.go | 2 +- .../ChunkClient/GetOperation/main.go | 2 +- .../apiv1alpha/ChunkClient/ListChunks/main.go | 2 +- .../ChunkClient/ListOperations/main.go | 2 +- .../CompletionClient/CancelOperation/main.go | 2 +- .../CompletionClient/CompleteQuery/main.go | 2 +- .../CompletionClient/GetOperation/main.go | 2 +- .../ImportCompletionSuggestions/main.go | 2 +- .../ImportSuggestionDenyListEntries/main.go | 2 +- .../CompletionClient/ListOperations/main.go | 2 +- .../PurgeCompletionSuggestions/main.go | 2 +- .../PurgeSuggestionDenyListEntries/main.go | 2 +- .../ControlClient/CancelOperation/main.go | 2 +- .../ControlClient/CreateControl/main.go | 2 +- .../ControlClient/DeleteControl/main.go | 2 +- .../ControlClient/GetControl/main.go | 2 +- .../ControlClient/GetOperation/main.go | 2 +- .../ControlClient/ListControls/main.go | 2 +- .../ControlClient/ListOperations/main.go | 2 +- .../ControlClient/UpdateControl/main.go | 2 +- .../AnswerQuery/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../ConverseConversation/main.go | 2 +- .../CreateConversation/main.go | 2 +- .../CreateSession/main.go | 2 +- .../DeleteConversation/main.go | 2 +- .../DeleteSession/main.go | 2 +- .../GetAnswer/main.go | 2 +- .../GetConversation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetSession/main.go | 2 +- .../ListConversations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListSessions/main.go | 2 +- .../UpdateConversation/main.go | 2 +- .../UpdateSession/main.go | 2 +- .../DataStoreClient/CancelOperation/main.go | 2 +- .../DataStoreClient/CreateDataStore/main.go | 2 +- .../DataStoreClient/DeleteDataStore/main.go | 2 +- .../DataStoreClient/GetDataStore/main.go | 2 +- .../GetDocumentProcessingConfig/main.go | 2 +- .../DataStoreClient/GetOperation/main.go | 2 +- .../DataStoreClient/ListDataStores/main.go | 2 +- .../DataStoreClient/ListOperations/main.go | 2 +- .../DataStoreClient/UpdateDataStore/main.go | 2 +- .../UpdateDocumentProcessingConfig/main.go | 2 +- .../BatchGetDocumentsMetadata/main.go | 2 +- .../DocumentClient/CancelOperation/main.go | 2 +- .../DocumentClient/CreateDocument/main.go | 2 +- .../DocumentClient/DeleteDocument/main.go | 2 +- .../DocumentClient/GetDocument/main.go | 2 +- .../DocumentClient/GetOperation/main.go | 2 +- .../GetProcessedDocument/main.go | 2 +- .../DocumentClient/ImportDocuments/main.go | 2 +- .../DocumentClient/ListDocuments/main.go | 2 +- .../DocumentClient/ListOperations/main.go | 2 +- .../DocumentClient/PurgeDocuments/main.go | 2 +- .../DocumentClient/UpdateDocument/main.go | 2 +- .../EngineClient/CancelOperation/main.go | 2 +- .../EngineClient/CreateEngine/main.go | 2 +- .../EngineClient/DeleteEngine/main.go | 2 +- .../apiv1alpha/EngineClient/GetEngine/main.go | 2 +- .../EngineClient/GetOperation/main.go | 2 +- .../EngineClient/ListEngines/main.go | 2 +- .../EngineClient/ListOperations/main.go | 2 +- .../EngineClient/PauseEngine/main.go | 2 +- .../EngineClient/ResumeEngine/main.go | 2 +- .../EngineClient/TuneEngine/main.go | 2 +- .../EngineClient/UpdateEngine/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../EstimateDataSize/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListOperations/main.go | 2 +- .../EvaluationClient/CancelOperation/main.go | 2 +- .../EvaluationClient/CreateEvaluation/main.go | 2 +- .../EvaluationClient/GetEvaluation/main.go | 2 +- .../EvaluationClient/GetOperation/main.go | 2 +- .../ListEvaluationResults/main.go | 2 +- .../EvaluationClient/ListEvaluations/main.go | 2 +- .../EvaluationClient/ListOperations/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CheckGrounding/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ProjectClient/CancelOperation/main.go | 2 +- .../ProjectClient/GetOperation/main.go | 2 +- .../ProjectClient/GetProject/main.go | 2 +- .../ProjectClient/ListOperations/main.go | 2 +- .../ProjectClient/ProvisionProject/main.go | 2 +- .../ProjectClient/ReportConsentChange/main.go | 2 +- .../RankClient/CancelOperation/main.go | 2 +- .../RankClient/GetOperation/main.go | 2 +- .../RankClient/ListOperations/main.go | 2 +- .../apiv1alpha/RankClient/Rank/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../RecommendationClient/GetOperation/main.go | 2 +- .../ListOperations/main.go | 2 +- .../RecommendationClient/Recommend/main.go | 2 +- .../SampleQueryClient/CancelOperation/main.go | 2 +- .../CreateSampleQuery/main.go | 2 +- .../DeleteSampleQuery/main.go | 2 +- .../SampleQueryClient/GetOperation/main.go | 2 +- .../SampleQueryClient/GetSampleQuery/main.go | 2 +- .../ImportSampleQueries/main.go | 2 +- .../SampleQueryClient/ListOperations/main.go | 2 +- .../ListSampleQueries/main.go | 2 +- .../UpdateSampleQuery/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateSampleQuerySet/main.go | 2 +- .../DeleteSampleQuerySet/main.go | 2 +- .../SampleQuerySetClient/GetOperation/main.go | 2 +- .../GetSampleQuerySet/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListSampleQuerySets/main.go | 2 +- .../UpdateSampleQuerySet/main.go | 2 +- .../SchemaClient/CancelOperation/main.go | 2 +- .../SchemaClient/CreateSchema/main.go | 2 +- .../SchemaClient/DeleteSchema/main.go | 2 +- .../SchemaClient/GetOperation/main.go | 2 +- .../apiv1alpha/SchemaClient/GetSchema/main.go | 2 +- .../SchemaClient/ListOperations/main.go | 2 +- .../SchemaClient/ListSchemas/main.go | 2 +- .../SchemaClient/UpdateSchema/main.go | 2 +- .../SearchClient/CancelOperation/main.go | 2 +- .../SearchClient/GetOperation/main.go | 2 +- .../SearchClient/ListOperations/main.go | 2 +- .../apiv1alpha/SearchClient/Search/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../SearchTuningClient/GetOperation/main.go | 2 +- .../ListCustomModels/main.go | 2 +- .../SearchTuningClient/ListOperations/main.go | 2 +- .../TrainCustomModel/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../ServingConfigClient/GetOperation/main.go | 2 +- .../GetServingConfig/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListServingConfigs/main.go | 2 +- .../UpdateServingConfig/main.go | 2 +- .../BatchCreateTargetSites/main.go | 2 +- .../BatchVerifyTargetSites/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateTargetSite/main.go | 2 +- .../DeleteTargetSite/main.go | 2 +- .../DisableAdvancedSiteSearch/main.go | 2 +- .../EnableAdvancedSiteSearch/main.go | 2 +- .../FetchDomainVerificationStatus/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetSiteSearchEngine/main.go | 2 +- .../GetTargetSite/main.go | 2 +- .../GetUriPatternDocumentData/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListTargetSites/main.go | 2 +- .../RecrawlUris/main.go | 2 +- .../SetUriPatternDocumentData/main.go | 2 +- .../UpdateTargetSite/main.go | 2 +- .../UserEventClient/CancelOperation/main.go | 2 +- .../UserEventClient/CollectUserEvent/main.go | 2 +- .../UserEventClient/GetOperation/main.go | 2 +- .../UserEventClient/ImportUserEvents/main.go | 2 +- .../UserEventClient/ListOperations/main.go | 2 +- .../UserEventClient/PurgeUserEvents/main.go | 2 +- .../UserEventClient/WriteUserEvent/main.go | 2 +- ....google.cloud.discoveryengine.v1alpha.json | 2 +- .../AdvancedCompleteQuery/main.go | 2 +- .../CompletionClient/CancelOperation/main.go | 2 +- .../CompletionClient/CompleteQuery/main.go | 2 +- .../CompletionClient/GetOperation/main.go | 2 +- .../ImportCompletionSuggestions/main.go | 2 +- .../ImportSuggestionDenyListEntries/main.go | 2 +- .../CompletionClient/ListOperations/main.go | 2 +- .../PurgeCompletionSuggestions/main.go | 2 +- .../PurgeSuggestionDenyListEntries/main.go | 2 +- .../ControlClient/CancelOperation/main.go | 2 +- .../ControlClient/CreateControl/main.go | 2 +- .../ControlClient/DeleteControl/main.go | 2 +- .../ControlClient/GetControl/main.go | 2 +- .../ControlClient/GetOperation/main.go | 2 +- .../ControlClient/ListControls/main.go | 2 +- .../ControlClient/ListOperations/main.go | 2 +- .../ControlClient/UpdateControl/main.go | 2 +- .../AnswerQuery/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../ConverseConversation/main.go | 2 +- .../CreateConversation/main.go | 2 +- .../CreateSession/main.go | 2 +- .../DeleteConversation/main.go | 2 +- .../DeleteSession/main.go | 2 +- .../GetAnswer/main.go | 2 +- .../GetConversation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetSession/main.go | 2 +- .../ListConversations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListSessions/main.go | 2 +- .../UpdateConversation/main.go | 2 +- .../UpdateSession/main.go | 2 +- .../DataStoreClient/CancelOperation/main.go | 2 +- .../DataStoreClient/CreateDataStore/main.go | 2 +- .../DataStoreClient/DeleteDataStore/main.go | 2 +- .../DataStoreClient/GetDataStore/main.go | 2 +- .../DataStoreClient/GetOperation/main.go | 2 +- .../DataStoreClient/ListDataStores/main.go | 2 +- .../DataStoreClient/ListOperations/main.go | 2 +- .../DataStoreClient/UpdateDataStore/main.go | 2 +- .../BatchGetDocumentsMetadata/main.go | 2 +- .../DocumentClient/CancelOperation/main.go | 2 +- .../DocumentClient/CreateDocument/main.go | 2 +- .../DocumentClient/DeleteDocument/main.go | 2 +- .../DocumentClient/GetDocument/main.go | 2 +- .../DocumentClient/GetOperation/main.go | 2 +- .../DocumentClient/ImportDocuments/main.go | 2 +- .../DocumentClient/ListDocuments/main.go | 2 +- .../DocumentClient/ListOperations/main.go | 2 +- .../DocumentClient/PurgeDocuments/main.go | 2 +- .../DocumentClient/UpdateDocument/main.go | 2 +- .../EngineClient/CancelOperation/main.go | 2 +- .../EngineClient/CreateEngine/main.go | 2 +- .../EngineClient/DeleteEngine/main.go | 2 +- .../apiv1beta/EngineClient/GetEngine/main.go | 2 +- .../EngineClient/GetOperation/main.go | 2 +- .../EngineClient/ListEngines/main.go | 2 +- .../EngineClient/ListOperations/main.go | 2 +- .../EngineClient/PauseEngine/main.go | 2 +- .../EngineClient/ResumeEngine/main.go | 2 +- .../apiv1beta/EngineClient/TuneEngine/main.go | 2 +- .../EngineClient/UpdateEngine/main.go | 2 +- .../EvaluationClient/CancelOperation/main.go | 2 +- .../EvaluationClient/CreateEvaluation/main.go | 2 +- .../EvaluationClient/GetEvaluation/main.go | 2 +- .../EvaluationClient/GetOperation/main.go | 2 +- .../ListEvaluationResults/main.go | 2 +- .../EvaluationClient/ListEvaluations/main.go | 2 +- .../EvaluationClient/ListOperations/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CheckGrounding/main.go | 2 +- .../GenerateGroundedContent/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListOperations/main.go | 2 +- .../StreamGenerateGroundedContent/main.go | 2 +- .../ProjectClient/CancelOperation/main.go | 2 +- .../ProjectClient/GetOperation/main.go | 2 +- .../ProjectClient/ListOperations/main.go | 2 +- .../ProjectClient/ProvisionProject/main.go | 2 +- .../RankClient/CancelOperation/main.go | 2 +- .../apiv1beta/RankClient/GetOperation/main.go | 2 +- .../RankClient/ListOperations/main.go | 2 +- .../apiv1beta/RankClient/Rank/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../RecommendationClient/GetOperation/main.go | 2 +- .../ListOperations/main.go | 2 +- .../RecommendationClient/Recommend/main.go | 2 +- .../SampleQueryClient/CancelOperation/main.go | 2 +- .../CreateSampleQuery/main.go | 2 +- .../DeleteSampleQuery/main.go | 2 +- .../SampleQueryClient/GetOperation/main.go | 2 +- .../SampleQueryClient/GetSampleQuery/main.go | 2 +- .../ImportSampleQueries/main.go | 2 +- .../SampleQueryClient/ListOperations/main.go | 2 +- .../ListSampleQueries/main.go | 2 +- .../UpdateSampleQuery/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateSampleQuerySet/main.go | 2 +- .../DeleteSampleQuerySet/main.go | 2 +- .../SampleQuerySetClient/GetOperation/main.go | 2 +- .../GetSampleQuerySet/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListSampleQuerySets/main.go | 2 +- .../UpdateSampleQuerySet/main.go | 2 +- .../SchemaClient/CancelOperation/main.go | 2 +- .../SchemaClient/CreateSchema/main.go | 2 +- .../SchemaClient/DeleteSchema/main.go | 2 +- .../SchemaClient/GetOperation/main.go | 2 +- .../apiv1beta/SchemaClient/GetSchema/main.go | 2 +- .../SchemaClient/ListOperations/main.go | 2 +- .../SchemaClient/ListSchemas/main.go | 2 +- .../SchemaClient/UpdateSchema/main.go | 2 +- .../SearchClient/CancelOperation/main.go | 2 +- .../SearchClient/GetOperation/main.go | 2 +- .../SearchClient/ListOperations/main.go | 2 +- .../apiv1beta/SearchClient/Search/main.go | 2 +- .../apiv1beta/SearchClient/SearchLite/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../SearchTuningClient/GetOperation/main.go | 2 +- .../ListCustomModels/main.go | 2 +- .../SearchTuningClient/ListOperations/main.go | 2 +- .../TrainCustomModel/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../ServingConfigClient/GetOperation/main.go | 2 +- .../GetServingConfig/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListServingConfigs/main.go | 2 +- .../UpdateServingConfig/main.go | 2 +- .../BatchCreateTargetSites/main.go | 2 +- .../BatchVerifyTargetSites/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateSitemap/main.go | 2 +- .../CreateTargetSite/main.go | 2 +- .../DeleteSitemap/main.go | 2 +- .../DeleteTargetSite/main.go | 2 +- .../DisableAdvancedSiteSearch/main.go | 2 +- .../EnableAdvancedSiteSearch/main.go | 2 +- .../FetchDomainVerificationStatus/main.go | 2 +- .../FetchSitemaps/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetSiteSearchEngine/main.go | 2 +- .../GetTargetSite/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListTargetSites/main.go | 2 +- .../RecrawlUris/main.go | 2 +- .../UpdateTargetSite/main.go | 2 +- .../UserEventClient/CancelOperation/main.go | 2 +- .../UserEventClient/CollectUserEvent/main.go | 2 +- .../UserEventClient/GetOperation/main.go | 2 +- .../UserEventClient/ImportUserEvents/main.go | 2 +- .../UserEventClient/ListOperations/main.go | 2 +- .../UserEventClient/PurgeUserEvents/main.go | 2 +- .../UserEventClient/WriteUserEvent/main.go | 2 +- ...a.google.cloud.discoveryengine.v1beta.json | 2 +- .../apiv2/Client/ActivateJobTrigger/main.go | 2 +- .../dlp/apiv2/Client/CancelDlpJob/main.go | 2 +- .../dlp/apiv2/Client/CreateConnection/main.go | 2 +- .../Client/CreateDeidentifyTemplate/main.go | 2 +- .../Client/CreateDiscoveryConfig/main.go | 2 +- .../dlp/apiv2/Client/CreateDlpJob/main.go | 2 +- .../Client/CreateInspectTemplate/main.go | 2 +- .../dlp/apiv2/Client/CreateJobTrigger/main.go | 2 +- .../apiv2/Client/CreateStoredInfoType/main.go | 2 +- .../apiv2/Client/DeidentifyContent/main.go | 2 +- .../dlp/apiv2/Client/DeleteConnection/main.go | 2 +- .../Client/DeleteDeidentifyTemplate/main.go | 2 +- .../Client/DeleteDiscoveryConfig/main.go | 2 +- .../dlp/apiv2/Client/DeleteDlpJob/main.go | 2 +- .../Client/DeleteFileStoreDataProfile/main.go | 2 +- .../Client/DeleteInspectTemplate/main.go | 2 +- .../dlp/apiv2/Client/DeleteJobTrigger/main.go | 2 +- .../apiv2/Client/DeleteStoredInfoType/main.go | 2 +- .../Client/DeleteTableDataProfile/main.go | 2 +- .../dlp/apiv2/Client/FinishDlpJob/main.go | 2 +- .../apiv2/Client/GetColumnDataProfile/main.go | 2 +- .../dlp/apiv2/Client/GetConnection/main.go | 2 +- .../Client/GetDeidentifyTemplate/main.go | 2 +- .../apiv2/Client/GetDiscoveryConfig/main.go | 2 +- .../dlp/apiv2/Client/GetDlpJob/main.go | 2 +- .../Client/GetFileStoreDataProfile/main.go | 2 +- .../apiv2/Client/GetInspectTemplate/main.go | 2 +- .../dlp/apiv2/Client/GetJobTrigger/main.go | 2 +- .../Client/GetProjectDataProfile/main.go | 2 +- .../apiv2/Client/GetStoredInfoType/main.go | 2 +- .../apiv2/Client/GetTableDataProfile/main.go | 2 +- .../apiv2/Client/HybridInspectDlpJob/main.go | 2 +- .../Client/HybridInspectJobTrigger/main.go | 2 +- .../dlp/apiv2/Client/InspectContent/main.go | 2 +- .../Client/ListColumnDataProfiles/main.go | 2 +- .../dlp/apiv2/Client/ListConnections/main.go | 2 +- .../Client/ListDeidentifyTemplates/main.go | 2 +- .../apiv2/Client/ListDiscoveryConfigs/main.go | 2 +- .../dlp/apiv2/Client/ListDlpJobs/main.go | 2 +- .../Client/ListFileStoreDataProfiles/main.go | 2 +- .../dlp/apiv2/Client/ListInfoTypes/main.go | 2 +- .../apiv2/Client/ListInspectTemplates/main.go | 2 +- .../dlp/apiv2/Client/ListJobTriggers/main.go | 2 +- .../Client/ListProjectDataProfiles/main.go | 2 +- .../apiv2/Client/ListStoredInfoTypes/main.go | 2 +- .../Client/ListTableDataProfiles/main.go | 2 +- .../dlp/apiv2/Client/RedactImage/main.go | 2 +- .../apiv2/Client/ReidentifyContent/main.go | 2 +- .../apiv2/Client/SearchConnections/main.go | 2 +- .../dlp/apiv2/Client/UpdateConnection/main.go | 2 +- .../Client/UpdateDeidentifyTemplate/main.go | 2 +- .../Client/UpdateDiscoveryConfig/main.go | 2 +- .../Client/UpdateInspectTemplate/main.go | 2 +- .../dlp/apiv2/Client/UpdateJobTrigger/main.go | 2 +- .../apiv2/Client/UpdateStoredInfoType/main.go | 2 +- ...nippet_metadata.google.privacy.dlp.v2.json | 2 +- .../BatchProcessDocuments/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateProcessor/main.go | 2 +- .../DeleteProcessor/main.go | 2 +- .../DeleteProcessorVersion/main.go | 2 +- .../DeployProcessorVersion/main.go | 2 +- .../DisableProcessor/main.go | 2 +- .../EnableProcessor/main.go | 2 +- .../EvaluateProcessorVersion/main.go | 2 +- .../FetchProcessorTypes/main.go | 2 +- .../GetEvaluation/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetProcessor/main.go | 2 +- .../GetProcessorType/main.go | 2 +- .../GetProcessorVersion/main.go | 2 +- .../ListEvaluations/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListProcessorTypes/main.go | 2 +- .../ListProcessorVersions/main.go | 2 +- .../ListProcessors/main.go | 2 +- .../ProcessDocument/main.go | 2 +- .../ReviewDocument/main.go | 2 +- .../SetDefaultProcessorVersion/main.go | 2 +- .../TrainProcessorVersion/main.go | 2 +- .../UndeployProcessorVersion/main.go | 2 +- ...t_metadata.google.cloud.documentai.v1.json | 2 +- .../BatchDeleteDocuments/main.go | 2 +- .../DocumentClient/CancelOperation/main.go | 2 +- .../DocumentClient/GetDatasetSchema/main.go | 2 +- .../DocumentClient/GetDocument/main.go | 2 +- .../DocumentClient/GetLocation/main.go | 2 +- .../DocumentClient/GetOperation/main.go | 2 +- .../DocumentClient/ImportDocuments/main.go | 2 +- .../DocumentClient/ListDocuments/main.go | 2 +- .../DocumentClient/ListLocations/main.go | 2 +- .../DocumentClient/ListOperations/main.go | 2 +- .../DocumentClient/UpdateDataset/main.go | 2 +- .../UpdateDatasetSchema/main.go | 2 +- .../BatchProcessDocuments/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateProcessor/main.go | 2 +- .../DeleteProcessor/main.go | 2 +- .../DeleteProcessorVersion/main.go | 2 +- .../DeployProcessorVersion/main.go | 2 +- .../DisableProcessor/main.go | 2 +- .../EnableProcessor/main.go | 2 +- .../EvaluateProcessorVersion/main.go | 2 +- .../FetchProcessorTypes/main.go | 2 +- .../GetEvaluation/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetProcessor/main.go | 2 +- .../GetProcessorType/main.go | 2 +- .../GetProcessorVersion/main.go | 2 +- .../ImportProcessorVersion/main.go | 2 +- .../ListEvaluations/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListProcessorTypes/main.go | 2 +- .../ListProcessorVersions/main.go | 2 +- .../ListProcessors/main.go | 2 +- .../ProcessDocument/main.go | 2 +- .../ReviewDocument/main.go | 2 +- .../SetDefaultProcessorVersion/main.go | 2 +- .../TrainProcessorVersion/main.go | 2 +- .../UndeployProcessorVersion/main.go | 2 +- ...adata.google.cloud.documentai.v1beta3.json | 2 +- .../Client/ConfigureContactSettings/main.go | 2 +- .../Client/ConfigureDnsSettings/main.go | 2 +- .../ConfigureManagementSettings/main.go | 2 +- .../Client/DeleteRegistration/main.go | 2 +- .../Client/ExportRegistration/main.go | 2 +- .../apiv1beta1/Client/GetRegistration/main.go | 2 +- .../Client/ListRegistrations/main.go | 2 +- .../apiv1beta1/Client/RegisterDomain/main.go | 2 +- .../Client/ResetAuthorizationCode/main.go | 2 +- .../Client/RetrieveAuthorizationCode/main.go | 2 +- .../Client/RetrieveRegisterParameters/main.go | 2 +- .../Client/RetrieveTransferParameters/main.go | 2 +- .../apiv1beta1/Client/SearchDomains/main.go | 2 +- .../apiv1beta1/Client/TransferDomain/main.go | 2 +- .../Client/UpdateRegistration/main.go | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apiv1/Client/CreateCluster/main.go | 2 +- .../apiv1/Client/CreateNodePool/main.go | 2 +- .../apiv1/Client/CreateVpnConnection/main.go | 2 +- .../apiv1/Client/DeleteCluster/main.go | 2 +- .../apiv1/Client/DeleteNodePool/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../apiv1/Client/DeleteVpnConnection/main.go | 2 +- .../apiv1/Client/GenerateAccessToken/main.go | 2 +- .../Client/GenerateOfflineCredential/main.go | 2 +- .../apiv1/Client/GetCluster/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetMachine/main.go | 2 +- .../apiv1/Client/GetNodePool/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/GetServerConfig/main.go | 2 +- .../apiv1/Client/GetVpnConnection/main.go | 2 +- .../apiv1/Client/ListClusters/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListMachines/main.go | 2 +- .../apiv1/Client/ListNodePools/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/ListVpnConnections/main.go | 2 +- .../apiv1/Client/UpdateCluster/main.go | 2 +- .../apiv1/Client/UpdateNodePool/main.go | 2 +- .../apiv1/Client/UpgradeCluster/main.go | 2 +- ...etadata.google.cloud.edgecontainer.v1.json | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../CreateInterconnectAttachment/main.go | 2 +- .../apiv1/Client/CreateNetwork/main.go | 2 +- .../apiv1/Client/CreateRouter/main.go | 2 +- .../apiv1/Client/CreateSubnet/main.go | 2 +- .../DeleteInterconnectAttachment/main.go | 2 +- .../apiv1/Client/DeleteNetwork/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../apiv1/Client/DeleteRouter/main.go | 2 +- .../apiv1/Client/DeleteSubnet/main.go | 2 +- .../apiv1/Client/DiagnoseInterconnect/main.go | 2 +- .../apiv1/Client/DiagnoseNetwork/main.go | 2 +- .../apiv1/Client/DiagnoseRouter/main.go | 2 +- .../apiv1/Client/GetInterconnect/main.go | 2 +- .../Client/GetInterconnectAttachment/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetNetwork/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/GetRouter/main.go | 2 +- .../apiv1/Client/GetSubnet/main.go | 2 +- .../edgenetwork/apiv1/Client/GetZone/main.go | 2 +- .../apiv1/Client/InitializeZone/main.go | 2 +- .../ListInterconnectAttachments/main.go | 2 +- .../apiv1/Client/ListInterconnects/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListNetworks/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/ListRouters/main.go | 2 +- .../apiv1/Client/ListSubnets/main.go | 2 +- .../apiv1/Client/ListZones/main.go | 2 +- .../apiv1/Client/UpdateRouter/main.go | 2 +- .../apiv1/Client/UpdateSubnet/main.go | 2 +- ..._metadata.google.cloud.edgenetwork.v1.json | 2 +- .../apiv1/Client/ComputeContacts/main.go | 2 +- .../apiv1/Client/CreateContact/main.go | 2 +- .../apiv1/Client/DeleteContact/main.go | 2 +- .../apiv1/Client/GetContact/main.go | 2 +- .../apiv1/Client/ListContacts/main.go | 2 +- .../apiv1/Client/SendTestMessage/main.go | 2 +- .../apiv1/Client/UpdateContact/main.go | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apiv1/Client/CreateChannel/main.go | 2 +- .../Client/CreateChannelConnection/main.go | 2 +- .../apiv1/Client/CreateEnrollment/main.go | 2 +- .../Client/CreateGoogleApiSource/main.go | 2 +- .../apiv1/Client/CreateMessageBus/main.go | 2 +- .../apiv1/Client/CreatePipeline/main.go | 2 +- .../apiv1/Client/CreateTrigger/main.go | 2 +- .../apiv1/Client/DeleteChannel/main.go | 2 +- .../Client/DeleteChannelConnection/main.go | 2 +- .../apiv1/Client/DeleteEnrollment/main.go | 2 +- .../Client/DeleteGoogleApiSource/main.go | 2 +- .../apiv1/Client/DeleteMessageBus/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../apiv1/Client/DeletePipeline/main.go | 2 +- .../apiv1/Client/DeleteTrigger/main.go | 2 +- .../eventarc/apiv1/Client/GetChannel/main.go | 2 +- .../apiv1/Client/GetChannelConnection/main.go | 2 +- .../apiv1/Client/GetEnrollment/main.go | 2 +- .../apiv1/Client/GetGoogleApiSource/main.go | 2 +- .../Client/GetGoogleChannelConfig/main.go | 2 +- .../apiv1/Client/GetIamPolicy/main.go | 2 +- .../eventarc/apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetMessageBus/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../eventarc/apiv1/Client/GetPipeline/main.go | 2 +- .../eventarc/apiv1/Client/GetProvider/main.go | 2 +- .../eventarc/apiv1/Client/GetTrigger/main.go | 2 +- .../Client/ListChannelConnections/main.go | 2 +- .../apiv1/Client/ListChannels/main.go | 2 +- .../apiv1/Client/ListEnrollments/main.go | 2 +- .../apiv1/Client/ListGoogleApiSources/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../Client/ListMessageBusEnrollments/main.go | 2 +- .../apiv1/Client/ListMessageBuses/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/ListPipelines/main.go | 2 +- .../apiv1/Client/ListProviders/main.go | 2 +- .../apiv1/Client/ListTriggers/main.go | 2 +- .../apiv1/Client/SetIamPolicy/main.go | 2 +- .../apiv1/Client/TestIamPermissions/main.go | 2 +- .../apiv1/Client/UpdateChannel/main.go | 2 +- .../apiv1/Client/UpdateEnrollment/main.go | 2 +- .../Client/UpdateGoogleApiSource/main.go | 2 +- .../Client/UpdateGoogleChannelConfig/main.go | 2 +- .../apiv1/Client/UpdateMessageBus/main.go | 2 +- .../apiv1/Client/UpdatePipeline/main.go | 2 +- .../apiv1/Client/UpdateTrigger/main.go | 2 +- .../apiv1/PublisherClient/Publish/main.go | 2 +- .../PublishChannelConnectionEvents/main.go | 2 +- .../PublisherClient/PublishEvents/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateBackup/main.go | 2 +- .../CreateInstance/main.go | 2 +- .../CreateSnapshot/main.go | 2 +- .../DeleteBackup/main.go | 2 +- .../DeleteInstance/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../DeleteSnapshot/main.go | 2 +- .../GetBackup/main.go | 2 +- .../GetInstance/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetSnapshot/main.go | 2 +- .../ListBackups/main.go | 2 +- .../ListInstances/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListSnapshots/main.go | 2 +- .../RestoreInstance/main.go | 2 +- .../RevertInstance/main.go | 2 +- .../UpdateBackup/main.go | 2 +- .../UpdateInstance/main.go | 2 +- .../UpdateSnapshot/main.go | 2 +- ...et_metadata.google.cloud.filestore.v1.json | 2 +- .../firestore/apiv1/Client/BatchWrite/main.go | 2 +- .../apiv1/Client/BeginTransaction/main.go | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../firestore/apiv1/Client/Commit/main.go | 2 +- .../apiv1/Client/CreateDocument/main.go | 2 +- .../apiv1/Client/DeleteDocument/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../apiv1/Client/GetDocument/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/ListCollectionIds/main.go | 2 +- .../apiv1/Client/ListDocuments/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../firestore/apiv1/Client/Listen/main.go | 2 +- .../apiv1/Client/PartitionQuery/main.go | 2 +- .../firestore/apiv1/Client/Rollback/main.go | 2 +- .../apiv1/Client/UpdateDocument/main.go | 2 +- .../firestore/apiv1/Client/Write/main.go | 2 +- .../BulkDeleteDocuments/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateBackupSchedule/main.go | 2 +- .../CreateDatabase/main.go | 2 +- .../FirestoreAdminClient/CreateIndex/main.go | 2 +- .../FirestoreAdminClient/DeleteBackup/main.go | 2 +- .../DeleteBackupSchedule/main.go | 2 +- .../DeleteDatabase/main.go | 2 +- .../FirestoreAdminClient/DeleteIndex/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../ExportDocuments/main.go | 2 +- .../FirestoreAdminClient/GetBackup/main.go | 2 +- .../GetBackupSchedule/main.go | 2 +- .../FirestoreAdminClient/GetDatabase/main.go | 2 +- .../FirestoreAdminClient/GetField/main.go | 2 +- .../FirestoreAdminClient/GetIndex/main.go | 2 +- .../FirestoreAdminClient/GetOperation/main.go | 2 +- .../ImportDocuments/main.go | 2 +- .../ListBackupSchedules/main.go | 2 +- .../FirestoreAdminClient/ListBackups/main.go | 2 +- .../ListDatabases/main.go | 2 +- .../FirestoreAdminClient/ListFields/main.go | 2 +- .../FirestoreAdminClient/ListIndexes/main.go | 2 +- .../ListOperations/main.go | 2 +- .../RestoreDatabase/main.go | 2 +- .../UpdateBackupSchedule/main.go | 2 +- .../UpdateDatabase/main.go | 2 +- .../FirestoreAdminClient/UpdateField/main.go | 2 +- .../CloudFunctionsClient/CallFunction/main.go | 2 +- .../CreateFunction/main.go | 2 +- .../DeleteFunction/main.go | 2 +- .../GenerateDownloadUrl/main.go | 2 +- .../GenerateUploadUrl/main.go | 2 +- .../CloudFunctionsClient/GetFunction/main.go | 2 +- .../CloudFunctionsClient/GetIamPolicy/main.go | 2 +- .../CloudFunctionsClient/GetOperation/main.go | 2 +- .../ListFunctions/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../CloudFunctionsClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateFunction/main.go | 2 +- ...et_metadata.google.cloud.functions.v1.json | 2 +- .../FunctionClient/CreateFunction/main.go | 2 +- .../FunctionClient/DeleteFunction/main.go | 2 +- .../GenerateDownloadUrl/main.go | 2 +- .../FunctionClient/GenerateUploadUrl/main.go | 2 +- .../apiv2/FunctionClient/GetFunction/main.go | 2 +- .../apiv2/FunctionClient/GetIamPolicy/main.go | 2 +- .../apiv2/FunctionClient/GetOperation/main.go | 2 +- .../FunctionClient/ListFunctions/main.go | 2 +- .../FunctionClient/ListLocations/main.go | 2 +- .../FunctionClient/ListOperations/main.go | 2 +- .../apiv2/FunctionClient/ListRuntimes/main.go | 2 +- .../apiv2/FunctionClient/SetIamPolicy/main.go | 2 +- .../FunctionClient/TestIamPermissions/main.go | 2 +- .../FunctionClient/UpdateFunction/main.go | 2 +- ...et_metadata.google.cloud.functions.v2.json | 2 +- .../FunctionClient/CreateFunction/main.go | 2 +- .../FunctionClient/DeleteFunction/main.go | 2 +- .../GenerateDownloadUrl/main.go | 2 +- .../FunctionClient/GenerateUploadUrl/main.go | 2 +- .../FunctionClient/GetFunction/main.go | 2 +- .../FunctionClient/GetIamPolicy/main.go | 2 +- .../FunctionClient/GetOperation/main.go | 2 +- .../FunctionClient/ListFunctions/main.go | 2 +- .../FunctionClient/ListLocations/main.go | 2 +- .../FunctionClient/ListOperations/main.go | 2 +- .../FunctionClient/ListRuntimes/main.go | 2 +- .../FunctionClient/SetIamPolicy/main.go | 2 +- .../FunctionClient/TestIamPermissions/main.go | 2 +- .../FunctionClient/UpdateFunction/main.go | 2 +- ...etadata.google.cloud.functions.v2beta.json | 2 +- .../CancelOperation/main.go | 2 +- .../BackupForGKEClient/CreateBackup/main.go | 2 +- .../CreateBackupPlan/main.go | 2 +- .../BackupForGKEClient/CreateRestore/main.go | 2 +- .../CreateRestorePlan/main.go | 2 +- .../BackupForGKEClient/DeleteBackup/main.go | 2 +- .../DeleteBackupPlan/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../BackupForGKEClient/DeleteRestore/main.go | 2 +- .../DeleteRestorePlan/main.go | 2 +- .../BackupForGKEClient/GetBackup/main.go | 2 +- .../GetBackupIndexDownloadUrl/main.go | 2 +- .../BackupForGKEClient/GetBackupPlan/main.go | 2 +- .../BackupForGKEClient/GetIamPolicy/main.go | 2 +- .../BackupForGKEClient/GetLocation/main.go | 2 +- .../BackupForGKEClient/GetOperation/main.go | 2 +- .../BackupForGKEClient/GetRestore/main.go | 2 +- .../BackupForGKEClient/GetRestorePlan/main.go | 2 +- .../GetVolumeBackup/main.go | 2 +- .../GetVolumeRestore/main.go | 2 +- .../ListBackupPlans/main.go | 2 +- .../BackupForGKEClient/ListBackups/main.go | 2 +- .../BackupForGKEClient/ListLocations/main.go | 2 +- .../BackupForGKEClient/ListOperations/main.go | 2 +- .../ListRestorePlans/main.go | 2 +- .../BackupForGKEClient/ListRestores/main.go | 2 +- .../ListVolumeBackups/main.go | 2 +- .../ListVolumeRestores/main.go | 2 +- .../BackupForGKEClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../BackupForGKEClient/UpdateBackup/main.go | 2 +- .../UpdateBackupPlan/main.go | 2 +- .../BackupForGKEClient/UpdateRestore/main.go | 2 +- .../UpdateRestorePlan/main.go | 2 +- ...et_metadata.google.cloud.gkebackup.v1.json | 2 +- .../GenerateCredentials/main.go | 2 +- .../GenerateCredentials/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateMembership/main.go | 2 +- .../DeleteMembership/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../GenerateConnectManifest/main.go | 2 +- .../GenerateExclusivityManifest/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetMembership/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListMemberships/main.go | 2 +- .../ListOperations/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateMembership/main.go | 2 +- .../ValidateExclusivity/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateAttachedCluster/main.go | 2 +- .../DeleteAttachedCluster/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../GenerateAttachedClusterAgentToken/main.go | 2 +- .../main.go | 2 +- .../GetAttachedCluster/main.go | 2 +- .../GetAttachedServerConfig/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ImportAttachedCluster/main.go | 2 +- .../ListAttachedClusters/main.go | 2 +- .../ListOperations/main.go | 2 +- .../UpdateAttachedCluster/main.go | 2 +- .../AwsClustersClient/CancelOperation/main.go | 2 +- .../CreateAwsCluster/main.go | 2 +- .../CreateAwsNodePool/main.go | 2 +- .../DeleteAwsCluster/main.go | 2 +- .../DeleteAwsNodePool/main.go | 2 +- .../AwsClustersClient/DeleteOperation/main.go | 2 +- .../GenerateAwsAccessToken/main.go | 2 +- .../GenerateAwsClusterAgentToken/main.go | 2 +- .../AwsClustersClient/GetAwsCluster/main.go | 2 +- .../GetAwsJsonWebKeys/main.go | 2 +- .../AwsClustersClient/GetAwsNodePool/main.go | 2 +- .../GetAwsOpenIdConfig/main.go | 2 +- .../GetAwsServerConfig/main.go | 2 +- .../AwsClustersClient/GetOperation/main.go | 2 +- .../AwsClustersClient/ListAwsClusters/main.go | 2 +- .../ListAwsNodePools/main.go | 2 +- .../AwsClustersClient/ListOperations/main.go | 2 +- .../RollbackAwsNodePoolUpdate/main.go | 2 +- .../UpdateAwsCluster/main.go | 2 +- .../UpdateAwsNodePool/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateAzureClient/main.go | 2 +- .../CreateAzureCluster/main.go | 2 +- .../CreateAzureNodePool/main.go | 2 +- .../DeleteAzureClient/main.go | 2 +- .../DeleteAzureCluster/main.go | 2 +- .../DeleteAzureNodePool/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../GenerateAzureAccessToken/main.go | 2 +- .../GenerateAzureClusterAgentToken/main.go | 2 +- .../GetAzureClient/main.go | 2 +- .../GetAzureCluster/main.go | 2 +- .../GetAzureJsonWebKeys/main.go | 2 +- .../GetAzureNodePool/main.go | 2 +- .../GetAzureOpenIdConfig/main.go | 2 +- .../GetAzureServerConfig/main.go | 2 +- .../AzureClustersClient/GetOperation/main.go | 2 +- .../ListAzureClients/main.go | 2 +- .../ListAzureClusters/main.go | 2 +- .../ListAzureNodePools/main.go | 2 +- .../ListOperations/main.go | 2 +- .../UpdateAzureCluster/main.go | 2 +- .../UpdateAzureNodePool/main.go | 2 +- ...etadata.google.cloud.gkemulticloud.v1.json | 2 +- .../apiv1/Client/CreateDeployment/main.go | 2 +- .../apiv1/Client/DeleteDeployment/main.go | 2 +- .../apiv1/Client/GetAuthorization/main.go | 2 +- .../apiv1/Client/GetDeployment/main.go | 2 +- .../apiv1/Client/GetInstallStatus/main.go | 2 +- .../apiv1/Client/InstallDeployment/main.go | 2 +- .../apiv1/Client/ListDeployments/main.go | 2 +- .../apiv1/Client/ReplaceDeployment/main.go | 2 +- .../apiv1/Client/UninstallDeployment/main.go | 2 +- .../IamPolicyClient/GetIamPolicy/main.go | 2 +- .../IamPolicyClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../apiv2/PoliciesClient/CreatePolicy/main.go | 2 +- .../apiv2/PoliciesClient/DeletePolicy/main.go | 2 +- .../apiv2/PoliciesClient/GetOperation/main.go | 2 +- .../apiv2/PoliciesClient/GetPolicy/main.go | 2 +- .../apiv2/PoliciesClient/ListPolicies/main.go | 2 +- .../apiv2/PoliciesClient/UpdatePolicy/main.go | 2 +- .../GenerateAccessToken/main.go | 2 +- .../GenerateIdToken/main.go | 2 +- .../IamCredentialsClient/SignBlob/main.go | 2 +- .../IamCredentialsClient/SignJwt/main.go | 2 +- .../CreateTunnelDestGroup/main.go | 2 +- .../DeleteTunnelDestGroup/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetIapSettings/main.go | 2 +- .../GetTunnelDestGroup/main.go | 2 +- .../ListTunnelDestGroups/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateIapSettings/main.go | 2 +- .../UpdateTunnelDestGroup/main.go | 2 +- .../CreateBrand/main.go | 2 +- .../CreateIdentityAwareProxyClient/main.go | 2 +- .../DeleteIdentityAwareProxyClient/main.go | 2 +- .../GetBrand/main.go | 2 +- .../GetIdentityAwareProxyClient/main.go | 2 +- .../ListBrands/main.go | 2 +- .../ListIdentityAwareProxyClients/main.go | 2 +- .../main.go | 2 +- .../FinalizeMfaEnrollment/main.go | 2 +- .../StartMfaEnrollment/main.go | 2 +- .../WithdrawMfa/main.go | 2 +- .../FinalizeMfaSignIn/main.go | 2 +- .../StartMfaSignIn/main.go | 2 +- ...adata.google.cloud.identitytoolkit.v2.json | 2 +- .../ids/apiv1/Client/CreateEndpoint/main.go | 2 +- .../ids/apiv1/Client/DeleteEndpoint/main.go | 2 +- .../ids/apiv1/Client/GetEndpoint/main.go | 2 +- .../ids/apiv1/Client/ListEndpoints/main.go | 2 +- .../BindDeviceToGateway/main.go | 2 +- .../DeviceManagerClient/CreateDevice/main.go | 2 +- .../CreateDeviceRegistry/main.go | 2 +- .../DeviceManagerClient/DeleteDevice/main.go | 2 +- .../DeleteDeviceRegistry/main.go | 2 +- .../DeviceManagerClient/GetDevice/main.go | 2 +- .../GetDeviceRegistry/main.go | 2 +- .../DeviceManagerClient/GetIamPolicy/main.go | 2 +- .../ListDeviceConfigVersions/main.go | 2 +- .../ListDeviceRegistries/main.go | 2 +- .../ListDeviceStates/main.go | 2 +- .../DeviceManagerClient/ListDevices/main.go | 2 +- .../ModifyCloudToDeviceConfig/main.go | 2 +- .../SendCommandToDevice/main.go | 2 +- .../DeviceManagerClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UnbindDeviceFromGateway/main.go | 2 +- .../DeviceManagerClient/UpdateDevice/main.go | 2 +- .../UpdateDeviceRegistry/main.go | 2 +- .../GetAutokeyConfig/main.go | 2 +- .../AutokeyAdminClient/GetIamPolicy/main.go | 2 +- .../AutokeyAdminClient/GetLocation/main.go | 2 +- .../AutokeyAdminClient/GetOperation/main.go | 2 +- .../AutokeyAdminClient/ListLocations/main.go | 2 +- .../AutokeyAdminClient/SetIamPolicy/main.go | 2 +- .../ShowEffectiveAutokeyConfig/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateAutokeyConfig/main.go | 2 +- .../AutokeyClient/CreateKeyHandle/main.go | 2 +- .../apiv1/AutokeyClient/GetIamPolicy/main.go | 2 +- .../apiv1/AutokeyClient/GetKeyHandle/main.go | 2 +- .../apiv1/AutokeyClient/GetLocation/main.go | 2 +- .../apiv1/AutokeyClient/GetOperation/main.go | 2 +- .../AutokeyClient/ListKeyHandles/main.go | 2 +- .../apiv1/AutokeyClient/ListLocations/main.go | 2 +- .../apiv1/AutokeyClient/SetIamPolicy/main.go | 2 +- .../AutokeyClient/TestIamPermissions/main.go | 2 +- .../EkmClient/CreateEkmConnection/main.go | 2 +- .../kms/apiv1/EkmClient/GetEkmConfig/main.go | 2 +- .../apiv1/EkmClient/GetEkmConnection/main.go | 2 +- .../kms/apiv1/EkmClient/GetIamPolicy/main.go | 2 +- .../kms/apiv1/EkmClient/GetLocation/main.go | 2 +- .../kms/apiv1/EkmClient/GetOperation/main.go | 2 +- .../EkmClient/ListEkmConnections/main.go | 2 +- .../kms/apiv1/EkmClient/ListLocations/main.go | 2 +- .../kms/apiv1/EkmClient/SetIamPolicy/main.go | 2 +- .../EkmClient/TestIamPermissions/main.go | 2 +- .../apiv1/EkmClient/UpdateEkmConfig/main.go | 2 +- .../EkmClient/UpdateEkmConnection/main.go | 2 +- .../EkmClient/VerifyConnectivity/main.go | 2 +- .../AsymmetricDecrypt/main.go | 2 +- .../AsymmetricSign/main.go | 2 +- .../CreateCryptoKey/main.go | 2 +- .../CreateCryptoKeyVersion/main.go | 2 +- .../CreateImportJob/main.go | 2 +- .../KeyManagementClient/CreateKeyRing/main.go | 2 +- .../apiv1/KeyManagementClient/Decrypt/main.go | 2 +- .../DestroyCryptoKeyVersion/main.go | 2 +- .../apiv1/KeyManagementClient/Encrypt/main.go | 2 +- .../GenerateRandomBytes/main.go | 2 +- .../KeyManagementClient/GetCryptoKey/main.go | 2 +- .../GetCryptoKeyVersion/main.go | 2 +- .../KeyManagementClient/GetIamPolicy/main.go | 2 +- .../KeyManagementClient/GetImportJob/main.go | 2 +- .../KeyManagementClient/GetKeyRing/main.go | 2 +- .../KeyManagementClient/GetLocation/main.go | 2 +- .../KeyManagementClient/GetOperation/main.go | 2 +- .../KeyManagementClient/GetPublicKey/main.go | 2 +- .../ImportCryptoKeyVersion/main.go | 2 +- .../ListCryptoKeyVersions/main.go | 2 +- .../ListCryptoKeys/main.go | 2 +- .../ListImportJobs/main.go | 2 +- .../KeyManagementClient/ListKeyRings/main.go | 2 +- .../KeyManagementClient/ListLocations/main.go | 2 +- .../apiv1/KeyManagementClient/MacSign/main.go | 2 +- .../KeyManagementClient/MacVerify/main.go | 2 +- .../KeyManagementClient/RawDecrypt/main.go | 2 +- .../KeyManagementClient/RawEncrypt/main.go | 2 +- .../RestoreCryptoKeyVersion/main.go | 2 +- .../KeyManagementClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateCryptoKey/main.go | 2 +- .../UpdateCryptoKeyPrimaryVersion/main.go | 2 +- .../UpdateCryptoKeyVersion/main.go | 2 +- .../snippet_metadata.google.cloud.kms.v1.json | 2 +- .../KeyDashboardClient/ListCryptoKeys/main.go | 2 +- .../GetProtectedResourcesSummary/main.go | 2 +- .../SearchProtectedResources/main.go | 2 +- ...etadata.google.cloud.kms.inventory.v1.json | 2 +- .../apiv1/Client/AnalyzeEntities/main.go | 2 +- .../Client/AnalyzeEntitySentiment/main.go | 2 +- .../apiv1/Client/AnalyzeSentiment/main.go | 2 +- .../apiv1/Client/AnalyzeSyntax/main.go | 2 +- .../apiv1/Client/AnnotateText/main.go | 2 +- .../apiv1/Client/ClassifyText/main.go | 2 +- .../apiv1/Client/ModerateText/main.go | 2 +- ...pet_metadata.google.cloud.language.v1.json | 2 +- .../apiv1beta2/Client/AnalyzeEntities/main.go | 2 +- .../Client/AnalyzeEntitySentiment/main.go | 2 +- .../Client/AnalyzeSentiment/main.go | 2 +- .../apiv1beta2/Client/AnalyzeSyntax/main.go | 2 +- .../apiv1beta2/Client/AnnotateText/main.go | 2 +- .../apiv1beta2/Client/ClassifyText/main.go | 2 +- .../apiv1beta2/Client/ModerateText/main.go | 2 +- ...etadata.google.cloud.language.v1beta2.json | 2 +- .../apiv2/Client/AnalyzeEntities/main.go | 2 +- .../apiv2/Client/AnalyzeSentiment/main.go | 2 +- .../apiv2/Client/AnnotateText/main.go | 2 +- .../apiv2/Client/ClassifyText/main.go | 2 +- .../apiv2/Client/ModerateText/main.go | 2 +- ...pet_metadata.google.cloud.language.v2.json | 2 +- .../CancelOperation/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../RunPipeline/main.go | 2 +- .../apiv2/Client/CancelOperation/main.go | 2 +- .../logging/apiv2/Client/DeleteLog/main.go | 2 +- .../logging/apiv2/Client/GetOperation/main.go | 2 +- .../apiv2/Client/ListLogEntries/main.go | 2 +- .../logging/apiv2/Client/ListLogs/main.go | 2 +- .../ListMonitoredResourceDescriptors/main.go | 2 +- .../apiv2/Client/ListOperations/main.go | 2 +- .../apiv2/Client/TailLogEntries/main.go | 2 +- .../apiv2/Client/WriteLogEntries/main.go | 2 +- .../ConfigClient/CancelOperation/main.go | 2 +- .../apiv2/ConfigClient/CopyLogEntries/main.go | 2 +- .../apiv2/ConfigClient/CreateBucket/main.go | 2 +- .../ConfigClient/CreateBucketAsync/main.go | 2 +- .../ConfigClient/CreateExclusion/main.go | 2 +- .../apiv2/ConfigClient/CreateLink/main.go | 2 +- .../apiv2/ConfigClient/CreateSink/main.go | 2 +- .../apiv2/ConfigClient/CreateView/main.go | 2 +- .../apiv2/ConfigClient/DeleteBucket/main.go | 2 +- .../ConfigClient/DeleteExclusion/main.go | 2 +- .../apiv2/ConfigClient/DeleteLink/main.go | 2 +- .../apiv2/ConfigClient/DeleteSink/main.go | 2 +- .../apiv2/ConfigClient/DeleteView/main.go | 2 +- .../apiv2/ConfigClient/GetBucket/main.go | 2 +- .../ConfigClient/GetCmekSettings/main.go | 2 +- .../apiv2/ConfigClient/GetExclusion/main.go | 2 +- .../apiv2/ConfigClient/GetLink/main.go | 2 +- .../apiv2/ConfigClient/GetOperation/main.go | 2 +- .../apiv2/ConfigClient/GetSettings/main.go | 2 +- .../apiv2/ConfigClient/GetSink/main.go | 2 +- .../apiv2/ConfigClient/GetView/main.go | 2 +- .../apiv2/ConfigClient/ListBuckets/main.go | 2 +- .../apiv2/ConfigClient/ListExclusions/main.go | 2 +- .../apiv2/ConfigClient/ListLinks/main.go | 2 +- .../apiv2/ConfigClient/ListOperations/main.go | 2 +- .../apiv2/ConfigClient/ListSinks/main.go | 2 +- .../apiv2/ConfigClient/ListViews/main.go | 2 +- .../apiv2/ConfigClient/UndeleteBucket/main.go | 2 +- .../apiv2/ConfigClient/UpdateBucket/main.go | 2 +- .../ConfigClient/UpdateBucketAsync/main.go | 2 +- .../ConfigClient/UpdateCmekSettings/main.go | 2 +- .../ConfigClient/UpdateExclusion/main.go | 2 +- .../apiv2/ConfigClient/UpdateSettings/main.go | 2 +- .../apiv2/ConfigClient/UpdateSink/main.go | 2 +- .../apiv2/ConfigClient/UpdateView/main.go | 2 +- .../MetricsClient/CancelOperation/main.go | 2 +- .../MetricsClient/CreateLogMetric/main.go | 2 +- .../MetricsClient/DeleteLogMetric/main.go | 2 +- .../apiv2/MetricsClient/GetLogMetric/main.go | 2 +- .../apiv2/MetricsClient/GetOperation/main.go | 2 +- .../MetricsClient/ListLogMetrics/main.go | 2 +- .../MetricsClient/ListOperations/main.go | 2 +- .../MetricsClient/UpdateLogMetric/main.go | 2 +- .../snippet_metadata.google.logging.v2.json | 2 +- .../OperationsClient/CancelOperation/main.go | 2 +- .../OperationsClient/DeleteOperation/main.go | 2 +- .../OperationsClient/GetOperation/main.go | 2 +- .../OperationsClient/ListOperations/main.go | 2 +- .../OperationsClient/WaitOperation/main.go | 2 +- .../apiv1/Client/AttachTrust/main.go | 2 +- .../Client/CreateMicrosoftAdDomain/main.go | 2 +- .../apiv1/Client/DeleteDomain/main.go | 2 +- .../apiv1/Client/DetachTrust/main.go | 2 +- .../apiv1/Client/GetDomain/main.go | 2 +- .../apiv1/Client/ListDomains/main.go | 2 +- .../apiv1/Client/ReconfigureTrust/main.go | 2 +- .../apiv1/Client/ResetAdminPassword/main.go | 2 +- .../apiv1/Client/UpdateDomain/main.go | 2 +- .../apiv1/Client/ValidateTrust/main.go | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apiv1/Client/CreateCluster/main.go | 2 +- .../apiv1/Client/CreateTopic/main.go | 2 +- .../apiv1/Client/DeleteCluster/main.go | 2 +- .../apiv1/Client/DeleteConsumerGroup/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../apiv1/Client/DeleteTopic/main.go | 2 +- .../apiv1/Client/GetCluster/main.go | 2 +- .../apiv1/Client/GetConsumerGroup/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/GetTopic/main.go | 2 +- .../apiv1/Client/ListClusters/main.go | 2 +- .../apiv1/Client/ListConsumerGroups/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/ListTopics/main.go | 2 +- .../apiv1/Client/UpdateCluster/main.go | 2 +- .../apiv1/Client/UpdateConsumerGroup/main.go | 2 +- .../apiv1/Client/UpdateTopic/main.go | 2 +- ...metadata.google.cloud.managedkafka.v1.json | 2 +- .../Client/ProvideValidationFeedback/main.go | 2 +- .../apiv1/Client/ValidateAddress/main.go | 2 +- ...data.google.maps.addressvalidation.v1.json | 2 +- .../apiv1/Client/ComputeInsights/main.go | 2 +- ..._metadata.google.maps.areainsights.v1.json | 2 +- .../apiv1/TripClient/CreateTrip/main.go | 2 +- .../apiv1/TripClient/GetTrip/main.go | 2 +- .../TripClient/ReportBillableTrip/main.go | 2 +- .../apiv1/TripClient/SearchTrips/main.go | 2 +- .../apiv1/TripClient/UpdateTrip/main.go | 2 +- .../apiv1/VehicleClient/CreateVehicle/main.go | 2 +- .../apiv1/VehicleClient/GetVehicle/main.go | 2 +- .../apiv1/VehicleClient/ListVehicles/main.go | 2 +- .../VehicleClient/SearchVehicles/main.go | 2 +- .../apiv1/VehicleClient/UpdateVehicle/main.go | 2 +- .../UpdateVehicleAttributes/main.go | 2 +- .../snippet_metadata.maps.fleetengine.v1.json | 2 +- .../apiv1/Client/BatchCreateTasks/main.go | 2 +- .../Client/CreateDeliveryVehicle/main.go | 2 +- .../delivery/apiv1/Client/CreateTask/main.go | 2 +- .../apiv1/Client/GetDeliveryVehicle/main.go | 2 +- .../delivery/apiv1/Client/GetTask/main.go | 2 +- .../apiv1/Client/GetTaskTrackingInfo/main.go | 2 +- .../apiv1/Client/ListDeliveryVehicles/main.go | 2 +- .../delivery/apiv1/Client/ListTasks/main.go | 2 +- .../Client/UpdateDeliveryVehicle/main.go | 2 +- .../delivery/apiv1/Client/UpdateTask/main.go | 2 +- ...metadata.maps.fleetengine.delivery.v1.json | 2 +- .../apiv1/Client/AutocompletePlaces/main.go | 2 +- .../places/apiv1/Client/GetPhotoMedia/main.go | 2 +- .../maps/places/apiv1/Client/GetPlace/main.go | 2 +- .../places/apiv1/Client/SearchNearby/main.go | 2 +- .../places/apiv1/Client/SearchText/main.go | 2 +- ...nippet_metadata.google.maps.places.v1.json | 2 +- .../apiv1/Client/BatchOptimizeTours/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/OptimizeTours/main.go | 2 +- ...data.google.maps.routeoptimization.v1.json | 2 +- .../apiv2/RoutesClient/ComputeRoutes/main.go | 2 +- ...ippet_metadata.google.maps.routing.v2.json | 2 +- .../FindClosestBuildingInsights/main.go | 2 +- .../solar/apiv1/Client/GetDataLayers/main.go | 2 +- .../solar/apiv1/Client/GetGeoTiff/main.go | 2 +- ...snippet_metadata.google.maps.solar.v1.json | 2 +- .../StreamingTranslateSpeech/main.go | 2 +- .../ApplyParameters/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateInstance/main.go | 2 +- .../DeleteInstance/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../CloudMemcacheClient/GetInstance/main.go | 2 +- .../CloudMemcacheClient/GetLocation/main.go | 2 +- .../CloudMemcacheClient/GetOperation/main.go | 2 +- .../CloudMemcacheClient/ListInstances/main.go | 2 +- .../CloudMemcacheClient/ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../RescheduleMaintenance/main.go | 2 +- .../UpdateInstance/main.go | 2 +- .../UpdateParameters/main.go | 2 +- .../ApplyParameters/main.go | 2 +- .../ApplySoftwareUpdate/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateInstance/main.go | 2 +- .../DeleteInstance/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../CloudMemcacheClient/GetInstance/main.go | 2 +- .../CloudMemcacheClient/GetLocation/main.go | 2 +- .../CloudMemcacheClient/GetOperation/main.go | 2 +- .../CloudMemcacheClient/ListInstances/main.go | 2 +- .../CloudMemcacheClient/ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../RescheduleMaintenance/main.go | 2 +- .../UpdateInstance/main.go | 2 +- .../UpdateParameters/main.go | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apiv1/Client/CreateInstance/main.go | 2 +- .../apiv1/Client/DeleteInstance/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../Client/GetCertificateAuthority/main.go | 2 +- .../apiv1/Client/GetInstance/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/ListInstances/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/UpdateInstance/main.go | 2 +- ..._metadata.google.cloud.memorystore.v1.json | 2 +- .../apiv1beta/Client/CancelOperation/main.go | 2 +- .../apiv1beta/Client/CreateInstance/main.go | 2 +- .../apiv1beta/Client/DeleteInstance/main.go | 2 +- .../apiv1beta/Client/DeleteOperation/main.go | 2 +- .../Client/GetCertificateAuthority/main.go | 2 +- .../apiv1beta/Client/GetInstance/main.go | 2 +- .../apiv1beta/Client/GetLocation/main.go | 2 +- .../apiv1beta/Client/GetOperation/main.go | 2 +- .../apiv1beta/Client/ListInstances/main.go | 2 +- .../apiv1beta/Client/ListLocations/main.go | 2 +- .../apiv1beta/Client/ListOperations/main.go | 2 +- .../apiv1beta/Client/UpdateInstance/main.go | 2 +- ...adata.google.cloud.memorystore.v1beta.json | 2 +- .../AlterMetadataResourceLocation/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateBackup/main.go | 2 +- .../CreateMetadataImport/main.go | 2 +- .../CreateService/main.go | 2 +- .../DeleteBackup/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../DeleteService/main.go | 2 +- .../ExportMetadata/main.go | 2 +- .../DataprocMetastoreClient/GetBackup/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetMetadataImport/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetService/main.go | 2 +- .../ListBackups/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListMetadataImports/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListServices/main.go | 2 +- .../MoveTableToDatabase/main.go | 2 +- .../QueryMetadata/main.go | 2 +- .../RestoreService/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateMetadataImport/main.go | 2 +- .../UpdateService/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateFederation/main.go | 2 +- .../DeleteFederation/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../GetFederation/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListFederations/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateFederation/main.go | 2 +- .../AlterMetadataResourceLocation/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateBackup/main.go | 2 +- .../CreateMetadataImport/main.go | 2 +- .../CreateService/main.go | 2 +- .../DeleteBackup/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../DeleteService/main.go | 2 +- .../ExportMetadata/main.go | 2 +- .../DataprocMetastoreClient/GetBackup/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetMetadataImport/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetService/main.go | 2 +- .../ListBackups/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListMetadataImports/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListServices/main.go | 2 +- .../MoveTableToDatabase/main.go | 2 +- .../QueryMetadata/main.go | 2 +- .../RemoveIamPolicy/main.go | 2 +- .../RestoreService/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateMetadataImport/main.go | 2 +- .../UpdateService/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateFederation/main.go | 2 +- .../DeleteFederation/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../GetFederation/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListFederations/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateFederation/main.go | 2 +- .../AlterMetadataResourceLocation/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateBackup/main.go | 2 +- .../CreateMetadataImport/main.go | 2 +- .../CreateService/main.go | 2 +- .../DeleteBackup/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../DeleteService/main.go | 2 +- .../ExportMetadata/main.go | 2 +- .../DataprocMetastoreClient/GetBackup/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetMetadataImport/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetService/main.go | 2 +- .../ListBackups/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListMetadataImports/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListServices/main.go | 2 +- .../MoveTableToDatabase/main.go | 2 +- .../QueryMetadata/main.go | 2 +- .../RemoveIamPolicy/main.go | 2 +- .../RestoreService/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateMetadataImport/main.go | 2 +- .../UpdateService/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateFederation/main.go | 2 +- .../DeleteFederation/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../GetFederation/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListFederations/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateFederation/main.go | 2 +- .../apiv1/Client/AddAssetsToGroup/main.go | 2 +- .../Client/AggregateAssetsValues/main.go | 2 +- .../apiv1/Client/BatchDeleteAssets/main.go | 2 +- .../apiv1/Client/BatchUpdateAssets/main.go | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apiv1/Client/CreateGroup/main.go | 2 +- .../apiv1/Client/CreateImportDataFile/main.go | 2 +- .../apiv1/Client/CreateImportJob/main.go | 2 +- .../apiv1/Client/CreatePreferenceSet/main.go | 2 +- .../apiv1/Client/CreateReport/main.go | 2 +- .../apiv1/Client/CreateReportConfig/main.go | 2 +- .../apiv1/Client/CreateSource/main.go | 2 +- .../apiv1/Client/DeleteAsset/main.go | 2 +- .../apiv1/Client/DeleteGroup/main.go | 2 +- .../apiv1/Client/DeleteImportDataFile/main.go | 2 +- .../apiv1/Client/DeleteImportJob/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../apiv1/Client/DeletePreferenceSet/main.go | 2 +- .../apiv1/Client/DeleteReport/main.go | 2 +- .../apiv1/Client/DeleteReportConfig/main.go | 2 +- .../apiv1/Client/DeleteSource/main.go | 2 +- .../apiv1/Client/GetAsset/main.go | 2 +- .../apiv1/Client/GetErrorFrame/main.go | 2 +- .../apiv1/Client/GetGroup/main.go | 2 +- .../apiv1/Client/GetImportDataFile/main.go | 2 +- .../apiv1/Client/GetImportJob/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/GetPreferenceSet/main.go | 2 +- .../apiv1/Client/GetReport/main.go | 2 +- .../apiv1/Client/GetReportConfig/main.go | 2 +- .../apiv1/Client/GetSettings/main.go | 2 +- .../apiv1/Client/GetSource/main.go | 2 +- .../apiv1/Client/ListAssets/main.go | 2 +- .../apiv1/Client/ListErrorFrames/main.go | 2 +- .../apiv1/Client/ListGroups/main.go | 2 +- .../apiv1/Client/ListImportDataFiles/main.go | 2 +- .../apiv1/Client/ListImportJobs/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/ListPreferenceSets/main.go | 2 +- .../apiv1/Client/ListReportConfigs/main.go | 2 +- .../apiv1/Client/ListReports/main.go | 2 +- .../apiv1/Client/ListSources/main.go | 2 +- .../Client/RemoveAssetsFromGroup/main.go | 2 +- .../apiv1/Client/ReportAssetFrames/main.go | 2 +- .../apiv1/Client/RunImportJob/main.go | 2 +- .../apiv1/Client/UpdateAsset/main.go | 2 +- .../apiv1/Client/UpdateGroup/main.go | 2 +- .../apiv1/Client/UpdateImportJob/main.go | 2 +- .../apiv1/Client/UpdatePreferenceSet/main.go | 2 +- .../apiv1/Client/UpdateSettings/main.go | 2 +- .../apiv1/Client/UpdateSource/main.go | 2 +- .../apiv1/Client/ValidateImportJob/main.go | 2 +- ...adata.google.cloud.migrationcenter.v1.json | 2 +- .../CreateAlertPolicy/main.go | 2 +- .../DeleteAlertPolicy/main.go | 2 +- .../AlertPolicyClient/GetAlertPolicy/main.go | 2 +- .../ListAlertPolicies/main.go | 2 +- .../UpdateAlertPolicy/main.go | 2 +- .../apiv3/v2/GroupClient/CreateGroup/main.go | 2 +- .../apiv3/v2/GroupClient/DeleteGroup/main.go | 2 +- .../apiv3/v2/GroupClient/GetGroup/main.go | 2 +- .../v2/GroupClient/ListGroupMembers/main.go | 2 +- .../apiv3/v2/GroupClient/ListGroups/main.go | 2 +- .../apiv3/v2/GroupClient/UpdateGroup/main.go | 2 +- .../CreateMetricDescriptor/main.go | 2 +- .../CreateServiceTimeSeries/main.go | 2 +- .../v2/MetricClient/CreateTimeSeries/main.go | 2 +- .../DeleteMetricDescriptor/main.go | 2 +- .../MetricClient/GetMetricDescriptor/main.go | 2 +- .../GetMonitoredResourceDescriptor/main.go | 2 +- .../ListMetricDescriptors/main.go | 2 +- .../ListMonitoredResourceDescriptors/main.go | 2 +- .../v2/MetricClient/ListTimeSeries/main.go | 2 +- .../CreateNotificationChannel/main.go | 2 +- .../DeleteNotificationChannel/main.go | 2 +- .../GetNotificationChannel/main.go | 2 +- .../GetNotificationChannelDescriptor/main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../ListNotificationChannels/main.go | 2 +- .../main.go | 2 +- .../UpdateNotificationChannel/main.go | 2 +- .../VerifyNotificationChannel/main.go | 2 +- .../v2/QueryClient/QueryTimeSeries/main.go | 2 +- .../CreateService/main.go | 2 +- .../CreateServiceLevelObjective/main.go | 2 +- .../DeleteService/main.go | 2 +- .../DeleteServiceLevelObjective/main.go | 2 +- .../GetService/main.go | 2 +- .../GetServiceLevelObjective/main.go | 2 +- .../ListServiceLevelObjectives/main.go | 2 +- .../ListServices/main.go | 2 +- .../UpdateService/main.go | 2 +- .../UpdateServiceLevelObjective/main.go | 2 +- .../v2/SnoozeClient/CreateSnooze/main.go | 2 +- .../apiv3/v2/SnoozeClient/GetSnooze/main.go | 2 +- .../apiv3/v2/SnoozeClient/ListSnoozes/main.go | 2 +- .../v2/SnoozeClient/UpdateSnooze/main.go | 2 +- .../CreateUptimeCheckConfig/main.go | 2 +- .../DeleteUptimeCheckConfig/main.go | 2 +- .../GetUptimeCheckConfig/main.go | 2 +- .../ListUptimeCheckConfigs/main.go | 2 +- .../ListUptimeCheckIps/main.go | 2 +- .../UpdateUptimeCheckConfig/main.go | 2 +- ...snippet_metadata.google.monitoring.v3.json | 2 +- .../DashboardsClient/CreateDashboard/main.go | 2 +- .../DashboardsClient/DeleteDashboard/main.go | 2 +- .../DashboardsClient/GetDashboard/main.go | 2 +- .../DashboardsClient/ListDashboards/main.go | 2 +- .../DashboardsClient/UpdateDashboard/main.go | 2 +- ...tadata.google.monitoring.dashboard.v1.json | 2 +- .../CreateMonitoredProject/main.go | 2 +- .../DeleteMonitoredProject/main.go | 2 +- .../GetMetricsScope/main.go | 2 +- .../main.go | 2 +- ...ata.google.monitoring.metricsscope.v1.json | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../Client/CreateActiveDirectory/main.go | 2 +- .../netapp/apiv1/Client/CreateBackup/main.go | 2 +- .../apiv1/Client/CreateBackupPolicy/main.go | 2 +- .../apiv1/Client/CreateBackupVault/main.go | 2 +- .../apiv1/Client/CreateKmsConfig/main.go | 2 +- .../apiv1/Client/CreateReplication/main.go | 2 +- .../apiv1/Client/CreateSnapshot/main.go | 2 +- .../apiv1/Client/CreateStoragePool/main.go | 2 +- .../netapp/apiv1/Client/CreateVolume/main.go | 2 +- .../Client/DeleteActiveDirectory/main.go | 2 +- .../netapp/apiv1/Client/DeleteBackup/main.go | 2 +- .../apiv1/Client/DeleteBackupPolicy/main.go | 2 +- .../apiv1/Client/DeleteBackupVault/main.go | 2 +- .../apiv1/Client/DeleteKmsConfig/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../apiv1/Client/DeleteReplication/main.go | 2 +- .../apiv1/Client/DeleteSnapshot/main.go | 2 +- .../apiv1/Client/DeleteStoragePool/main.go | 2 +- .../netapp/apiv1/Client/DeleteVolume/main.go | 2 +- .../apiv1/Client/EncryptVolumes/main.go | 2 +- .../apiv1/Client/EstablishPeering/main.go | 2 +- .../apiv1/Client/GetActiveDirectory/main.go | 2 +- .../netapp/apiv1/Client/GetBackup/main.go | 2 +- .../apiv1/Client/GetBackupPolicy/main.go | 2 +- .../apiv1/Client/GetBackupVault/main.go | 2 +- .../netapp/apiv1/Client/GetKmsConfig/main.go | 2 +- .../netapp/apiv1/Client/GetLocation/main.go | 2 +- .../netapp/apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/GetReplication/main.go | 2 +- .../netapp/apiv1/Client/GetSnapshot/main.go | 2 +- .../apiv1/Client/GetStoragePool/main.go | 2 +- .../netapp/apiv1/Client/GetVolume/main.go | 2 +- .../Client/ListActiveDirectories/main.go | 2 +- .../apiv1/Client/ListBackupPolicies/main.go | 2 +- .../apiv1/Client/ListBackupVaults/main.go | 2 +- .../netapp/apiv1/Client/ListBackups/main.go | 2 +- .../apiv1/Client/ListKmsConfigs/main.go | 2 +- .../netapp/apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/ListReplications/main.go | 2 +- .../netapp/apiv1/Client/ListSnapshots/main.go | 2 +- .../apiv1/Client/ListStoragePools/main.go | 2 +- .../netapp/apiv1/Client/ListVolumes/main.go | 2 +- .../apiv1/Client/ResumeReplication/main.go | 2 +- .../ReverseReplicationDirection/main.go | 2 +- .../netapp/apiv1/Client/RevertVolume/main.go | 2 +- .../apiv1/Client/StopReplication/main.go | 2 +- .../Client/SwitchActiveReplicaZone/main.go | 2 +- .../apiv1/Client/SyncReplication/main.go | 2 +- .../Client/UpdateActiveDirectory/main.go | 2 +- .../netapp/apiv1/Client/UpdateBackup/main.go | 2 +- .../apiv1/Client/UpdateBackupPolicy/main.go | 2 +- .../apiv1/Client/UpdateBackupVault/main.go | 2 +- .../apiv1/Client/UpdateKmsConfig/main.go | 2 +- .../apiv1/Client/UpdateReplication/main.go | 2 +- .../apiv1/Client/UpdateSnapshot/main.go | 2 +- .../apiv1/Client/UpdateStoragePool/main.go | 2 +- .../netapp/apiv1/Client/UpdateVolume/main.go | 2 +- .../apiv1/Client/VerifyKmsConfig/main.go | 2 +- ...ippet_metadata.google.cloud.netapp.v1.json | 2 +- .../apiv1/HubClient/AcceptHubSpoke/main.go | 2 +- .../apiv1/HubClient/CancelOperation/main.go | 2 +- .../apiv1/HubClient/CreateHub/main.go | 2 +- .../apiv1/HubClient/CreateSpoke/main.go | 2 +- .../apiv1/HubClient/DeleteHub/main.go | 2 +- .../apiv1/HubClient/DeleteOperation/main.go | 2 +- .../apiv1/HubClient/DeleteSpoke/main.go | 2 +- .../apiv1/HubClient/GetGroup/main.go | 2 +- .../apiv1/HubClient/GetHub/main.go | 2 +- .../apiv1/HubClient/GetIamPolicy/main.go | 2 +- .../apiv1/HubClient/GetLocation/main.go | 2 +- .../apiv1/HubClient/GetOperation/main.go | 2 +- .../apiv1/HubClient/GetRoute/main.go | 2 +- .../apiv1/HubClient/GetRouteTable/main.go | 2 +- .../apiv1/HubClient/GetSpoke/main.go | 2 +- .../apiv1/HubClient/ListGroups/main.go | 2 +- .../apiv1/HubClient/ListHubSpokes/main.go | 2 +- .../apiv1/HubClient/ListHubs/main.go | 2 +- .../apiv1/HubClient/ListLocations/main.go | 2 +- .../apiv1/HubClient/ListOperations/main.go | 2 +- .../apiv1/HubClient/ListRouteTables/main.go | 2 +- .../apiv1/HubClient/ListRoutes/main.go | 2 +- .../apiv1/HubClient/ListSpokes/main.go | 2 +- .../apiv1/HubClient/QueryHubStatus/main.go | 2 +- .../apiv1/HubClient/RejectHubSpoke/main.go | 2 +- .../apiv1/HubClient/SetIamPolicy/main.go | 2 +- .../HubClient/TestIamPermissions/main.go | 2 +- .../apiv1/HubClient/UpdateGroup/main.go | 2 +- .../apiv1/HubClient/UpdateHub/main.go | 2 +- .../apiv1/HubClient/UpdateSpoke/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreatePolicyBasedRoute/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../DeletePolicyBasedRoute/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetPolicyBasedRoute/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListPolicyBasedRoutes/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../apiv1alpha1/HubClient/CreateHub/main.go | 2 +- .../apiv1alpha1/HubClient/CreateSpoke/main.go | 2 +- .../apiv1alpha1/HubClient/DeleteHub/main.go | 2 +- .../apiv1alpha1/HubClient/DeleteSpoke/main.go | 2 +- .../apiv1alpha1/HubClient/GetHub/main.go | 2 +- .../apiv1alpha1/HubClient/GetSpoke/main.go | 2 +- .../apiv1alpha1/HubClient/ListHubs/main.go | 2 +- .../apiv1alpha1/HubClient/ListSpokes/main.go | 2 +- .../apiv1alpha1/HubClient/UpdateHub/main.go | 2 +- .../apiv1alpha1/HubClient/UpdateSpoke/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateConnectivityTest/main.go | 2 +- .../DeleteConnectivityTest/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../GetConnectivityTest/main.go | 2 +- .../ReachabilityClient/GetIamPolicy/main.go | 2 +- .../ReachabilityClient/GetLocation/main.go | 2 +- .../ReachabilityClient/GetOperation/main.go | 2 +- .../ListConnectivityTests/main.go | 2 +- .../ReachabilityClient/ListLocations/main.go | 2 +- .../ReachabilityClient/ListOperations/main.go | 2 +- .../RerunConnectivityTest/main.go | 2 +- .../ReachabilityClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateConnectivityTest/main.go | 2 +- ...ata.google.cloud.networkmanagement.v1.json | 2 +- .../apiv1beta1/Client/CancelOperation/main.go | 2 +- .../Client/CreateAuthorizationPolicy/main.go | 2 +- .../Client/CreateClientTlsPolicy/main.go | 2 +- .../Client/CreateServerTlsPolicy/main.go | 2 +- .../Client/DeleteAuthorizationPolicy/main.go | 2 +- .../Client/DeleteClientTlsPolicy/main.go | 2 +- .../apiv1beta1/Client/DeleteOperation/main.go | 2 +- .../Client/DeleteServerTlsPolicy/main.go | 2 +- .../Client/GetAuthorizationPolicy/main.go | 2 +- .../Client/GetClientTlsPolicy/main.go | 2 +- .../apiv1beta1/Client/GetIamPolicy/main.go | 2 +- .../apiv1beta1/Client/GetLocation/main.go | 2 +- .../apiv1beta1/Client/GetOperation/main.go | 2 +- .../Client/GetServerTlsPolicy/main.go | 2 +- .../Client/ListAuthorizationPolicies/main.go | 2 +- .../Client/ListClientTlsPolicies/main.go | 2 +- .../apiv1beta1/Client/ListLocations/main.go | 2 +- .../apiv1beta1/Client/ListOperations/main.go | 2 +- .../Client/ListServerTlsPolicies/main.go | 2 +- .../apiv1beta1/Client/SetIamPolicy/main.go | 2 +- .../Client/TestIamPermissions/main.go | 2 +- .../Client/UpdateAuthorizationPolicy/main.go | 2 +- .../Client/UpdateClientTlsPolicy/main.go | 2 +- .../Client/UpdateServerTlsPolicy/main.go | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apiv1/Client/CreateEndpointPolicy/main.go | 2 +- .../apiv1/Client/CreateGateway/main.go | 2 +- .../apiv1/Client/CreateGrpcRoute/main.go | 2 +- .../apiv1/Client/CreateHttpRoute/main.go | 2 +- .../apiv1/Client/CreateMesh/main.go | 2 +- .../apiv1/Client/CreateServiceBinding/main.go | 2 +- .../apiv1/Client/CreateTcpRoute/main.go | 2 +- .../apiv1/Client/CreateTlsRoute/main.go | 2 +- .../apiv1/Client/DeleteEndpointPolicy/main.go | 2 +- .../apiv1/Client/DeleteGateway/main.go | 2 +- .../apiv1/Client/DeleteGrpcRoute/main.go | 2 +- .../apiv1/Client/DeleteHttpRoute/main.go | 2 +- .../apiv1/Client/DeleteMesh/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../apiv1/Client/DeleteServiceBinding/main.go | 2 +- .../apiv1/Client/DeleteTcpRoute/main.go | 2 +- .../apiv1/Client/DeleteTlsRoute/main.go | 2 +- .../apiv1/Client/GetEndpointPolicy/main.go | 2 +- .../apiv1/Client/GetGateway/main.go | 2 +- .../apiv1/Client/GetGrpcRoute/main.go | 2 +- .../apiv1/Client/GetHttpRoute/main.go | 2 +- .../apiv1/Client/GetIamPolicy/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetMesh/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/GetServiceBinding/main.go | 2 +- .../apiv1/Client/GetTcpRoute/main.go | 2 +- .../apiv1/Client/GetTlsRoute/main.go | 2 +- .../apiv1/Client/ListEndpointPolicies/main.go | 2 +- .../apiv1/Client/ListGateways/main.go | 2 +- .../apiv1/Client/ListGrpcRoutes/main.go | 2 +- .../apiv1/Client/ListHttpRoutes/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListMeshes/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/ListServiceBindings/main.go | 2 +- .../apiv1/Client/ListTcpRoutes/main.go | 2 +- .../apiv1/Client/ListTlsRoutes/main.go | 2 +- .../apiv1/Client/SetIamPolicy/main.go | 2 +- .../apiv1/Client/TestIamPermissions/main.go | 2 +- .../apiv1/Client/UpdateEndpointPolicy/main.go | 2 +- .../apiv1/Client/UpdateGateway/main.go | 2 +- .../apiv1/Client/UpdateGrpcRoute/main.go | 2 +- .../apiv1/Client/UpdateHttpRoute/main.go | 2 +- .../apiv1/Client/UpdateMesh/main.go | 2 +- .../apiv1/Client/UpdateTcpRoute/main.go | 2 +- .../apiv1/Client/UpdateTlsRoute/main.go | 2 +- .../apiv1/DepClient/CancelOperation/main.go | 2 +- .../DepClient/CreateLbRouteExtension/main.go | 2 +- .../CreateLbTrafficExtension/main.go | 2 +- .../DepClient/DeleteLbRouteExtension/main.go | 2 +- .../DeleteLbTrafficExtension/main.go | 2 +- .../apiv1/DepClient/DeleteOperation/main.go | 2 +- .../apiv1/DepClient/GetIamPolicy/main.go | 2 +- .../DepClient/GetLbRouteExtension/main.go | 2 +- .../DepClient/GetLbTrafficExtension/main.go | 2 +- .../apiv1/DepClient/GetLocation/main.go | 2 +- .../apiv1/DepClient/GetOperation/main.go | 2 +- .../DepClient/ListLbRouteExtensions/main.go | 2 +- .../DepClient/ListLbTrafficExtensions/main.go | 2 +- .../apiv1/DepClient/ListLocations/main.go | 2 +- .../apiv1/DepClient/ListOperations/main.go | 2 +- .../apiv1/DepClient/SetIamPolicy/main.go | 2 +- .../DepClient/TestIamPermissions/main.go | 2 +- .../DepClient/UpdateLbRouteExtension/main.go | 2 +- .../UpdateLbTrafficExtension/main.go | 2 +- ...adata.google.cloud.networkservices.v1.json | 2 +- .../CancelOperation/main.go | 2 +- .../CreateRuntime/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../DeleteRuntime/main.go | 2 +- .../DiagnoseRuntime/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../ManagedNotebookClient/GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ManagedNotebookClient/GetRuntime/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListRuntimes/main.go | 2 +- .../RefreshRuntimeTokenInternal/main.go | 2 +- .../ReportRuntimeEvent/main.go | 2 +- .../ResetRuntime/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../StartRuntime/main.go | 2 +- .../ManagedNotebookClient/StopRuntime/main.go | 2 +- .../SwitchRuntime/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateRuntime/main.go | 2 +- .../UpgradeRuntime/main.go | 2 +- .../NotebookClient/CancelOperation/main.go | 2 +- .../NotebookClient/CreateEnvironment/main.go | 2 +- .../NotebookClient/CreateExecution/main.go | 2 +- .../NotebookClient/CreateInstance/main.go | 2 +- .../NotebookClient/CreateSchedule/main.go | 2 +- .../NotebookClient/DeleteEnvironment/main.go | 2 +- .../NotebookClient/DeleteExecution/main.go | 2 +- .../NotebookClient/DeleteInstance/main.go | 2 +- .../NotebookClient/DeleteOperation/main.go | 2 +- .../NotebookClient/DeleteSchedule/main.go | 2 +- .../NotebookClient/DiagnoseInstance/main.go | 2 +- .../NotebookClient/GetEnvironment/main.go | 2 +- .../apiv1/NotebookClient/GetExecution/main.go | 2 +- .../apiv1/NotebookClient/GetIamPolicy/main.go | 2 +- .../apiv1/NotebookClient/GetInstance/main.go | 2 +- .../NotebookClient/GetInstanceHealth/main.go | 2 +- .../apiv1/NotebookClient/GetLocation/main.go | 2 +- .../apiv1/NotebookClient/GetOperation/main.go | 2 +- .../apiv1/NotebookClient/GetSchedule/main.go | 2 +- .../IsInstanceUpgradeable/main.go | 2 +- .../NotebookClient/ListEnvironments/main.go | 2 +- .../NotebookClient/ListExecutions/main.go | 2 +- .../NotebookClient/ListInstances/main.go | 2 +- .../NotebookClient/ListLocations/main.go | 2 +- .../NotebookClient/ListOperations/main.go | 2 +- .../NotebookClient/ListSchedules/main.go | 2 +- .../NotebookClient/RegisterInstance/main.go | 2 +- .../NotebookClient/ReportInstanceInfo/main.go | 2 +- .../NotebookClient/ResetInstance/main.go | 2 +- .../NotebookClient/RollbackInstance/main.go | 2 +- .../apiv1/NotebookClient/SetIamPolicy/main.go | 2 +- .../SetInstanceAccelerator/main.go | 2 +- .../NotebookClient/SetInstanceLabels/main.go | 2 +- .../SetInstanceMachineType/main.go | 2 +- .../NotebookClient/StartInstance/main.go | 2 +- .../apiv1/NotebookClient/StopInstance/main.go | 2 +- .../NotebookClient/TestIamPermissions/main.go | 2 +- .../NotebookClient/TriggerSchedule/main.go | 2 +- .../UpdateInstanceConfig/main.go | 2 +- .../UpdateInstanceMetadataItems/main.go | 2 +- .../UpdateShieldedInstanceConfig/main.go | 2 +- .../NotebookClient/UpgradeInstance/main.go | 2 +- .../UpgradeInstanceInternal/main.go | 2 +- .../NotebookClient/CancelOperation/main.go | 2 +- .../NotebookClient/CreateEnvironment/main.go | 2 +- .../NotebookClient/CreateInstance/main.go | 2 +- .../NotebookClient/DeleteEnvironment/main.go | 2 +- .../NotebookClient/DeleteInstance/main.go | 2 +- .../NotebookClient/DeleteOperation/main.go | 2 +- .../NotebookClient/GetEnvironment/main.go | 2 +- .../NotebookClient/GetIamPolicy/main.go | 2 +- .../NotebookClient/GetInstance/main.go | 2 +- .../NotebookClient/GetLocation/main.go | 2 +- .../NotebookClient/GetOperation/main.go | 2 +- .../IsInstanceUpgradeable/main.go | 2 +- .../NotebookClient/ListEnvironments/main.go | 2 +- .../NotebookClient/ListInstances/main.go | 2 +- .../NotebookClient/ListLocations/main.go | 2 +- .../NotebookClient/ListOperations/main.go | 2 +- .../NotebookClient/RegisterInstance/main.go | 2 +- .../NotebookClient/ReportInstanceInfo/main.go | 2 +- .../NotebookClient/ResetInstance/main.go | 2 +- .../NotebookClient/SetIamPolicy/main.go | 2 +- .../SetInstanceAccelerator/main.go | 2 +- .../NotebookClient/SetInstanceLabels/main.go | 2 +- .../SetInstanceMachineType/main.go | 2 +- .../NotebookClient/StartInstance/main.go | 2 +- .../NotebookClient/StopInstance/main.go | 2 +- .../NotebookClient/TestIamPermissions/main.go | 2 +- .../NotebookClient/UpgradeInstance/main.go | 2 +- .../UpgradeInstanceInternal/main.go | 2 +- .../NotebookClient/CancelOperation/main.go | 2 +- .../CheckInstanceUpgradability/main.go | 2 +- .../NotebookClient/CreateInstance/main.go | 2 +- .../NotebookClient/DeleteInstance/main.go | 2 +- .../NotebookClient/DeleteOperation/main.go | 2 +- .../NotebookClient/DiagnoseInstance/main.go | 2 +- .../apiv2/NotebookClient/GetIamPolicy/main.go | 2 +- .../apiv2/NotebookClient/GetInstance/main.go | 2 +- .../apiv2/NotebookClient/GetLocation/main.go | 2 +- .../apiv2/NotebookClient/GetOperation/main.go | 2 +- .../NotebookClient/ListInstances/main.go | 2 +- .../NotebookClient/ListLocations/main.go | 2 +- .../NotebookClient/ListOperations/main.go | 2 +- .../NotebookClient/ResetInstance/main.go | 2 +- .../NotebookClient/RollbackInstance/main.go | 2 +- .../apiv2/NotebookClient/SetIamPolicy/main.go | 2 +- .../NotebookClient/StartInstance/main.go | 2 +- .../apiv2/NotebookClient/StopInstance/main.go | 2 +- .../NotebookClient/TestIamPermissions/main.go | 2 +- .../NotebookClient/UpdateInstance/main.go | 2 +- .../NotebookClient/UpgradeInstance/main.go | 2 +- .../BatchOptimizeTours/main.go | 2 +- .../FleetRoutingClient/GetOperation/main.go | 2 +- .../FleetRoutingClient/OptimizeTours/main.go | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../Client/CreateAutonomousDatabase/main.go | 2 +- .../CreateCloudExadataInfrastructure/main.go | 2 +- .../apiv1/Client/CreateCloudVmCluster/main.go | 2 +- .../Client/DeleteAutonomousDatabase/main.go | 2 +- .../DeleteCloudExadataInfrastructure/main.go | 2 +- .../apiv1/Client/DeleteCloudVmCluster/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../GenerateAutonomousDatabaseWallet/main.go | 2 +- .../Client/GetAutonomousDatabase/main.go | 2 +- .../GetCloudExadataInfrastructure/main.go | 2 +- .../apiv1/Client/GetCloudVmCluster/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../ListAutonomousDatabaseBackups/main.go | 2 +- .../main.go | 2 +- .../Client/ListAutonomousDatabases/main.go | 2 +- .../Client/ListAutonomousDbVersions/main.go | 2 +- .../ListCloudExadataInfrastructures/main.go | 2 +- .../apiv1/Client/ListCloudVmClusters/main.go | 2 +- .../apiv1/Client/ListDbNodes/main.go | 2 +- .../apiv1/Client/ListDbServers/main.go | 2 +- .../apiv1/Client/ListDbSystemShapes/main.go | 2 +- .../apiv1/Client/ListEntitlements/main.go | 2 +- .../apiv1/Client/ListGiVersions/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../Client/RestoreAutonomousDatabase/main.go | 2 +- ...tadata.google.cloud.oracledatabase.v1.json | 2 +- .../EnvironmentsClient/CheckUpgrade/main.go | 2 +- .../CreateEnvironment/main.go | 2 +- .../CreateUserWorkloadsConfigMap/main.go | 2 +- .../CreateUserWorkloadsSecret/main.go | 2 +- .../DatabaseFailover/main.go | 2 +- .../DeleteEnvironment/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../DeleteUserWorkloadsConfigMap/main.go | 2 +- .../DeleteUserWorkloadsSecret/main.go | 2 +- .../ExecuteAirflowCommand/main.go | 2 +- .../FetchDatabaseProperties/main.go | 2 +- .../EnvironmentsClient/GetEnvironment/main.go | 2 +- .../EnvironmentsClient/GetOperation/main.go | 2 +- .../GetUserWorkloadsConfigMap/main.go | 2 +- .../GetUserWorkloadsSecret/main.go | 2 +- .../ListEnvironments/main.go | 2 +- .../EnvironmentsClient/ListOperations/main.go | 2 +- .../ListUserWorkloadsConfigMaps/main.go | 2 +- .../ListUserWorkloadsSecrets/main.go | 2 +- .../EnvironmentsClient/ListWorkloads/main.go | 2 +- .../EnvironmentsClient/LoadSnapshot/main.go | 2 +- .../PollAirflowCommand/main.go | 2 +- .../EnvironmentsClient/SaveSnapshot/main.go | 2 +- .../StopAirflowCommand/main.go | 2 +- .../UpdateEnvironment/main.go | 2 +- .../UpdateUserWorkloadsConfigMap/main.go | 2 +- .../UpdateUserWorkloadsSecret/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../ImageVersionsClient/GetOperation/main.go | 2 +- .../ListImageVersions/main.go | 2 +- .../ListOperations/main.go | 2 +- ...loud.orchestration.airflow.service.v1.json | 2 +- .../Client/CreateCustomConstraint/main.go | 2 +- .../apiv2/Client/CreatePolicy/main.go | 2 +- .../Client/DeleteCustomConstraint/main.go | 2 +- .../apiv2/Client/DeletePolicy/main.go | 2 +- .../apiv2/Client/GetCustomConstraint/main.go | 2 +- .../apiv2/Client/GetEffectivePolicy/main.go | 2 +- .../orgpolicy/apiv2/Client/GetPolicy/main.go | 2 +- .../apiv2/Client/ListConstraints/main.go | 2 +- .../Client/ListCustomConstraints/main.go | 2 +- .../apiv2/Client/ListPolicies/main.go | 2 +- .../Client/UpdateCustomConstraint/main.go | 2 +- .../apiv2/Client/UpdatePolicy/main.go | 2 +- ...et_metadata.google.cloud.orgpolicy.v2.json | 2 +- .../apiv1/Client/RegisterAgent/main.go | 2 +- .../apiv1/Client/ReportInventory/main.go | 2 +- .../apiv1/Client/ReportTaskComplete/main.go | 2 +- .../apiv1/Client/ReportTaskProgress/main.go | 2 +- .../apiv1/Client/StartNextTask/main.go | 2 +- ...oogle.cloud.osconfig.agentendpoint.v1.json | 2 +- .../Client/LookupEffectiveGuestPolicy/main.go | 2 +- .../apiv1beta/Client/RegisterAgent/main.go | 2 +- .../Client/ReportTaskComplete/main.go | 2 +- .../Client/ReportTaskProgress/main.go | 2 +- .../apiv1beta/Client/StartNextTask/main.go | 2 +- ...e.cloud.osconfig.agentendpoint.v1beta.json | 2 +- .../apiv1/Client/CancelPatchJob/main.go | 2 +- .../Client/CreatePatchDeployment/main.go | 2 +- .../Client/DeletePatchDeployment/main.go | 2 +- .../apiv1/Client/ExecutePatchJob/main.go | 2 +- .../apiv1/Client/GetPatchDeployment/main.go | 2 +- .../osconfig/apiv1/Client/GetPatchJob/main.go | 2 +- .../apiv1/Client/ListPatchDeployments/main.go | 2 +- .../ListPatchJobInstanceDetails/main.go | 2 +- .../apiv1/Client/ListPatchJobs/main.go | 2 +- .../apiv1/Client/PausePatchDeployment/main.go | 2 +- .../Client/ResumePatchDeployment/main.go | 2 +- .../Client/UpdatePatchDeployment/main.go | 2 +- .../CreateOSPolicyAssignment/main.go | 2 +- .../DeleteOSPolicyAssignment/main.go | 2 +- .../OsConfigZonalClient/GetInventory/main.go | 2 +- .../GetOSPolicyAssignment/main.go | 2 +- .../GetOSPolicyAssignmentReport/main.go | 2 +- .../GetVulnerabilityReport/main.go | 2 +- .../ListInventories/main.go | 2 +- .../ListOSPolicyAssignmentReports/main.go | 2 +- .../ListOSPolicyAssignmentRevisions/main.go | 2 +- .../ListOSPolicyAssignments/main.go | 2 +- .../ListVulnerabilityReports/main.go | 2 +- .../UpdateOSPolicyAssignment/main.go | 2 +- ...pet_metadata.google.cloud.osconfig.v1.json | 2 +- .../CreateOSPolicyAssignment/main.go | 2 +- .../DeleteOSPolicyAssignment/main.go | 2 +- .../GetInstanceOSPoliciesCompliance/main.go | 2 +- .../OsConfigZonalClient/GetInventory/main.go | 2 +- .../GetOSPolicyAssignment/main.go | 2 +- .../GetOSPolicyAssignmentReport/main.go | 2 +- .../GetVulnerabilityReport/main.go | 2 +- .../ListInstanceOSPoliciesCompliances/main.go | 2 +- .../ListInventories/main.go | 2 +- .../ListOSPolicyAssignmentReports/main.go | 2 +- .../ListOSPolicyAssignmentRevisions/main.go | 2 +- .../ListOSPolicyAssignments/main.go | 2 +- .../ListVulnerabilityReports/main.go | 2 +- .../UpdateOSPolicyAssignment/main.go | 2 +- ...etadata.google.cloud.osconfig.v1alpha.json | 2 +- .../apiv1beta/Client/CancelPatchJob/main.go | 2 +- .../Client/CreateGuestPolicy/main.go | 2 +- .../Client/CreatePatchDeployment/main.go | 2 +- .../Client/DeleteGuestPolicy/main.go | 2 +- .../Client/DeletePatchDeployment/main.go | 2 +- .../apiv1beta/Client/ExecutePatchJob/main.go | 2 +- .../apiv1beta/Client/GetGuestPolicy/main.go | 2 +- .../Client/GetPatchDeployment/main.go | 2 +- .../apiv1beta/Client/GetPatchJob/main.go | 2 +- .../Client/ListGuestPolicies/main.go | 2 +- .../Client/ListPatchDeployments/main.go | 2 +- .../ListPatchJobInstanceDetails/main.go | 2 +- .../apiv1beta/Client/ListPatchJobs/main.go | 2 +- .../Client/LookupEffectiveGuestPolicy/main.go | 2 +- .../Client/PausePatchDeployment/main.go | 2 +- .../Client/ResumePatchDeployment/main.go | 2 +- .../Client/UpdateGuestPolicy/main.go | 2 +- .../Client/UpdatePatchDeployment/main.go | 2 +- ...metadata.google.cloud.osconfig.v1beta.json | 2 +- .../apiv1/Client/CreateSshPublicKey/main.go | 2 +- .../apiv1/Client/DeletePosixAccount/main.go | 2 +- .../apiv1/Client/DeleteSshPublicKey/main.go | 2 +- .../apiv1/Client/GetLoginProfile/main.go | 2 +- .../apiv1/Client/GetSshPublicKey/main.go | 2 +- .../apiv1/Client/ImportSshPublicKey/main.go | 2 +- .../apiv1/Client/UpdateSshPublicKey/main.go | 2 +- ...ppet_metadata.google.cloud.oslogin.v1.json | 2 +- .../Client/CreateSshPublicKey/main.go | 2 +- .../Client/DeletePosixAccount/main.go | 2 +- .../Client/DeleteSshPublicKey/main.go | 2 +- .../apiv1beta/Client/GetLoginProfile/main.go | 2 +- .../apiv1beta/Client/GetSshPublicKey/main.go | 2 +- .../Client/ImportSshPublicKey/main.go | 2 +- .../apiv1beta/Client/SignSshPublicKey/main.go | 2 +- .../Client/UpdateSshPublicKey/main.go | 2 +- ..._metadata.google.cloud.oslogin.v1beta.json | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apiv1/Client/CreateInstance/main.go | 2 +- .../apiv1/Client/DeleteInstance/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../apiv1/Client/ExportData/main.go | 2 +- .../apiv1/Client/GetInstance/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/ImportData/main.go | 2 +- .../apiv1/Client/ListInstances/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/UpdateInstance/main.go | 2 +- ...etadata.google.cloud.parallelstore.v1.json | 2 +- .../apiv1beta/Client/CancelOperation/main.go | 2 +- .../apiv1beta/Client/CreateInstance/main.go | 2 +- .../apiv1beta/Client/DeleteInstance/main.go | 2 +- .../apiv1beta/Client/DeleteOperation/main.go | 2 +- .../apiv1beta/Client/ExportData/main.go | 2 +- .../apiv1beta/Client/GetInstance/main.go | 2 +- .../apiv1beta/Client/GetLocation/main.go | 2 +- .../apiv1beta/Client/GetOperation/main.go | 2 +- .../apiv1beta/Client/ImportData/main.go | 2 +- .../apiv1beta/Client/ListInstances/main.go | 2 +- .../apiv1beta/Client/ListLocations/main.go | 2 +- .../apiv1beta/Client/ListOperations/main.go | 2 +- .../apiv1beta/Client/UpdateInstance/main.go | 2 +- ...ata.google.cloud.parallelstore.v1beta.json | 2 +- .../ReportPhishing/main.go | 2 +- .../SimulatorClient/CreateReplay/main.go | 2 +- .../SimulatorClient/GetOperation/main.go | 2 +- .../apiv1/SimulatorClient/GetReplay/main.go | 2 +- .../SimulatorClient/ListOperations/main.go | 2 +- .../SimulatorClient/ListReplayResults/main.go | 2 +- .../TroubleshootIamPolicy/main.go | 2 +- .../TroubleshootIamPolicy/main.go | 2 +- .../apiv1beta1/Client/SearchCatalogs/main.go | 2 +- .../apiv1beta1/Client/SearchProducts/main.go | 2 +- .../apiv1beta1/Client/SearchVersions/main.go | 2 +- .../apiv1/Client/ApproveGrant/main.go | 2 +- .../Client/CheckOnboardingStatus/main.go | 2 +- .../apiv1/Client/CreateEntitlement/main.go | 2 +- .../apiv1/Client/CreateGrant/main.go | 2 +- .../apiv1/Client/DeleteEntitlement/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../apiv1/Client/DenyGrant/main.go | 2 +- .../apiv1/Client/GetEntitlement/main.go | 2 +- .../apiv1/Client/GetGrant/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/ListEntitlements/main.go | 2 +- .../apiv1/Client/ListGrants/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/RevokeGrant/main.go | 2 +- .../apiv1/Client/SearchEntitlements/main.go | 2 +- .../apiv1/Client/SearchGrants/main.go | 2 +- .../apiv1/Client/UpdateEntitlement/main.go | 2 +- ...ogle.cloud.privilegedaccessmanager.v1.json | 2 +- .../apiv1/PublisherClient/CreateTopic/main.go | 2 +- .../apiv1/PublisherClient/DeleteTopic/main.go | 2 +- .../DetachSubscription/main.go | 2 +- .../PublisherClient/GetIamPolicy/main.go | 2 +- .../apiv1/PublisherClient/GetTopic/main.go | 2 +- .../ListTopicSnapshots/main.go | 2 +- .../ListTopicSubscriptions/main.go | 2 +- .../apiv1/PublisherClient/ListTopics/main.go | 2 +- .../apiv1/PublisherClient/Publish/main.go | 2 +- .../PublisherClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../apiv1/PublisherClient/UpdateTopic/main.go | 2 +- .../apiv1/SchemaClient/CommitSchema/main.go | 2 +- .../apiv1/SchemaClient/CreateSchema/main.go | 2 +- .../apiv1/SchemaClient/DeleteSchema/main.go | 2 +- .../SchemaClient/DeleteSchemaRevision/main.go | 2 +- .../apiv1/SchemaClient/GetIamPolicy/main.go | 2 +- .../apiv1/SchemaClient/GetSchema/main.go | 2 +- .../SchemaClient/ListSchemaRevisions/main.go | 2 +- .../apiv1/SchemaClient/ListSchemas/main.go | 2 +- .../apiv1/SchemaClient/RollbackSchema/main.go | 2 +- .../apiv1/SchemaClient/SetIamPolicy/main.go | 2 +- .../SchemaClient/TestIamPermissions/main.go | 2 +- .../SchemaClient/ValidateMessage/main.go | 2 +- .../apiv1/SchemaClient/ValidateSchema/main.go | 2 +- .../SubscriberClient/Acknowledge/main.go | 2 +- .../SubscriberClient/CreateSnapshot/main.go | 2 +- .../CreateSubscription/main.go | 2 +- .../SubscriberClient/DeleteSnapshot/main.go | 2 +- .../DeleteSubscription/main.go | 2 +- .../SubscriberClient/GetIamPolicy/main.go | 2 +- .../SubscriberClient/GetSnapshot/main.go | 2 +- .../SubscriberClient/GetSubscription/main.go | 2 +- .../SubscriberClient/ListSnapshots/main.go | 2 +- .../ListSubscriptions/main.go | 2 +- .../ModifyAckDeadline/main.go | 2 +- .../SubscriberClient/ModifyPushConfig/main.go | 2 +- .../apiv1/SubscriberClient/Pull/main.go | 2 +- .../apiv1/SubscriberClient/Seek/main.go | 2 +- .../SubscriberClient/SetIamPolicy/main.go | 2 +- .../SubscriberClient/StreamingPull/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../SubscriberClient/UpdateSnapshot/main.go | 2 +- .../UpdateSubscription/main.go | 2 +- .../apiv1/AdminClient/CancelOperation/main.go | 2 +- .../AdminClient/CreateReservation/main.go | 2 +- .../AdminClient/CreateSubscription/main.go | 2 +- .../apiv1/AdminClient/CreateTopic/main.go | 2 +- .../apiv1/AdminClient/DeleteOperation/main.go | 2 +- .../AdminClient/DeleteReservation/main.go | 2 +- .../AdminClient/DeleteSubscription/main.go | 2 +- .../apiv1/AdminClient/DeleteTopic/main.go | 2 +- .../apiv1/AdminClient/GetOperation/main.go | 2 +- .../apiv1/AdminClient/GetReservation/main.go | 2 +- .../apiv1/AdminClient/GetSubscription/main.go | 2 +- .../apiv1/AdminClient/GetTopic/main.go | 2 +- .../AdminClient/GetTopicPartitions/main.go | 2 +- .../apiv1/AdminClient/ListOperations/main.go | 2 +- .../AdminClient/ListReservationTopics/main.go | 2 +- .../AdminClient/ListReservations/main.go | 2 +- .../AdminClient/ListSubscriptions/main.go | 2 +- .../ListTopicSubscriptions/main.go | 2 +- .../apiv1/AdminClient/ListTopics/main.go | 2 +- .../AdminClient/SeekSubscription/main.go | 2 +- .../AdminClient/UpdateReservation/main.go | 2 +- .../AdminClient/UpdateSubscription/main.go | 2 +- .../apiv1/AdminClient/UpdateTopic/main.go | 2 +- .../CursorClient/CancelOperation/main.go | 2 +- .../apiv1/CursorClient/CommitCursor/main.go | 2 +- .../CursorClient/DeleteOperation/main.go | 2 +- .../apiv1/CursorClient/GetOperation/main.go | 2 +- .../apiv1/CursorClient/ListOperations/main.go | 2 +- .../CursorClient/ListPartitionCursors/main.go | 2 +- .../StreamingCommitCursor/main.go | 2 +- .../AssignPartitions/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListOperations/main.go | 2 +- .../PublisherClient/CancelOperation/main.go | 2 +- .../PublisherClient/DeleteOperation/main.go | 2 +- .../PublisherClient/GetOperation/main.go | 2 +- .../PublisherClient/ListOperations/main.go | 2 +- .../apiv1/PublisherClient/Publish/main.go | 2 +- .../SubscriberClient/CancelOperation/main.go | 2 +- .../SubscriberClient/DeleteOperation/main.go | 2 +- .../SubscriberClient/GetOperation/main.go | 2 +- .../SubscriberClient/ListOperations/main.go | 2 +- .../apiv1/SubscriberClient/Subscribe/main.go | 2 +- .../TopicStatsClient/CancelOperation/main.go | 2 +- .../ComputeHeadCursor/main.go | 2 +- .../ComputeMessageStats/main.go | 2 +- .../ComputeTimeCursor/main.go | 2 +- .../TopicStatsClient/DeleteOperation/main.go | 2 +- .../TopicStatsClient/GetOperation/main.go | 2 +- .../TopicStatsClient/ListOperations/main.go | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apiv1/Client/CreateAnnotation/main.go | 2 +- .../apiv1/Client/CreateCollector/main.go | 2 +- .../apiv1/Client/DeleteCollector/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../apiv1/Client/GetAnnotation/main.go | 2 +- .../apiv1/Client/GetCollector/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/ListCollectors/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/PauseCollector/main.go | 2 +- .../apiv1/Client/RegisterCollector/main.go | 2 +- .../apiv1/Client/ResumeCollector/main.go | 2 +- .../apiv1/Client/UpdateCollector/main.go | 2 +- .../v2/apiv1/Client/AddIpOverride/main.go | 2 +- .../apiv1/Client/AnnotateAssessment/main.go | 2 +- .../v2/apiv1/Client/CreateAssessment/main.go | 2 +- .../apiv1/Client/CreateFirewallPolicy/main.go | 2 +- .../v2/apiv1/Client/CreateKey/main.go | 2 +- .../apiv1/Client/DeleteFirewallPolicy/main.go | 2 +- .../v2/apiv1/Client/DeleteKey/main.go | 2 +- .../v2/apiv1/Client/GetFirewallPolicy/main.go | 2 +- .../v2/apiv1/Client/GetKey/main.go | 2 +- .../v2/apiv1/Client/GetMetrics/main.go | 2 +- .../apiv1/Client/ListFirewallPolicies/main.go | 2 +- .../v2/apiv1/Client/ListIpOverrides/main.go | 2 +- .../v2/apiv1/Client/ListKeys/main.go | 2 +- .../main.go | 2 +- .../Client/ListRelatedAccountGroups/main.go | 2 +- .../v2/apiv1/Client/MigrateKey/main.go | 2 +- .../v2/apiv1/Client/RemoveIpOverride/main.go | 2 +- .../Client/ReorderFirewallPolicies/main.go | 2 +- .../Client/RetrieveLegacySecretKey/main.go | 2 +- .../main.go | 2 +- .../apiv1/Client/UpdateFirewallPolicy/main.go | 2 +- .../v2/apiv1/Client/UpdateKey/main.go | 2 +- .../AnnotateAssessment/main.go | 2 +- .../CreateAssessment/main.go | 2 +- .../CatalogClient/CreateCatalogItem/main.go | 2 +- .../CatalogClient/DeleteCatalogItem/main.go | 2 +- .../CatalogClient/GetCatalogItem/main.go | 2 +- .../CatalogClient/ImportCatalogItems/main.go | 2 +- .../CatalogClient/ListCatalogItems/main.go | 2 +- .../CatalogClient/UpdateCatalogItem/main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../ListPredictionApiKeyRegistrations/main.go | 2 +- .../PredictionClient/Predict/main.go | 2 +- .../UserEventClient/CollectUserEvent/main.go | 2 +- .../UserEventClient/ImportUserEvents/main.go | 2 +- .../UserEventClient/ListUserEvents/main.go | 2 +- .../UserEventClient/PurgeUserEvents/main.go | 2 +- .../UserEventClient/WriteUserEvent/main.go | 2 +- .../apiv1/Client/GetInsight/main.go | 2 +- .../apiv1/Client/GetInsightTypeConfig/main.go | 2 +- .../apiv1/Client/GetRecommendation/main.go | 2 +- .../apiv1/Client/GetRecommenderConfig/main.go | 2 +- .../apiv1/Client/ListInsights/main.go | 2 +- .../apiv1/Client/ListRecommendations/main.go | 2 +- .../apiv1/Client/MarkInsightAccepted/main.go | 2 +- .../Client/MarkRecommendationClaimed/main.go | 2 +- .../MarkRecommendationDismissed/main.go | 2 +- .../Client/MarkRecommendationFailed/main.go | 2 +- .../MarkRecommendationSucceeded/main.go | 2 +- .../Client/UpdateInsightTypeConfig/main.go | 2 +- .../Client/UpdateRecommenderConfig/main.go | 2 +- ..._metadata.google.cloud.recommender.v1.json | 2 +- .../apiv1beta1/Client/GetInsight/main.go | 2 +- .../Client/GetInsightTypeConfig/main.go | 2 +- .../Client/GetRecommendation/main.go | 2 +- .../Client/GetRecommenderConfig/main.go | 2 +- .../Client/ListInsightTypes/main.go | 2 +- .../apiv1beta1/Client/ListInsights/main.go | 2 +- .../Client/ListRecommendations/main.go | 2 +- .../Client/ListRecommenders/main.go | 2 +- .../Client/MarkInsightAccepted/main.go | 2 +- .../Client/MarkRecommendationClaimed/main.go | 2 +- .../Client/MarkRecommendationFailed/main.go | 2 +- .../MarkRecommendationSucceeded/main.go | 2 +- .../Client/UpdateInsightTypeConfig/main.go | 2 +- .../Client/UpdateRecommenderConfig/main.go | 2 +- ...data.google.cloud.recommender.v1beta1.json | 2 +- .../CloudRedisClient/CancelOperation/main.go | 2 +- .../CloudRedisClient/CreateInstance/main.go | 2 +- .../CloudRedisClient/DeleteInstance/main.go | 2 +- .../CloudRedisClient/DeleteOperation/main.go | 2 +- .../CloudRedisClient/ExportInstance/main.go | 2 +- .../CloudRedisClient/FailoverInstance/main.go | 2 +- .../CloudRedisClient/GetInstance/main.go | 2 +- .../GetInstanceAuthString/main.go | 2 +- .../CloudRedisClient/GetLocation/main.go | 2 +- .../CloudRedisClient/GetOperation/main.go | 2 +- .../CloudRedisClient/ImportInstance/main.go | 2 +- .../CloudRedisClient/ListInstances/main.go | 2 +- .../CloudRedisClient/ListLocations/main.go | 2 +- .../CloudRedisClient/ListOperations/main.go | 2 +- .../RescheduleMaintenance/main.go | 2 +- .../CloudRedisClient/UpdateInstance/main.go | 2 +- .../CloudRedisClient/UpgradeInstance/main.go | 2 +- ...nippet_metadata.google.cloud.redis.v1.json | 2 +- .../CloudRedisClient/CreateInstance/main.go | 2 +- .../CloudRedisClient/DeleteInstance/main.go | 2 +- .../CloudRedisClient/ExportInstance/main.go | 2 +- .../CloudRedisClient/FailoverInstance/main.go | 2 +- .../CloudRedisClient/GetInstance/main.go | 2 +- .../GetInstanceAuthString/main.go | 2 +- .../CloudRedisClient/ImportInstance/main.go | 2 +- .../CloudRedisClient/ListInstances/main.go | 2 +- .../RescheduleMaintenance/main.go | 2 +- .../CloudRedisClient/UpdateInstance/main.go | 2 +- .../CloudRedisClient/UpgradeInstance/main.go | 2 +- ...t_metadata.google.cloud.redis.v1beta1.json | 2 +- .../CancelOperation/main.go | 2 +- .../CreateCluster/main.go | 2 +- .../DeleteCluster/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../GetCluster/main.go | 2 +- .../GetClusterCertificateAuthority/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListClusters/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../UpdateCluster/main.go | 2 +- ...etadata.google.cloud.redis.cluster.v1.json | 2 +- .../apiv2/FoldersClient/CreateFolder/main.go | 2 +- .../apiv2/FoldersClient/DeleteFolder/main.go | 2 +- .../apiv2/FoldersClient/GetFolder/main.go | 2 +- .../apiv2/FoldersClient/GetIamPolicy/main.go | 2 +- .../apiv2/FoldersClient/ListFolders/main.go | 2 +- .../apiv2/FoldersClient/MoveFolder/main.go | 2 +- .../apiv2/FoldersClient/SearchFolders/main.go | 2 +- .../apiv2/FoldersClient/SetIamPolicy/main.go | 2 +- .../FoldersClient/TestIamPermissions/main.go | 2 +- .../FoldersClient/UndeleteFolder/main.go | 2 +- .../apiv2/FoldersClient/UpdateFolder/main.go | 2 +- .../apiv3/FoldersClient/CreateFolder/main.go | 2 +- .../apiv3/FoldersClient/DeleteFolder/main.go | 2 +- .../apiv3/FoldersClient/GetFolder/main.go | 2 +- .../apiv3/FoldersClient/GetIamPolicy/main.go | 2 +- .../apiv3/FoldersClient/GetOperation/main.go | 2 +- .../apiv3/FoldersClient/ListFolders/main.go | 2 +- .../apiv3/FoldersClient/MoveFolder/main.go | 2 +- .../apiv3/FoldersClient/SearchFolders/main.go | 2 +- .../apiv3/FoldersClient/SetIamPolicy/main.go | 2 +- .../FoldersClient/TestIamPermissions/main.go | 2 +- .../FoldersClient/UndeleteFolder/main.go | 2 +- .../apiv3/FoldersClient/UpdateFolder/main.go | 2 +- .../OrganizationsClient/GetIamPolicy/main.go | 2 +- .../OrganizationsClient/GetOperation/main.go | 2 +- .../GetOrganization/main.go | 2 +- .../SearchOrganizations/main.go | 2 +- .../OrganizationsClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../ProjectsClient/CreateProject/main.go | 2 +- .../ProjectsClient/DeleteProject/main.go | 2 +- .../apiv3/ProjectsClient/GetIamPolicy/main.go | 2 +- .../apiv3/ProjectsClient/GetOperation/main.go | 2 +- .../apiv3/ProjectsClient/GetProject/main.go | 2 +- .../apiv3/ProjectsClient/ListProjects/main.go | 2 +- .../apiv3/ProjectsClient/MoveProject/main.go | 2 +- .../ProjectsClient/SearchProjects/main.go | 2 +- .../apiv3/ProjectsClient/SetIamPolicy/main.go | 2 +- .../ProjectsClient/TestIamPermissions/main.go | 2 +- .../ProjectsClient/UndeleteProject/main.go | 2 +- .../ProjectsClient/UpdateProject/main.go | 2 +- .../CreateTagBinding/main.go | 2 +- .../DeleteTagBinding/main.go | 2 +- .../TagBindingsClient/GetOperation/main.go | 2 +- .../ListEffectiveTags/main.go | 2 +- .../TagBindingsClient/ListTagBindings/main.go | 2 +- .../TagHoldsClient/CreateTagHold/main.go | 2 +- .../TagHoldsClient/DeleteTagHold/main.go | 2 +- .../apiv3/TagHoldsClient/GetOperation/main.go | 2 +- .../apiv3/TagHoldsClient/ListTagHolds/main.go | 2 +- .../apiv3/TagKeysClient/CreateTagKey/main.go | 2 +- .../apiv3/TagKeysClient/DeleteTagKey/main.go | 2 +- .../apiv3/TagKeysClient/GetIamPolicy/main.go | 2 +- .../TagKeysClient/GetNamespacedTagKey/main.go | 2 +- .../apiv3/TagKeysClient/GetOperation/main.go | 2 +- .../apiv3/TagKeysClient/GetTagKey/main.go | 2 +- .../apiv3/TagKeysClient/ListTagKeys/main.go | 2 +- .../apiv3/TagKeysClient/SetIamPolicy/main.go | 2 +- .../TagKeysClient/TestIamPermissions/main.go | 2 +- .../apiv3/TagKeysClient/UpdateTagKey/main.go | 2 +- .../TagValuesClient/CreateTagValue/main.go | 2 +- .../TagValuesClient/DeleteTagValue/main.go | 2 +- .../TagValuesClient/GetIamPolicy/main.go | 2 +- .../GetNamespacedTagValue/main.go | 2 +- .../TagValuesClient/GetOperation/main.go | 2 +- .../apiv3/TagValuesClient/GetTagValue/main.go | 2 +- .../TagValuesClient/ListTagValues/main.go | 2 +- .../TagValuesClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../TagValuesClient/UpdateTagValue/main.go | 2 +- .../apiv1/Client/GetSetting/main.go | 2 +- .../apiv1/Client/ListSettings/main.go | 2 +- .../apiv1/Client/UpdateSetting/main.go | 2 +- ...data.google.cloud.resourcesettings.v1.json | 2 +- .../ExportAnalyticsMetrics/main.go | 2 +- .../AnalyticsClient/GetOperation/main.go | 2 +- .../AnalyticsClient/ListOperations/main.go | 2 +- .../CatalogClient/AddCatalogAttribute/main.go | 2 +- .../CatalogClient/GetAttributesConfig/main.go | 2 +- .../CatalogClient/GetCompletionConfig/main.go | 2 +- .../CatalogClient/GetDefaultBranch/main.go | 2 +- .../apiv2/CatalogClient/GetOperation/main.go | 2 +- .../apiv2/CatalogClient/ListCatalogs/main.go | 2 +- .../CatalogClient/ListOperations/main.go | 2 +- .../RemoveCatalogAttribute/main.go | 2 +- .../ReplaceCatalogAttribute/main.go | 2 +- .../CatalogClient/SetDefaultBranch/main.go | 2 +- .../UpdateAttributesConfig/main.go | 2 +- .../apiv2/CatalogClient/UpdateCatalog/main.go | 2 +- .../UpdateCompletionConfig/main.go | 2 +- .../CompletionClient/CompleteQuery/main.go | 2 +- .../CompletionClient/GetOperation/main.go | 2 +- .../ImportCompletionData/main.go | 2 +- .../CompletionClient/ListOperations/main.go | 2 +- .../apiv2/ControlClient/CreateControl/main.go | 2 +- .../apiv2/ControlClient/DeleteControl/main.go | 2 +- .../apiv2/ControlClient/GetControl/main.go | 2 +- .../apiv2/ControlClient/GetOperation/main.go | 2 +- .../apiv2/ControlClient/ListControls/main.go | 2 +- .../ControlClient/ListOperations/main.go | 2 +- .../apiv2/ControlClient/UpdateControl/main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListGenerativeQuestionConfigs/main.go | 2 +- .../ListOperations/main.go | 2 +- .../UpdateGenerativeQuestionConfig/main.go | 2 +- .../main.go | 2 +- .../apiv2/ModelClient/CreateModel/main.go | 2 +- .../apiv2/ModelClient/DeleteModel/main.go | 2 +- .../retail/apiv2/ModelClient/GetModel/main.go | 2 +- .../apiv2/ModelClient/GetOperation/main.go | 2 +- .../apiv2/ModelClient/ListModels/main.go | 2 +- .../apiv2/ModelClient/ListOperations/main.go | 2 +- .../apiv2/ModelClient/PauseModel/main.go | 2 +- .../apiv2/ModelClient/ResumeModel/main.go | 2 +- .../apiv2/ModelClient/TuneModel/main.go | 2 +- .../apiv2/ModelClient/UpdateModel/main.go | 2 +- .../PredictionClient/GetOperation/main.go | 2 +- .../PredictionClient/ListOperations/main.go | 2 +- .../apiv2/PredictionClient/Predict/main.go | 2 +- .../AddFulfillmentPlaces/main.go | 2 +- .../ProductClient/AddLocalInventories/main.go | 2 +- .../apiv2/ProductClient/CreateProduct/main.go | 2 +- .../apiv2/ProductClient/DeleteProduct/main.go | 2 +- .../apiv2/ProductClient/GetOperation/main.go | 2 +- .../apiv2/ProductClient/GetProduct/main.go | 2 +- .../ProductClient/ImportProducts/main.go | 2 +- .../ProductClient/ListOperations/main.go | 2 +- .../apiv2/ProductClient/ListProducts/main.go | 2 +- .../apiv2/ProductClient/PurgeProducts/main.go | 2 +- .../RemoveFulfillmentPlaces/main.go | 2 +- .../RemoveLocalInventories/main.go | 2 +- .../apiv2/ProductClient/SetInventory/main.go | 2 +- .../apiv2/ProductClient/UpdateProduct/main.go | 2 +- .../apiv2/SearchClient/GetOperation/main.go | 2 +- .../apiv2/SearchClient/ListOperations/main.go | 2 +- .../retail/apiv2/SearchClient/Search/main.go | 2 +- .../ServingConfigClient/AddControl/main.go | 2 +- .../CreateServingConfig/main.go | 2 +- .../DeleteServingConfig/main.go | 2 +- .../ServingConfigClient/GetOperation/main.go | 2 +- .../GetServingConfig/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListServingConfigs/main.go | 2 +- .../ServingConfigClient/RemoveControl/main.go | 2 +- .../UpdateServingConfig/main.go | 2 +- .../UserEventClient/CollectUserEvent/main.go | 2 +- .../UserEventClient/GetOperation/main.go | 2 +- .../UserEventClient/ImportUserEvents/main.go | 2 +- .../UserEventClient/ListOperations/main.go | 2 +- .../UserEventClient/PurgeUserEvents/main.go | 2 +- .../UserEventClient/RejoinUserEvents/main.go | 2 +- .../UserEventClient/WriteUserEvent/main.go | 2 +- ...ippet_metadata.google.cloud.retail.v2.json | 2 +- .../ExportAnalyticsMetrics/main.go | 2 +- .../AnalyticsClient/GetOperation/main.go | 2 +- .../AnalyticsClient/ListOperations/main.go | 2 +- .../apiv2alpha/BranchClient/GetBranch/main.go | 2 +- .../BranchClient/GetOperation/main.go | 2 +- .../BranchClient/ListBranches/main.go | 2 +- .../BranchClient/ListOperations/main.go | 2 +- .../CatalogClient/AddCatalogAttribute/main.go | 2 +- .../BatchRemoveCatalogAttributes/main.go | 2 +- .../CatalogClient/GetAttributesConfig/main.go | 2 +- .../CatalogClient/GetCompletionConfig/main.go | 2 +- .../CatalogClient/GetDefaultBranch/main.go | 2 +- .../CatalogClient/GetOperation/main.go | 2 +- .../CatalogClient/ListCatalogs/main.go | 2 +- .../CatalogClient/ListOperations/main.go | 2 +- .../RemoveCatalogAttribute/main.go | 2 +- .../ReplaceCatalogAttribute/main.go | 2 +- .../CatalogClient/SetDefaultBranch/main.go | 2 +- .../UpdateAttributesConfig/main.go | 2 +- .../CatalogClient/UpdateCatalog/main.go | 2 +- .../UpdateCompletionConfig/main.go | 2 +- .../CompletionClient/CompleteQuery/main.go | 2 +- .../CompletionClient/GetOperation/main.go | 2 +- .../ImportCompletionData/main.go | 2 +- .../CompletionClient/ListOperations/main.go | 2 +- .../ControlClient/CreateControl/main.go | 2 +- .../ControlClient/DeleteControl/main.go | 2 +- .../ControlClient/GetControl/main.go | 2 +- .../ControlClient/GetOperation/main.go | 2 +- .../ControlClient/ListControls/main.go | 2 +- .../ControlClient/ListOperations/main.go | 2 +- .../ControlClient/UpdateControl/main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListGenerativeQuestionConfigs/main.go | 2 +- .../ListOperations/main.go | 2 +- .../UpdateGenerativeQuestionConfig/main.go | 2 +- .../main.go | 2 +- .../CreateMerchantCenterAccountLink/main.go | 2 +- .../DeleteMerchantCenterAccountLink/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListMerchantCenterAccountLinks/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ModelClient/CreateModel/main.go | 2 +- .../ModelClient/DeleteModel/main.go | 2 +- .../apiv2alpha/ModelClient/GetModel/main.go | 2 +- .../ModelClient/GetOperation/main.go | 2 +- .../apiv2alpha/ModelClient/ListModels/main.go | 2 +- .../ModelClient/ListOperations/main.go | 2 +- .../apiv2alpha/ModelClient/PauseModel/main.go | 2 +- .../ModelClient/ResumeModel/main.go | 2 +- .../apiv2alpha/ModelClient/TuneModel/main.go | 2 +- .../ModelClient/UpdateModel/main.go | 2 +- .../PredictionClient/GetOperation/main.go | 2 +- .../PredictionClient/ListOperations/main.go | 2 +- .../PredictionClient/Predict/main.go | 2 +- .../AddFulfillmentPlaces/main.go | 2 +- .../ProductClient/AddLocalInventories/main.go | 2 +- .../ProductClient/CreateProduct/main.go | 2 +- .../ProductClient/DeleteProduct/main.go | 2 +- .../ProductClient/ExportProducts/main.go | 2 +- .../ProductClient/GetOperation/main.go | 2 +- .../ProductClient/GetProduct/main.go | 2 +- .../ProductClient/ImportProducts/main.go | 2 +- .../ProductClient/ListOperations/main.go | 2 +- .../ProductClient/ListProducts/main.go | 2 +- .../ProductClient/PurgeProducts/main.go | 2 +- .../RemoveFulfillmentPlaces/main.go | 2 +- .../RemoveLocalInventories/main.go | 2 +- .../ProductClient/SetInventory/main.go | 2 +- .../ProductClient/UpdateProduct/main.go | 2 +- .../ProjectClient/AcceptTerms/main.go | 2 +- .../ProjectClient/EnrollSolution/main.go | 2 +- .../ProjectClient/GetAlertConfig/main.go | 2 +- .../ProjectClient/GetLoggingConfig/main.go | 2 +- .../ProjectClient/GetOperation/main.go | 2 +- .../ProjectClient/GetProject/main.go | 2 +- .../ListEnrolledSolutions/main.go | 2 +- .../ProjectClient/ListOperations/main.go | 2 +- .../ProjectClient/UpdateAlertConfig/main.go | 2 +- .../ProjectClient/UpdateLoggingConfig/main.go | 2 +- .../SearchClient/GetOperation/main.go | 2 +- .../SearchClient/ListOperations/main.go | 2 +- .../apiv2alpha/SearchClient/Search/main.go | 2 +- .../ServingConfigClient/AddControl/main.go | 2 +- .../CreateServingConfig/main.go | 2 +- .../DeleteServingConfig/main.go | 2 +- .../ServingConfigClient/GetOperation/main.go | 2 +- .../GetServingConfig/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListServingConfigs/main.go | 2 +- .../ServingConfigClient/RemoveControl/main.go | 2 +- .../UpdateServingConfig/main.go | 2 +- .../UserEventClient/CollectUserEvent/main.go | 2 +- .../UserEventClient/ExportUserEvents/main.go | 2 +- .../UserEventClient/GetOperation/main.go | 2 +- .../UserEventClient/ImportUserEvents/main.go | 2 +- .../UserEventClient/ListOperations/main.go | 2 +- .../UserEventClient/PurgeUserEvents/main.go | 2 +- .../UserEventClient/RejoinUserEvents/main.go | 2 +- .../UserEventClient/WriteUserEvent/main.go | 2 +- ..._metadata.google.cloud.retail.v2alpha.json | 2 +- .../ExportAnalyticsMetrics/main.go | 2 +- .../AnalyticsClient/GetOperation/main.go | 2 +- .../AnalyticsClient/ListOperations/main.go | 2 +- .../CatalogClient/AddCatalogAttribute/main.go | 2 +- .../BatchRemoveCatalogAttributes/main.go | 2 +- .../CatalogClient/GetAttributesConfig/main.go | 2 +- .../CatalogClient/GetCompletionConfig/main.go | 2 +- .../CatalogClient/GetDefaultBranch/main.go | 2 +- .../CatalogClient/GetOperation/main.go | 2 +- .../CatalogClient/ListCatalogs/main.go | 2 +- .../CatalogClient/ListOperations/main.go | 2 +- .../RemoveCatalogAttribute/main.go | 2 +- .../ReplaceCatalogAttribute/main.go | 2 +- .../CatalogClient/SetDefaultBranch/main.go | 2 +- .../UpdateAttributesConfig/main.go | 2 +- .../CatalogClient/UpdateCatalog/main.go | 2 +- .../UpdateCompletionConfig/main.go | 2 +- .../CompletionClient/CompleteQuery/main.go | 2 +- .../CompletionClient/GetOperation/main.go | 2 +- .../ImportCompletionData/main.go | 2 +- .../CompletionClient/ListOperations/main.go | 2 +- .../ControlClient/CreateControl/main.go | 2 +- .../ControlClient/DeleteControl/main.go | 2 +- .../ControlClient/GetControl/main.go | 2 +- .../ControlClient/GetOperation/main.go | 2 +- .../ControlClient/ListControls/main.go | 2 +- .../ControlClient/ListOperations/main.go | 2 +- .../ControlClient/UpdateControl/main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListGenerativeQuestionConfigs/main.go | 2 +- .../ListOperations/main.go | 2 +- .../UpdateGenerativeQuestionConfig/main.go | 2 +- .../main.go | 2 +- .../apiv2beta/ModelClient/CreateModel/main.go | 2 +- .../apiv2beta/ModelClient/DeleteModel/main.go | 2 +- .../apiv2beta/ModelClient/GetModel/main.go | 2 +- .../ModelClient/GetOperation/main.go | 2 +- .../apiv2beta/ModelClient/ListModels/main.go | 2 +- .../ModelClient/ListOperations/main.go | 2 +- .../apiv2beta/ModelClient/PauseModel/main.go | 2 +- .../apiv2beta/ModelClient/ResumeModel/main.go | 2 +- .../apiv2beta/ModelClient/TuneModel/main.go | 2 +- .../apiv2beta/ModelClient/UpdateModel/main.go | 2 +- .../PredictionClient/GetOperation/main.go | 2 +- .../PredictionClient/ListOperations/main.go | 2 +- .../PredictionClient/Predict/main.go | 2 +- .../AddFulfillmentPlaces/main.go | 2 +- .../ProductClient/AddLocalInventories/main.go | 2 +- .../ProductClient/CreateProduct/main.go | 2 +- .../ProductClient/DeleteProduct/main.go | 2 +- .../ProductClient/ExportProducts/main.go | 2 +- .../ProductClient/GetOperation/main.go | 2 +- .../ProductClient/GetProduct/main.go | 2 +- .../ProductClient/ImportProducts/main.go | 2 +- .../ProductClient/ListOperations/main.go | 2 +- .../ProductClient/ListProducts/main.go | 2 +- .../ProductClient/PurgeProducts/main.go | 2 +- .../RemoveFulfillmentPlaces/main.go | 2 +- .../RemoveLocalInventories/main.go | 2 +- .../ProductClient/SetInventory/main.go | 2 +- .../ProductClient/UpdateProduct/main.go | 2 +- .../ProjectClient/GetAlertConfig/main.go | 2 +- .../ProjectClient/GetOperation/main.go | 2 +- .../ProjectClient/ListOperations/main.go | 2 +- .../ProjectClient/UpdateAlertConfig/main.go | 2 +- .../SearchClient/GetOperation/main.go | 2 +- .../SearchClient/ListOperations/main.go | 2 +- .../apiv2beta/SearchClient/Search/main.go | 2 +- .../ServingConfigClient/AddControl/main.go | 2 +- .../CreateServingConfig/main.go | 2 +- .../DeleteServingConfig/main.go | 2 +- .../ServingConfigClient/GetOperation/main.go | 2 +- .../GetServingConfig/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListServingConfigs/main.go | 2 +- .../ServingConfigClient/RemoveControl/main.go | 2 +- .../UpdateServingConfig/main.go | 2 +- .../UserEventClient/CollectUserEvent/main.go | 2 +- .../UserEventClient/ExportUserEvents/main.go | 2 +- .../UserEventClient/GetOperation/main.go | 2 +- .../UserEventClient/ImportUserEvents/main.go | 2 +- .../UserEventClient/ListOperations/main.go | 2 +- .../UserEventClient/PurgeUserEvents/main.go | 2 +- .../UserEventClient/RejoinUserEvents/main.go | 2 +- .../UserEventClient/WriteUserEvent/main.go | 2 +- ...t_metadata.google.cloud.retail.v2beta.json | 2 +- .../BuildsClient/DeleteOperation/main.go | 2 +- .../apiv2/BuildsClient/GetOperation/main.go | 2 +- .../apiv2/BuildsClient/ListOperations/main.go | 2 +- .../apiv2/BuildsClient/SubmitBuild/main.go | 2 +- .../apiv2/BuildsClient/WaitOperation/main.go | 2 +- .../ExecutionsClient/CancelExecution/main.go | 2 +- .../ExecutionsClient/DeleteExecution/main.go | 2 +- .../ExecutionsClient/DeleteOperation/main.go | 2 +- .../ExecutionsClient/GetExecution/main.go | 2 +- .../ExecutionsClient/GetOperation/main.go | 2 +- .../ExecutionsClient/ListExecutions/main.go | 2 +- .../ExecutionsClient/ListOperations/main.go | 2 +- .../ExecutionsClient/WaitOperation/main.go | 2 +- .../run/apiv2/JobsClient/CreateJob/main.go | 2 +- .../run/apiv2/JobsClient/DeleteJob/main.go | 2 +- .../apiv2/JobsClient/DeleteOperation/main.go | 2 +- .../run/apiv2/JobsClient/GetIamPolicy/main.go | 2 +- .../run/apiv2/JobsClient/GetJob/main.go | 2 +- .../run/apiv2/JobsClient/GetOperation/main.go | 2 +- .../run/apiv2/JobsClient/ListJobs/main.go | 2 +- .../apiv2/JobsClient/ListOperations/main.go | 2 +- .../run/apiv2/JobsClient/RunJob/main.go | 2 +- .../run/apiv2/JobsClient/SetIamPolicy/main.go | 2 +- .../JobsClient/TestIamPermissions/main.go | 2 +- .../run/apiv2/JobsClient/UpdateJob/main.go | 2 +- .../apiv2/JobsClient/WaitOperation/main.go | 2 +- .../RevisionsClient/DeleteOperation/main.go | 2 +- .../RevisionsClient/DeleteRevision/main.go | 2 +- .../RevisionsClient/GetOperation/main.go | 2 +- .../apiv2/RevisionsClient/GetRevision/main.go | 2 +- .../RevisionsClient/ListOperations/main.go | 2 +- .../RevisionsClient/ListRevisions/main.go | 2 +- .../RevisionsClient/WaitOperation/main.go | 2 +- .../ServicesClient/CreateService/main.go | 2 +- .../ServicesClient/DeleteOperation/main.go | 2 +- .../ServicesClient/DeleteService/main.go | 2 +- .../apiv2/ServicesClient/GetIamPolicy/main.go | 2 +- .../apiv2/ServicesClient/GetOperation/main.go | 2 +- .../apiv2/ServicesClient/GetService/main.go | 2 +- .../ServicesClient/ListOperations/main.go | 2 +- .../apiv2/ServicesClient/ListServices/main.go | 2 +- .../apiv2/ServicesClient/SetIamPolicy/main.go | 2 +- .../ServicesClient/TestIamPermissions/main.go | 2 +- .../ServicesClient/UpdateService/main.go | 2 +- .../ServicesClient/WaitOperation/main.go | 2 +- .../apiv2/TasksClient/DeleteOperation/main.go | 2 +- .../apiv2/TasksClient/GetOperation/main.go | 2 +- .../run/apiv2/TasksClient/GetTask/main.go | 2 +- .../apiv2/TasksClient/ListOperations/main.go | 2 +- .../run/apiv2/TasksClient/ListTasks/main.go | 2 +- .../apiv2/TasksClient/WaitOperation/main.go | 2 +- .../CloudSchedulerClient/CreateJob/main.go | 2 +- .../CloudSchedulerClient/DeleteJob/main.go | 2 +- .../apiv1/CloudSchedulerClient/GetJob/main.go | 2 +- .../CloudSchedulerClient/GetLocation/main.go | 2 +- .../CloudSchedulerClient/ListJobs/main.go | 2 +- .../ListLocations/main.go | 2 +- .../CloudSchedulerClient/PauseJob/main.go | 2 +- .../CloudSchedulerClient/ResumeJob/main.go | 2 +- .../apiv1/CloudSchedulerClient/RunJob/main.go | 2 +- .../CloudSchedulerClient/UpdateJob/main.go | 2 +- .../CloudSchedulerClient/CreateJob/main.go | 2 +- .../CloudSchedulerClient/DeleteJob/main.go | 2 +- .../CloudSchedulerClient/GetJob/main.go | 2 +- .../CloudSchedulerClient/GetLocation/main.go | 2 +- .../CloudSchedulerClient/ListJobs/main.go | 2 +- .../ListLocations/main.go | 2 +- .../CloudSchedulerClient/PauseJob/main.go | 2 +- .../CloudSchedulerClient/ResumeJob/main.go | 2 +- .../CloudSchedulerClient/RunJob/main.go | 2 +- .../CloudSchedulerClient/UpdateJob/main.go | 2 +- .../apiv1/Client/AccessSecretVersion/main.go | 2 +- .../apiv1/Client/AddSecretVersion/main.go | 2 +- .../apiv1/Client/CreateSecret/main.go | 2 +- .../apiv1/Client/DeleteSecret/main.go | 2 +- .../apiv1/Client/DestroySecretVersion/main.go | 2 +- .../apiv1/Client/DisableSecretVersion/main.go | 2 +- .../apiv1/Client/EnableSecretVersion/main.go | 2 +- .../apiv1/Client/GetIamPolicy/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetSecret/main.go | 2 +- .../apiv1/Client/GetSecretVersion/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListSecretVersions/main.go | 2 +- .../apiv1/Client/ListSecrets/main.go | 2 +- .../apiv1/Client/SetIamPolicy/main.go | 2 +- .../apiv1/Client/TestIamPermissions/main.go | 2 +- .../apiv1/Client/UpdateSecret/main.go | 2 +- ...etadata.google.cloud.secretmanager.v1.json | 2 +- .../Client/AccessSecretVersion/main.go | 2 +- .../Client/AddSecretVersion/main.go | 2 +- .../apiv1beta2/Client/CreateSecret/main.go | 2 +- .../apiv1beta2/Client/DeleteSecret/main.go | 2 +- .../Client/DestroySecretVersion/main.go | 2 +- .../Client/DisableSecretVersion/main.go | 2 +- .../Client/EnableSecretVersion/main.go | 2 +- .../apiv1beta2/Client/GetIamPolicy/main.go | 2 +- .../apiv1beta2/Client/GetLocation/main.go | 2 +- .../apiv1beta2/Client/GetSecret/main.go | 2 +- .../Client/GetSecretVersion/main.go | 2 +- .../apiv1beta2/Client/ListLocations/main.go | 2 +- .../Client/ListSecretVersions/main.go | 2 +- .../apiv1beta2/Client/ListSecrets/main.go | 2 +- .../apiv1beta2/Client/SetIamPolicy/main.go | 2 +- .../Client/TestIamPermissions/main.go | 2 +- .../apiv1beta2/Client/UpdateSecret/main.go | 2 +- ...ta.google.cloud.secretmanager.v1beta2.json | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apiv1/Client/CreateBranchRule/main.go | 2 +- .../apiv1/Client/CreateInstance/main.go | 2 +- .../apiv1/Client/CreateRepository/main.go | 2 +- .../apiv1/Client/DeleteBranchRule/main.go | 2 +- .../apiv1/Client/DeleteInstance/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../apiv1/Client/DeleteRepository/main.go | 2 +- .../apiv1/Client/GetBranchRule/main.go | 2 +- .../apiv1/Client/GetIamPolicy/main.go | 2 +- .../apiv1/Client/GetIamPolicyRepo/main.go | 2 +- .../apiv1/Client/GetInstance/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/GetRepository/main.go | 2 +- .../apiv1/Client/ListBranchRules/main.go | 2 +- .../apiv1/Client/ListInstances/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/ListRepositories/main.go | 2 +- .../apiv1/Client/SetIamPolicy/main.go | 2 +- .../apiv1/Client/SetIamPolicyRepo/main.go | 2 +- .../apiv1/Client/TestIamPermissions/main.go | 2 +- .../Client/TestIamPermissionsRepo/main.go | 2 +- .../apiv1/Client/UpdateBranchRule/main.go | 2 +- ...a.google.cloud.securesourcemanager.v1.json | 2 +- .../ActivateCertificateAuthority/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateCaPool/main.go | 2 +- .../CreateCertificate/main.go | 2 +- .../CreateCertificateAuthority/main.go | 2 +- .../CreateCertificateTemplate/main.go | 2 +- .../DeleteCaPool/main.go | 2 +- .../DeleteCertificateAuthority/main.go | 2 +- .../DeleteCertificateTemplate/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../DisableCertificateAuthority/main.go | 2 +- .../EnableCertificateAuthority/main.go | 2 +- .../FetchCaCerts/main.go | 2 +- .../FetchCertificateAuthorityCsr/main.go | 2 +- .../GetCaPool/main.go | 2 +- .../GetCertificate/main.go | 2 +- .../GetCertificateAuthority/main.go | 2 +- .../GetCertificateRevocationList/main.go | 2 +- .../GetCertificateTemplate/main.go | 2 +- .../GetIamPolicy/main.go | 2 +- .../GetLocation/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListCaPools/main.go | 2 +- .../ListCertificateAuthorities/main.go | 2 +- .../ListCertificateRevocationLists/main.go | 2 +- .../ListCertificateTemplates/main.go | 2 +- .../ListCertificates/main.go | 2 +- .../ListLocations/main.go | 2 +- .../ListOperations/main.go | 2 +- .../RevokeCertificate/main.go | 2 +- .../SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UndeleteCertificateAuthority/main.go | 2 +- .../UpdateCaPool/main.go | 2 +- .../UpdateCertificate/main.go | 2 +- .../UpdateCertificateAuthority/main.go | 2 +- .../UpdateCertificateRevocationList/main.go | 2 +- .../UpdateCertificateTemplate/main.go | 2 +- ...ta.google.cloud.security.privateca.v1.json | 2 +- .../CreateExternalAccountKey/main.go | 2 +- ...ata.google.cloud.security.publicca.v1.json | 2 +- .../CreateExternalAccountKey/main.go | 2 +- ...oogle.cloud.security.publicca.v1beta1.json | 2 +- .../BatchCreateResourceValueConfigs/main.go | 2 +- .../apiv1/Client/BulkMuteFindings/main.go | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apiv1/Client/CreateBigQueryExport/main.go | 2 +- .../main.go | 2 +- .../apiv1/Client/CreateFinding/main.go | 2 +- .../apiv1/Client/CreateMuteConfig/main.go | 2 +- .../Client/CreateNotificationConfig/main.go | 2 +- .../main.go | 2 +- .../apiv1/Client/CreateSource/main.go | 2 +- .../apiv1/Client/DeleteBigQueryExport/main.go | 2 +- .../main.go | 2 +- .../apiv1/Client/DeleteMuteConfig/main.go | 2 +- .../Client/DeleteNotificationConfig/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../Client/DeleteResourceValueConfig/main.go | 2 +- .../main.go | 2 +- .../apiv1/Client/GetBigQueryExport/main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../apiv1/Client/GetIamPolicy/main.go | 2 +- .../apiv1/Client/GetMuteConfig/main.go | 2 +- .../Client/GetNotificationConfig/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../Client/GetOrganizationSettings/main.go | 2 +- .../Client/GetResourceValueConfig/main.go | 2 +- .../main.go | 2 +- .../apiv1/Client/GetSimulation/main.go | 2 +- .../apiv1/Client/GetSource/main.go | 2 +- .../apiv1/Client/GetValuedResource/main.go | 2 +- .../apiv1/Client/GroupAssets/main.go | 2 +- .../apiv1/Client/GroupFindings/main.go | 2 +- .../apiv1/Client/ListAssets/main.go | 2 +- .../apiv1/Client/ListAttackPaths/main.go | 2 +- .../apiv1/Client/ListBigQueryExports/main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../apiv1/Client/ListFindings/main.go | 2 +- .../apiv1/Client/ListMuteConfigs/main.go | 2 +- .../Client/ListNotificationConfigs/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../Client/ListResourceValueConfigs/main.go | 2 +- .../main.go | 2 +- .../apiv1/Client/ListSources/main.go | 2 +- .../apiv1/Client/ListValuedResources/main.go | 2 +- .../apiv1/Client/RunAssetDiscovery/main.go | 2 +- .../apiv1/Client/SetFindingState/main.go | 2 +- .../apiv1/Client/SetIamPolicy/main.go | 2 +- .../apiv1/Client/SetMute/main.go | 2 +- .../main.go | 2 +- .../apiv1/Client/TestIamPermissions/main.go | 2 +- .../apiv1/Client/UpdateBigQueryExport/main.go | 2 +- .../main.go | 2 +- .../apiv1/Client/UpdateExternalSystem/main.go | 2 +- .../apiv1/Client/UpdateFinding/main.go | 2 +- .../apiv1/Client/UpdateMuteConfig/main.go | 2 +- .../Client/UpdateNotificationConfig/main.go | 2 +- .../Client/UpdateOrganizationSettings/main.go | 2 +- .../Client/UpdateResourceValueConfig/main.go | 2 +- .../main.go | 2 +- .../apiv1/Client/UpdateSecurityMarks/main.go | 2 +- .../apiv1/Client/UpdateSource/main.go | 2 +- .../main.go | 2 +- ...tadata.google.cloud.securitycenter.v1.json | 2 +- .../apiv1beta1/Client/CreateFinding/main.go | 2 +- .../apiv1beta1/Client/CreateSource/main.go | 2 +- .../apiv1beta1/Client/GetIamPolicy/main.go | 2 +- .../Client/GetOrganizationSettings/main.go | 2 +- .../apiv1beta1/Client/GetSource/main.go | 2 +- .../apiv1beta1/Client/GroupAssets/main.go | 2 +- .../apiv1beta1/Client/GroupFindings/main.go | 2 +- .../apiv1beta1/Client/ListAssets/main.go | 2 +- .../apiv1beta1/Client/ListFindings/main.go | 2 +- .../apiv1beta1/Client/ListSources/main.go | 2 +- .../Client/RunAssetDiscovery/main.go | 2 +- .../apiv1beta1/Client/SetFindingState/main.go | 2 +- .../apiv1beta1/Client/SetIamPolicy/main.go | 2 +- .../Client/TestIamPermissions/main.go | 2 +- .../apiv1beta1/Client/UpdateFinding/main.go | 2 +- .../Client/UpdateOrganizationSettings/main.go | 2 +- .../Client/UpdateSecurityMarks/main.go | 2 +- .../apiv1beta1/Client/UpdateSource/main.go | 2 +- ...a.google.cloud.securitycenter.v1beta1.json | 2 +- .../apiv1p1beta1/Client/CreateFinding/main.go | 2 +- .../Client/CreateNotificationConfig/main.go | 2 +- .../apiv1p1beta1/Client/CreateSource/main.go | 2 +- .../Client/DeleteNotificationConfig/main.go | 2 +- .../apiv1p1beta1/Client/GetIamPolicy/main.go | 2 +- .../Client/GetNotificationConfig/main.go | 2 +- .../Client/GetOrganizationSettings/main.go | 2 +- .../apiv1p1beta1/Client/GetSource/main.go | 2 +- .../apiv1p1beta1/Client/GroupAssets/main.go | 2 +- .../apiv1p1beta1/Client/GroupFindings/main.go | 2 +- .../apiv1p1beta1/Client/ListAssets/main.go | 2 +- .../apiv1p1beta1/Client/ListFindings/main.go | 2 +- .../Client/ListNotificationConfigs/main.go | 2 +- .../apiv1p1beta1/Client/ListSources/main.go | 2 +- .../Client/RunAssetDiscovery/main.go | 2 +- .../Client/SetFindingState/main.go | 2 +- .../apiv1p1beta1/Client/SetIamPolicy/main.go | 2 +- .../Client/TestIamPermissions/main.go | 2 +- .../apiv1p1beta1/Client/UpdateFinding/main.go | 2 +- .../Client/UpdateNotificationConfig/main.go | 2 +- .../Client/UpdateOrganizationSettings/main.go | 2 +- .../Client/UpdateSecurityMarks/main.go | 2 +- .../apiv1p1beta1/Client/UpdateSource/main.go | 2 +- ...google.cloud.securitycenter.v1p1beta1.json | 2 +- .../BatchCreateResourceValueConfigs/main.go | 2 +- .../apiv2/Client/BulkMuteFindings/main.go | 2 +- .../apiv2/Client/CancelOperation/main.go | 2 +- .../apiv2/Client/CreateBigQueryExport/main.go | 2 +- .../apiv2/Client/CreateFinding/main.go | 2 +- .../apiv2/Client/CreateMuteConfig/main.go | 2 +- .../Client/CreateNotificationConfig/main.go | 2 +- .../apiv2/Client/CreateSource/main.go | 2 +- .../apiv2/Client/DeleteBigQueryExport/main.go | 2 +- .../apiv2/Client/DeleteMuteConfig/main.go | 2 +- .../Client/DeleteNotificationConfig/main.go | 2 +- .../apiv2/Client/DeleteOperation/main.go | 2 +- .../Client/DeleteResourceValueConfig/main.go | 2 +- .../apiv2/Client/GetBigQueryExport/main.go | 2 +- .../apiv2/Client/GetIamPolicy/main.go | 2 +- .../apiv2/Client/GetMuteConfig/main.go | 2 +- .../Client/GetNotificationConfig/main.go | 2 +- .../apiv2/Client/GetOperation/main.go | 2 +- .../Client/GetResourceValueConfig/main.go | 2 +- .../apiv2/Client/GetSimulation/main.go | 2 +- .../apiv2/Client/GetSource/main.go | 2 +- .../apiv2/Client/GetValuedResource/main.go | 2 +- .../apiv2/Client/GroupFindings/main.go | 2 +- .../apiv2/Client/ListAttackPaths/main.go | 2 +- .../apiv2/Client/ListBigQueryExports/main.go | 2 +- .../apiv2/Client/ListFindings/main.go | 2 +- .../apiv2/Client/ListMuteConfigs/main.go | 2 +- .../Client/ListNotificationConfigs/main.go | 2 +- .../apiv2/Client/ListOperations/main.go | 2 +- .../Client/ListResourceValueConfigs/main.go | 2 +- .../apiv2/Client/ListSources/main.go | 2 +- .../apiv2/Client/ListValuedResources/main.go | 2 +- .../apiv2/Client/SetFindingState/main.go | 2 +- .../apiv2/Client/SetIamPolicy/main.go | 2 +- .../apiv2/Client/SetMute/main.go | 2 +- .../apiv2/Client/TestIamPermissions/main.go | 2 +- .../apiv2/Client/UpdateBigQueryExport/main.go | 2 +- .../apiv2/Client/UpdateExternalSystem/main.go | 2 +- .../apiv2/Client/UpdateFinding/main.go | 2 +- .../apiv2/Client/UpdateMuteConfig/main.go | 2 +- .../Client/UpdateNotificationConfig/main.go | 2 +- .../Client/UpdateResourceValueConfig/main.go | 2 +- .../apiv2/Client/UpdateSecurityMarks/main.go | 2 +- .../apiv2/Client/UpdateSource/main.go | 2 +- ...tadata.google.cloud.securitycenter.v2.json | 2 +- .../BatchCalculateEffectiveSettings/main.go | 2 +- .../BatchGetSettings/main.go | 2 +- .../main.go | 2 +- .../CalculateEffectiveSettings/main.go | 2 +- .../GetComponentSettings/main.go | 2 +- .../GetServiceAccount/main.go | 2 +- .../GetSettings/main.go | 2 +- .../ListComponents/main.go | 2 +- .../ListDetectors/main.go | 2 +- .../ResetComponentSettings/main.go | 2 +- .../ResetSettings/main.go | 2 +- .../UpdateComponentSettings/main.go | 2 +- .../UpdateSettings/main.go | 2 +- ...cloud.securitycenter.settings.v1beta1.json | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../Client/GetSecurityCenterService/main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../Client/ListSecurityCenterServices/main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- .../UpdateSecurityCenterService/main.go | 2 +- .../main.go | 2 +- .../main.go | 2 +- ...gle.cloud.securitycentermanagement.v1.json | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apiv1/Client/CreatePosture/main.go | 2 +- .../Client/CreatePostureDeployment/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../apiv1/Client/DeletePosture/main.go | 2 +- .../Client/DeletePostureDeployment/main.go | 2 +- .../apiv1/Client/ExtractPosture/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/GetPosture/main.go | 2 +- .../apiv1/Client/GetPostureDeployment/main.go | 2 +- .../apiv1/Client/GetPostureTemplate/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../Client/ListPostureDeployments/main.go | 2 +- .../apiv1/Client/ListPostureRevisions/main.go | 2 +- .../apiv1/Client/ListPostureTemplates/main.go | 2 +- .../apiv1/Client/ListPostures/main.go | 2 +- .../apiv1/Client/UpdatePosture/main.go | 2 +- .../Client/UpdatePostureDeployment/main.go | 2 +- ...adata.google.cloud.securityposture.v1.json | 2 +- .../AllocateQuota/main.go | 2 +- .../ServiceControllerClient/Check/main.go | 2 +- .../ServiceControllerClient/Report/main.go | 2 +- ...metadata.google.api.servicecontrol.v1.json | 2 +- .../apiv1/LookupClient/GetLocation/main.go | 2 +- .../apiv1/LookupClient/ListLocations/main.go | 2 +- .../apiv1/LookupClient/ResolveService/main.go | 2 +- .../RegistrationClient/CreateEndpoint/main.go | 2 +- .../CreateNamespace/main.go | 2 +- .../RegistrationClient/CreateService/main.go | 2 +- .../RegistrationClient/DeleteEndpoint/main.go | 2 +- .../DeleteNamespace/main.go | 2 +- .../RegistrationClient/DeleteService/main.go | 2 +- .../RegistrationClient/GetEndpoint/main.go | 2 +- .../RegistrationClient/GetIamPolicy/main.go | 2 +- .../RegistrationClient/GetLocation/main.go | 2 +- .../RegistrationClient/GetNamespace/main.go | 2 +- .../RegistrationClient/GetService/main.go | 2 +- .../RegistrationClient/ListEndpoints/main.go | 2 +- .../RegistrationClient/ListLocations/main.go | 2 +- .../RegistrationClient/ListNamespaces/main.go | 2 +- .../RegistrationClient/ListServices/main.go | 2 +- .../RegistrationClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../RegistrationClient/UpdateEndpoint/main.go | 2 +- .../UpdateNamespace/main.go | 2 +- .../RegistrationClient/UpdateService/main.go | 2 +- .../LookupClient/GetLocation/main.go | 2 +- .../LookupClient/ListLocations/main.go | 2 +- .../LookupClient/ResolveService/main.go | 2 +- .../RegistrationClient/CreateEndpoint/main.go | 2 +- .../CreateNamespace/main.go | 2 +- .../RegistrationClient/CreateService/main.go | 2 +- .../RegistrationClient/DeleteEndpoint/main.go | 2 +- .../DeleteNamespace/main.go | 2 +- .../RegistrationClient/DeleteService/main.go | 2 +- .../RegistrationClient/GetEndpoint/main.go | 2 +- .../RegistrationClient/GetIamPolicy/main.go | 2 +- .../RegistrationClient/GetLocation/main.go | 2 +- .../RegistrationClient/GetNamespace/main.go | 2 +- .../RegistrationClient/GetService/main.go | 2 +- .../RegistrationClient/ListEndpoints/main.go | 2 +- .../RegistrationClient/ListLocations/main.go | 2 +- .../RegistrationClient/ListNamespaces/main.go | 2 +- .../RegistrationClient/ListServices/main.go | 2 +- .../RegistrationClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../RegistrationClient/UpdateEndpoint/main.go | 2 +- .../UpdateNamespace/main.go | 2 +- .../RegistrationClient/UpdateService/main.go | 2 +- .../apiv1/Client/GetEvent/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetOrganizationEvent/main.go | 2 +- .../Client/GetOrganizationImpact/main.go | 2 +- .../apiv1/Client/ListEvents/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../Client/ListOrganizationEvents/main.go | 2 +- .../Client/ListOrganizationImpacts/main.go | 2 +- ...etadata.google.cloud.servicehealth.v1.json | 2 +- .../CreateService/main.go | 2 +- .../CreateServiceConfig/main.go | 2 +- .../CreateServiceRollout/main.go | 2 +- .../DeleteService/main.go | 2 +- .../GenerateConfigReport/main.go | 2 +- .../ServiceManagerClient/GetIamPolicy/main.go | 2 +- .../ServiceManagerClient/GetService/main.go | 2 +- .../GetServiceConfig/main.go | 2 +- .../GetServiceRollout/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListServiceConfigs/main.go | 2 +- .../ListServiceRollouts/main.go | 2 +- .../ServiceManagerClient/ListServices/main.go | 2 +- .../ServiceManagerClient/SetIamPolicy/main.go | 2 +- .../SubmitConfigSource/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UndeleteService/main.go | 2 +- .../apiv1/Client/BatchEnableServices/main.go | 2 +- .../apiv1/Client/BatchGetServices/main.go | 2 +- .../apiv1/Client/DisableService/main.go | 2 +- .../apiv1/Client/EnableService/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/GetService/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/ListServices/main.go | 2 +- .../CloudShellClient/AddPublicKey/main.go | 2 +- .../AuthorizeEnvironment/main.go | 2 +- .../CloudShellClient/GetEnvironment/main.go | 2 +- .../CloudShellClient/RemovePublicKey/main.go | 2 +- .../CloudShellClient/StartEnvironment/main.go | 2 +- .../CreateAccountLabel/main.go | 2 +- .../DeleteAccountLabel/main.go | 2 +- .../ListAccountLabels/main.go | 2 +- .../UpdateAccountLabel/main.go | 2 +- .../apiv1/AccountsClient/GetAccount/main.go | 2 +- .../AccountsClient/ListChildAccounts/main.go | 2 +- .../apiv1/AccountsClient/UpdateLabels/main.go | 2 +- .../DeleteCssProductInput/main.go | 2 +- .../InsertCssProductInput/main.go | 2 +- .../UpdateCssProductInput/main.go | 2 +- .../CssProductsClient/GetCssProduct/main.go | 2 +- .../CssProductsClient/ListCssProducts/main.go | 2 +- ...ippet_metadata.google.shopping.css.v1.json | 2 +- .../ListAccountIssues/main.go | 2 +- .../AccountTaxClient/GetAccountTax/main.go | 2 +- .../AccountTaxClient/ListAccountTax/main.go | 2 +- .../AccountTaxClient/UpdateAccountTax/main.go | 2 +- .../GetAutofeedSettings/main.go | 2 +- .../UpdateAutofeedSettings/main.go | 2 +- .../GetBusinessIdentity/main.go | 2 +- .../UpdateBusinessIdentity/main.go | 2 +- .../GetBusinessInfo/main.go | 2 +- .../UpdateBusinessInfo/main.go | 2 +- .../Client/CreateAndConfigureAccount/main.go | 2 +- .../apiv1beta/Client/DeleteAccount/main.go | 2 +- .../apiv1beta/Client/GetAccount/main.go | 2 +- .../apiv1beta/Client/ListAccounts/main.go | 2 +- .../apiv1beta/Client/ListSubAccounts/main.go | 2 +- .../apiv1beta/Client/UpdateAccount/main.go | 2 +- .../GetEmailPreferences/main.go | 2 +- .../UpdateEmailPreferences/main.go | 2 +- .../HomepageClient/ClaimHomepage/main.go | 2 +- .../HomepageClient/GetHomepage/main.go | 2 +- .../HomepageClient/UnclaimHomepage/main.go | 2 +- .../HomepageClient/UpdateHomepage/main.go | 2 +- .../GetOnlineReturnPolicy/main.go | 2 +- .../ListOnlineReturnPolicies/main.go | 2 +- .../ProgramsClient/DisableProgram/main.go | 2 +- .../ProgramsClient/EnableProgram/main.go | 2 +- .../ProgramsClient/GetProgram/main.go | 2 +- .../ProgramsClient/ListPrograms/main.go | 2 +- .../RegionsClient/CreateRegion/main.go | 2 +- .../RegionsClient/DeleteRegion/main.go | 2 +- .../apiv1beta/RegionsClient/GetRegion/main.go | 2 +- .../RegionsClient/ListRegions/main.go | 2 +- .../RegionsClient/UpdateRegion/main.go | 2 +- .../GetShippingSettings/main.go | 2 +- .../InsertShippingSettings/main.go | 2 +- .../GetTermsOfServiceAgreementState/main.go | 2 +- .../main.go | 2 +- .../AcceptTermsOfService/main.go | 2 +- .../GetTermsOfService/main.go | 2 +- .../RetrieveLatestTermsOfService/main.go | 2 +- .../apiv1beta/UserClient/CreateUser/main.go | 2 +- .../apiv1beta/UserClient/DeleteUser/main.go | 2 +- .../apiv1beta/UserClient/GetUser/main.go | 2 +- .../apiv1beta/UserClient/ListUsers/main.go | 2 +- .../apiv1beta/UserClient/UpdateUser/main.go | 2 +- ...gle.shopping.merchant.accounts.v1beta.json | 2 +- .../CreateConversionSource/main.go | 2 +- .../DeleteConversionSource/main.go | 2 +- .../GetConversionSource/main.go | 2 +- .../ListConversionSources/main.go | 2 +- .../UndeleteConversionSource/main.go | 2 +- .../UpdateConversionSource/main.go | 2 +- ....shopping.merchant.conversions.v1beta.json | 2 +- .../apiv1beta/Client/CreateDataSource/main.go | 2 +- .../apiv1beta/Client/DeleteDataSource/main.go | 2 +- .../apiv1beta/Client/FetchDataSource/main.go | 2 +- .../apiv1beta/Client/GetDataSource/main.go | 2 +- .../apiv1beta/Client/ListDataSources/main.go | 2 +- .../apiv1beta/Client/UpdateDataSource/main.go | 2 +- .../FileUploadsClient/GetFileUpload/main.go | 2 +- ....shopping.merchant.datasources.v1beta.json | 2 +- .../DeleteLocalInventory/main.go | 2 +- .../InsertLocalInventory/main.go | 2 +- .../ListLocalInventories/main.go | 2 +- .../DeleteRegionalInventory/main.go | 2 +- .../InsertRegionalInventory/main.go | 2 +- .../ListRegionalInventories/main.go | 2 +- ....shopping.merchant.inventories.v1beta.json | 2 +- .../InsertLfpInventory/main.go | 2 +- .../LfpSaleClient/InsertLfpSale/main.go | 2 +- .../LfpStoreClient/DeleteLfpStore/main.go | 2 +- .../LfpStoreClient/GetLfpStore/main.go | 2 +- .../LfpStoreClient/InsertLfpStore/main.go | 2 +- .../LfpStoreClient/ListLfpStores/main.go | 2 +- ...a.google.shopping.merchant.lfp.v1beta.json | 2 +- .../CreateNotificationSubscription/main.go | 2 +- .../DeleteNotificationSubscription/main.go | 2 +- .../GetNotificationSubscription/main.go | 2 +- .../ListNotificationSubscriptions/main.go | 2 +- .../UpdateNotificationSubscription/main.go | 2 +- ...hopping.merchant.notifications.v1beta.json | 2 +- .../apiv1beta/Client/GetProduct/main.go | 2 +- .../apiv1beta/Client/ListProducts/main.go | 2 +- .../DeleteProductInput/main.go | 2 +- .../InsertProductInput/main.go | 2 +- ...gle.shopping.merchant.products.v1beta.json | 2 +- .../apiv1beta/Client/GetPromotion/main.go | 2 +- .../apiv1beta/Client/InsertPromotion/main.go | 2 +- .../apiv1beta/Client/ListPromotions/main.go | 2 +- ...e.shopping.merchant.promotions.v1beta.json | 2 +- .../apiv1beta/Client/ListQuotaGroups/main.go | 2 +- ...google.shopping.merchant.quota.v1beta.json | 2 +- .../apiv1beta/ReportClient/Search/main.go | 2 +- ...ogle.shopping.merchant.reports.v1beta.json | 2 +- .../DeleteMerchantReview/main.go | 2 +- .../GetMerchantReview/main.go | 2 +- .../InsertMerchantReview/main.go | 2 +- .../ListMerchantReviews/main.go | 2 +- .../DeleteProductReview/main.go | 2 +- .../GetProductReview/main.go | 2 +- .../InsertProductReview/main.go | 2 +- .../ListProductReviews/main.go | 2 +- ...ogle.shopping.merchant.reviews.v1beta.json | 2 +- .../CancelOperation/main.go | 2 +- .../DatabaseAdminClient/CopyBackup/main.go | 2 +- .../DatabaseAdminClient/CreateBackup/main.go | 2 +- .../CreateBackupSchedule/main.go | 2 +- .../CreateDatabase/main.go | 2 +- .../DatabaseAdminClient/DeleteBackup/main.go | 2 +- .../DeleteBackupSchedule/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../DatabaseAdminClient/DropDatabase/main.go | 2 +- .../DatabaseAdminClient/GetBackup/main.go | 2 +- .../GetBackupSchedule/main.go | 2 +- .../DatabaseAdminClient/GetDatabase/main.go | 2 +- .../GetDatabaseDdl/main.go | 2 +- .../DatabaseAdminClient/GetIamPolicy/main.go | 2 +- .../DatabaseAdminClient/GetOperation/main.go | 2 +- .../ListBackupOperations/main.go | 2 +- .../ListBackupSchedules/main.go | 2 +- .../DatabaseAdminClient/ListBackups/main.go | 2 +- .../ListDatabaseOperations/main.go | 2 +- .../ListDatabaseRoles/main.go | 2 +- .../DatabaseAdminClient/ListDatabases/main.go | 2 +- .../ListOperations/main.go | 2 +- .../RestoreDatabase/main.go | 2 +- .../DatabaseAdminClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../DatabaseAdminClient/UpdateBackup/main.go | 2 +- .../UpdateBackupSchedule/main.go | 2 +- .../UpdateDatabase/main.go | 2 +- .../UpdateDatabaseDdl/main.go | 2 +- .../CreateInstance/main.go | 2 +- .../CreateInstanceConfig/main.go | 2 +- .../CreateInstancePartition/main.go | 2 +- .../DeleteInstance/main.go | 2 +- .../DeleteInstanceConfig/main.go | 2 +- .../DeleteInstancePartition/main.go | 2 +- .../InstanceAdminClient/GetIamPolicy/main.go | 2 +- .../InstanceAdminClient/GetInstance/main.go | 2 +- .../GetInstanceConfig/main.go | 2 +- .../GetInstancePartition/main.go | 2 +- .../ListInstanceConfigOperations/main.go | 2 +- .../ListInstanceConfigs/main.go | 2 +- .../ListInstancePartitionOperations/main.go | 2 +- .../ListInstancePartitions/main.go | 2 +- .../InstanceAdminClient/ListInstances/main.go | 2 +- .../InstanceAdminClient/MoveInstance/main.go | 2 +- .../InstanceAdminClient/SetIamPolicy/main.go | 2 +- .../TestIamPermissions/main.go | 2 +- .../UpdateInstance/main.go | 2 +- .../UpdateInstanceConfig/main.go | 2 +- .../UpdateInstancePartition/main.go | 2 +- .../apiv1/Client/BatchCreateSessions/main.go | 2 +- .../apiv1/Client/BeginTransaction/main.go | 2 +- .../spanner/apiv1/Client/Commit/main.go | 2 +- .../apiv1/Client/CreateSession/main.go | 2 +- .../apiv1/Client/DeleteSession/main.go | 2 +- .../apiv1/Client/ExecuteBatchDml/main.go | 2 +- .../spanner/apiv1/Client/ExecuteSql/main.go | 2 +- .../spanner/apiv1/Client/GetSession/main.go | 2 +- .../spanner/apiv1/Client/ListSessions/main.go | 2 +- .../apiv1/Client/PartitionQuery/main.go | 2 +- .../apiv1/Client/PartitionRead/main.go | 2 +- .../spanner/apiv1/Client/Read/main.go | 2 +- .../spanner/apiv1/Client/Rollback/main.go | 2 +- .../ExecuteActionAsync/main.go | 2 +- .../CreateCustomClass/main.go | 2 +- .../AdaptationClient/CreatePhraseSet/main.go | 2 +- .../DeleteCustomClass/main.go | 2 +- .../AdaptationClient/DeletePhraseSet/main.go | 2 +- .../AdaptationClient/GetCustomClass/main.go | 2 +- .../AdaptationClient/GetOperation/main.go | 2 +- .../AdaptationClient/GetPhraseSet/main.go | 2 +- .../ListCustomClasses/main.go | 2 +- .../AdaptationClient/ListOperations/main.go | 2 +- .../AdaptationClient/ListPhraseSet/main.go | 2 +- .../UpdateCustomClass/main.go | 2 +- .../AdaptationClient/UpdatePhraseSet/main.go | 2 +- .../speech/apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/LongRunningRecognize/main.go | 2 +- .../speech/apiv1/Client/Recognize/main.go | 2 +- .../apiv1/Client/StreamingRecognize/main.go | 2 +- ...ippet_metadata.google.cloud.speech.v1.json | 2 +- .../CreateCustomClass/main.go | 2 +- .../AdaptationClient/CreatePhraseSet/main.go | 2 +- .../DeleteCustomClass/main.go | 2 +- .../AdaptationClient/DeletePhraseSet/main.go | 2 +- .../AdaptationClient/GetCustomClass/main.go | 2 +- .../AdaptationClient/GetOperation/main.go | 2 +- .../AdaptationClient/GetPhraseSet/main.go | 2 +- .../ListCustomClasses/main.go | 2 +- .../AdaptationClient/ListOperations/main.go | 2 +- .../AdaptationClient/ListPhraseSet/main.go | 2 +- .../UpdateCustomClass/main.go | 2 +- .../AdaptationClient/UpdatePhraseSet/main.go | 2 +- .../apiv1p1beta1/Client/GetOperation/main.go | 2 +- .../Client/ListOperations/main.go | 2 +- .../Client/LongRunningRecognize/main.go | 2 +- .../apiv1p1beta1/Client/Recognize/main.go | 2 +- .../Client/StreamingRecognize/main.go | 2 +- ...etadata.google.cloud.speech.v1p1beta1.json | 2 +- .../apiv2/Client/BatchRecognize/main.go | 2 +- .../apiv2/Client/CancelOperation/main.go | 2 +- .../apiv2/Client/CreateCustomClass/main.go | 2 +- .../apiv2/Client/CreatePhraseSet/main.go | 2 +- .../apiv2/Client/CreateRecognizer/main.go | 2 +- .../apiv2/Client/DeleteCustomClass/main.go | 2 +- .../apiv2/Client/DeleteOperation/main.go | 2 +- .../apiv2/Client/DeletePhraseSet/main.go | 2 +- .../apiv2/Client/DeleteRecognizer/main.go | 2 +- .../speech/apiv2/Client/GetConfig/main.go | 2 +- .../apiv2/Client/GetCustomClass/main.go | 2 +- .../speech/apiv2/Client/GetLocation/main.go | 2 +- .../speech/apiv2/Client/GetOperation/main.go | 2 +- .../speech/apiv2/Client/GetPhraseSet/main.go | 2 +- .../speech/apiv2/Client/GetRecognizer/main.go | 2 +- .../apiv2/Client/ListCustomClasses/main.go | 2 +- .../speech/apiv2/Client/ListLocations/main.go | 2 +- .../apiv2/Client/ListOperations/main.go | 2 +- .../apiv2/Client/ListPhraseSets/main.go | 2 +- .../apiv2/Client/ListRecognizers/main.go | 2 +- .../speech/apiv2/Client/Recognize/main.go | 2 +- .../apiv2/Client/StreamingRecognize/main.go | 2 +- .../apiv2/Client/UndeleteCustomClass/main.go | 2 +- .../apiv2/Client/UndeletePhraseSet/main.go | 2 +- .../apiv2/Client/UndeleteRecognizer/main.go | 2 +- .../speech/apiv2/Client/UpdateConfig/main.go | 2 +- .../apiv2/Client/UpdateCustomClass/main.go | 2 +- .../apiv2/Client/UpdatePhraseSet/main.go | 2 +- .../apiv2/Client/UpdateRecognizer/main.go | 2 +- ...ippet_metadata.google.cloud.speech.v2.json | 2 +- .../StorageControlClient/CreateFolder/main.go | 2 +- .../CreateManagedFolder/main.go | 2 +- .../StorageControlClient/DeleteFolder/main.go | 2 +- .../DeleteManagedFolder/main.go | 2 +- .../StorageControlClient/GetFolder/main.go | 2 +- .../GetManagedFolder/main.go | 2 +- .../GetStorageLayout/main.go | 2 +- .../StorageControlClient/ListFolders/main.go | 2 +- .../ListManagedFolders/main.go | 2 +- .../StorageControlClient/RenameFolder/main.go | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apiv1/Client/CreateReportConfig/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../apiv1/Client/DeleteReportConfig/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/GetReportConfig/main.go | 2 +- .../apiv1/Client/GetReportDetail/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/ListReportConfigs/main.go | 2 +- .../apiv1/Client/ListReportDetails/main.go | 2 +- .../apiv1/Client/UpdateReportConfig/main.go | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apiv1/Client/CreateAgentPool/main.go | 2 +- .../apiv1/Client/CreateTransferJob/main.go | 2 +- .../apiv1/Client/DeleteAgentPool/main.go | 2 +- .../apiv1/Client/DeleteTransferJob/main.go | 2 +- .../apiv1/Client/GetAgentPool/main.go | 2 +- .../Client/GetGoogleServiceAccount/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/GetTransferJob/main.go | 2 +- .../apiv1/Client/ListAgentPools/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/ListTransferJobs/main.go | 2 +- .../Client/PauseTransferOperation/main.go | 2 +- .../Client/ResumeTransferOperation/main.go | 2 +- .../apiv1/Client/RunTransferJob/main.go | 2 +- .../apiv1/Client/UpdateAgentPool/main.go | 2 +- .../apiv1/Client/UpdateTransferJob/main.go | 2 +- .../BatchDeletePhotos/main.go | 2 +- .../BatchGetPhotos/main.go | 2 +- .../BatchUpdatePhotos/main.go | 2 +- .../CreatePhoto/main.go | 2 +- .../CreatePhotoSequence/main.go | 2 +- .../DeletePhoto/main.go | 2 +- .../DeletePhotoSequence/main.go | 2 +- .../StreetViewPublishClient/GetPhoto/main.go | 2 +- .../GetPhotoSequence/main.go | 2 +- .../ListPhotoSequences/main.go | 2 +- .../ListPhotos/main.go | 2 +- .../StartPhotoSequenceUpload/main.go | 2 +- .../StartUpload/main.go | 2 +- .../UpdatePhoto/main.go | 2 +- ...metadata.google.streetview.publish.v1.json | 2 +- .../ListAttachments/main.go | 2 +- .../apiv2/CaseClient/CloseCase/main.go | 2 +- .../apiv2/CaseClient/CreateCase/main.go | 2 +- .../apiv2/CaseClient/EscalateCase/main.go | 2 +- .../support/apiv2/CaseClient/GetCase/main.go | 2 +- .../apiv2/CaseClient/ListCases/main.go | 2 +- .../SearchCaseClassifications/main.go | 2 +- .../apiv2/CaseClient/SearchCases/main.go | 2 +- .../apiv2/CaseClient/UpdateCase/main.go | 2 +- .../apiv2/CommentClient/CreateComment/main.go | 2 +- .../apiv2/CommentClient/ListComments/main.go | 2 +- .../apiv4/CompanyClient/CreateCompany/main.go | 2 +- .../apiv4/CompanyClient/DeleteCompany/main.go | 2 +- .../apiv4/CompanyClient/GetCompany/main.go | 2 +- .../apiv4/CompanyClient/GetOperation/main.go | 2 +- .../apiv4/CompanyClient/ListCompanies/main.go | 2 +- .../apiv4/CompanyClient/UpdateCompany/main.go | 2 +- .../CompletionClient/CompleteQuery/main.go | 2 +- .../CompletionClient/GetOperation/main.go | 2 +- .../EventClient/CreateClientEvent/main.go | 2 +- .../apiv4/EventClient/GetOperation/main.go | 2 +- .../apiv4/JobClient/BatchCreateJobs/main.go | 2 +- .../apiv4/JobClient/BatchDeleteJobs/main.go | 2 +- .../apiv4/JobClient/BatchUpdateJobs/main.go | 2 +- .../talent/apiv4/JobClient/CreateJob/main.go | 2 +- .../talent/apiv4/JobClient/DeleteJob/main.go | 2 +- .../talent/apiv4/JobClient/GetJob/main.go | 2 +- .../apiv4/JobClient/GetOperation/main.go | 2 +- .../talent/apiv4/JobClient/ListJobs/main.go | 2 +- .../talent/apiv4/JobClient/SearchJobs/main.go | 2 +- .../JobClient/SearchJobsForAlert/main.go | 2 +- .../talent/apiv4/JobClient/UpdateJob/main.go | 2 +- .../apiv4/TenantClient/CreateTenant/main.go | 2 +- .../apiv4/TenantClient/DeleteTenant/main.go | 2 +- .../apiv4/TenantClient/GetOperation/main.go | 2 +- .../apiv4/TenantClient/GetTenant/main.go | 2 +- .../apiv4/TenantClient/ListTenants/main.go | 2 +- .../apiv4/TenantClient/UpdateTenant/main.go | 2 +- .../CompanyClient/CreateCompany/main.go | 2 +- .../CompanyClient/DeleteCompany/main.go | 2 +- .../CompanyClient/GetCompany/main.go | 2 +- .../CompanyClient/GetOperation/main.go | 2 +- .../CompanyClient/ListCompanies/main.go | 2 +- .../CompanyClient/UpdateCompany/main.go | 2 +- .../CompletionClient/CompleteQuery/main.go | 2 +- .../CompletionClient/GetOperation/main.go | 2 +- .../EventClient/CreateClientEvent/main.go | 2 +- .../EventClient/GetOperation/main.go | 2 +- .../JobClient/BatchCreateJobs/main.go | 2 +- .../JobClient/BatchDeleteJobs/main.go | 2 +- .../JobClient/BatchUpdateJobs/main.go | 2 +- .../apiv4beta1/JobClient/CreateJob/main.go | 2 +- .../apiv4beta1/JobClient/DeleteJob/main.go | 2 +- .../apiv4beta1/JobClient/GetJob/main.go | 2 +- .../apiv4beta1/JobClient/GetOperation/main.go | 2 +- .../apiv4beta1/JobClient/ListJobs/main.go | 2 +- .../apiv4beta1/JobClient/SearchJobs/main.go | 2 +- .../JobClient/SearchJobsForAlert/main.go | 2 +- .../apiv4beta1/JobClient/UpdateJob/main.go | 2 +- .../TenantClient/CreateTenant/main.go | 2 +- .../TenantClient/DeleteTenant/main.go | 2 +- .../TenantClient/GetOperation/main.go | 2 +- .../apiv4beta1/TenantClient/GetTenant/main.go | 2 +- .../TenantClient/ListTenants/main.go | 2 +- .../TenantClient/UpdateTenant/main.go | 2 +- .../apiv1/Client/ApplyDeployment/main.go | 2 +- .../Client/ApplyHydratedDeployment/main.go | 2 +- .../apiv1/Client/ApproveBlueprint/main.go | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../Client/ComputeDeploymentStatus/main.go | 2 +- .../apiv1/Client/CreateBlueprint/main.go | 2 +- .../apiv1/Client/CreateDeployment/main.go | 2 +- .../apiv1/Client/CreateEdgeSlm/main.go | 2 +- .../Client/CreateOrchestrationCluster/main.go | 2 +- .../apiv1/Client/DeleteBlueprint/main.go | 2 +- .../apiv1/Client/DeleteEdgeSlm/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../Client/DeleteOrchestrationCluster/main.go | 2 +- .../Client/DiscardBlueprintChanges/main.go | 2 +- .../Client/DiscardDeploymentChanges/main.go | 2 +- .../apiv1/Client/GetBlueprint/main.go | 2 +- .../apiv1/Client/GetDeployment/main.go | 2 +- .../apiv1/Client/GetEdgeSlm/main.go | 2 +- .../Client/GetHydratedDeployment/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../Client/GetOrchestrationCluster/main.go | 2 +- .../apiv1/Client/GetPublicBlueprint/main.go | 2 +- .../Client/ListBlueprintRevisions/main.go | 2 +- .../apiv1/Client/ListBlueprints/main.go | 2 +- .../Client/ListDeploymentRevisions/main.go | 2 +- .../apiv1/Client/ListDeployments/main.go | 2 +- .../apiv1/Client/ListEdgeSlms/main.go | 2 +- .../Client/ListHydratedDeployments/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../Client/ListOrchestrationClusters/main.go | 2 +- .../apiv1/Client/ListPublicBlueprints/main.go | 2 +- .../apiv1/Client/ProposeBlueprint/main.go | 2 +- .../apiv1/Client/RejectBlueprint/main.go | 2 +- .../apiv1/Client/RemoveDeployment/main.go | 2 +- .../apiv1/Client/RollbackDeployment/main.go | 2 +- .../Client/SearchBlueprintRevisions/main.go | 2 +- .../Client/SearchDeploymentRevisions/main.go | 2 +- .../apiv1/Client/UpdateBlueprint/main.go | 2 +- .../apiv1/Client/UpdateDeployment/main.go | 2 +- .../Client/UpdateHydratedDeployment/main.go | 2 +- ...adata.google.cloud.telcoautomation.v1.json | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/ListVoices/main.go | 2 +- .../apiv1/Client/StreamingSynthesize/main.go | 2 +- .../apiv1/Client/SynthesizeSpeech/main.go | 2 +- .../GetOperation/main.go | 2 +- .../ListOperations/main.go | 2 +- .../SynthesizeLongAudio/main.go | 2 +- .../tpu/apiv1/Client/CancelOperation/main.go | 2 +- .../tpu/apiv1/Client/CreateNode/main.go | 2 +- .../tpu/apiv1/Client/DeleteNode/main.go | 2 +- .../tpu/apiv1/Client/DeleteOperation/main.go | 2 +- .../apiv1/Client/GetAcceleratorType/main.go | 2 +- .../tpu/apiv1/Client/GetLocation/main.go | 2 +- .../snippets/tpu/apiv1/Client/GetNode/main.go | 2 +- .../tpu/apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/GetTensorFlowVersion/main.go | 2 +- .../apiv1/Client/ListAcceleratorTypes/main.go | 2 +- .../tpu/apiv1/Client/ListLocations/main.go | 2 +- .../tpu/apiv1/Client/ListNodes/main.go | 2 +- .../tpu/apiv1/Client/ListOperations/main.go | 2 +- .../Client/ListTensorFlowVersions/main.go | 2 +- .../tpu/apiv1/Client/ReimageNode/main.go | 2 +- .../tpu/apiv1/Client/StartNode/main.go | 2 +- .../tpu/apiv1/Client/StopNode/main.go | 2 +- .../trace/apiv1/Client/GetTrace/main.go | 2 +- .../trace/apiv1/Client/ListTraces/main.go | 2 +- .../trace/apiv1/Client/PatchTraces/main.go | 2 +- .../apiv2/Client/BatchWriteSpans/main.go | 2 +- .../trace/apiv2/Client/CreateSpan/main.go | 2 +- .../AdaptiveMtTranslate/main.go | 2 +- .../BatchTranslateDocument/main.go | 2 +- .../BatchTranslateText/main.go | 2 +- .../TranslationClient/CancelOperation/main.go | 2 +- .../CreateAdaptiveMtDataset/main.go | 2 +- .../TranslationClient/CreateDataset/main.go | 2 +- .../TranslationClient/CreateGlossary/main.go | 2 +- .../CreateGlossaryEntry/main.go | 2 +- .../TranslationClient/CreateModel/main.go | 2 +- .../DeleteAdaptiveMtDataset/main.go | 2 +- .../DeleteAdaptiveMtFile/main.go | 2 +- .../TranslationClient/DeleteDataset/main.go | 2 +- .../TranslationClient/DeleteGlossary/main.go | 2 +- .../DeleteGlossaryEntry/main.go | 2 +- .../TranslationClient/DeleteModel/main.go | 2 +- .../TranslationClient/DeleteOperation/main.go | 2 +- .../TranslationClient/DetectLanguage/main.go | 2 +- .../TranslationClient/ExportData/main.go | 2 +- .../GetAdaptiveMtDataset/main.go | 2 +- .../GetAdaptiveMtFile/main.go | 2 +- .../TranslationClient/GetDataset/main.go | 2 +- .../TranslationClient/GetGlossary/main.go | 2 +- .../GetGlossaryEntry/main.go | 2 +- .../TranslationClient/GetLocation/main.go | 2 +- .../apiv3/TranslationClient/GetModel/main.go | 2 +- .../TranslationClient/GetOperation/main.go | 2 +- .../GetSupportedLanguages/main.go | 2 +- .../ImportAdaptiveMtFile/main.go | 2 +- .../TranslationClient/ImportData/main.go | 2 +- .../ListAdaptiveMtDatasets/main.go | 2 +- .../ListAdaptiveMtFiles/main.go | 2 +- .../ListAdaptiveMtSentences/main.go | 2 +- .../TranslationClient/ListDatasets/main.go | 2 +- .../TranslationClient/ListExamples/main.go | 2 +- .../TranslationClient/ListGlossaries/main.go | 2 +- .../ListGlossaryEntries/main.go | 2 +- .../TranslationClient/ListLocations/main.go | 2 +- .../TranslationClient/ListModels/main.go | 2 +- .../TranslationClient/ListOperations/main.go | 2 +- .../TranslationClient/RomanizeText/main.go | 2 +- .../TranslateDocument/main.go | 2 +- .../TranslationClient/TranslateText/main.go | 2 +- .../TranslationClient/UpdateGlossary/main.go | 2 +- .../UpdateGlossaryEntry/main.go | 2 +- .../TranslationClient/WaitOperation/main.go | 2 +- ..._metadata.google.cloud.translation.v3.json | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apiv1/Client/CreateAsset/main.go | 2 +- .../apiv1/Client/CreateChannel/main.go | 2 +- .../apiv1/Client/CreateClip/main.go | 2 +- .../apiv1/Client/CreateEvent/main.go | 2 +- .../apiv1/Client/CreateInput/main.go | 2 +- .../apiv1/Client/DeleteAsset/main.go | 2 +- .../apiv1/Client/DeleteChannel/main.go | 2 +- .../apiv1/Client/DeleteClip/main.go | 2 +- .../apiv1/Client/DeleteEvent/main.go | 2 +- .../apiv1/Client/DeleteInput/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../livestream/apiv1/Client/GetAsset/main.go | 2 +- .../apiv1/Client/GetChannel/main.go | 2 +- .../livestream/apiv1/Client/GetClip/main.go | 2 +- .../livestream/apiv1/Client/GetEvent/main.go | 2 +- .../livestream/apiv1/Client/GetInput/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../livestream/apiv1/Client/GetPool/main.go | 2 +- .../apiv1/Client/ListAssets/main.go | 2 +- .../apiv1/Client/ListChannels/main.go | 2 +- .../livestream/apiv1/Client/ListClips/main.go | 2 +- .../apiv1/Client/ListEvents/main.go | 2 +- .../apiv1/Client/ListInputs/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/StartChannel/main.go | 2 +- .../apiv1/Client/StopChannel/main.go | 2 +- .../apiv1/Client/UpdateChannel/main.go | 2 +- .../apiv1/Client/UpdateInput/main.go | 2 +- .../apiv1/Client/UpdatePool/main.go | 2 +- ...data.google.cloud.video.livestream.v1.json | 2 +- .../CancelOperation/main.go | 2 +- .../VideoStitcherClient/CreateCdnKey/main.go | 2 +- .../CreateLiveConfig/main.go | 2 +- .../CreateLiveSession/main.go | 2 +- .../VideoStitcherClient/CreateSlate/main.go | 2 +- .../CreateVodConfig/main.go | 2 +- .../CreateVodSession/main.go | 2 +- .../VideoStitcherClient/DeleteCdnKey/main.go | 2 +- .../DeleteLiveConfig/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../VideoStitcherClient/DeleteSlate/main.go | 2 +- .../DeleteVodConfig/main.go | 2 +- .../VideoStitcherClient/GetCdnKey/main.go | 2 +- .../GetLiveAdTagDetail/main.go | 2 +- .../VideoStitcherClient/GetLiveConfig/main.go | 2 +- .../GetLiveSession/main.go | 2 +- .../VideoStitcherClient/GetOperation/main.go | 2 +- .../VideoStitcherClient/GetSlate/main.go | 2 +- .../GetVodAdTagDetail/main.go | 2 +- .../VideoStitcherClient/GetVodConfig/main.go | 2 +- .../VideoStitcherClient/GetVodSession/main.go | 2 +- .../GetVodStitchDetail/main.go | 2 +- .../VideoStitcherClient/ListCdnKeys/main.go | 2 +- .../ListLiveAdTagDetails/main.go | 2 +- .../ListLiveConfigs/main.go | 2 +- .../ListOperations/main.go | 2 +- .../VideoStitcherClient/ListSlates/main.go | 2 +- .../ListVodAdTagDetails/main.go | 2 +- .../ListVodConfigs/main.go | 2 +- .../ListVodStitchDetails/main.go | 2 +- .../VideoStitcherClient/UpdateCdnKey/main.go | 2 +- .../UpdateLiveConfig/main.go | 2 +- .../VideoStitcherClient/UpdateSlate/main.go | 2 +- .../UpdateVodConfig/main.go | 2 +- ...tadata.google.cloud.video.stitcher.v1.json | 2 +- .../transcoder/apiv1/Client/CreateJob/main.go | 2 +- .../apiv1/Client/CreateJobTemplate/main.go | 2 +- .../transcoder/apiv1/Client/DeleteJob/main.go | 2 +- .../apiv1/Client/DeleteJobTemplate/main.go | 2 +- .../transcoder/apiv1/Client/GetJob/main.go | 2 +- .../apiv1/Client/GetJobTemplate/main.go | 2 +- .../apiv1/Client/ListJobTemplates/main.go | 2 +- .../transcoder/apiv1/Client/ListJobs/main.go | 2 +- ...data.google.cloud.video.transcoder.v1.json | 2 +- .../apiv1/Client/AnnotateVideo/main.go | 2 +- .../apiv1beta2/Client/AnnotateVideo/main.go | 2 +- .../apiv1p3beta1/Client/AnnotateVideo/main.go | 2 +- .../StreamingAnnotateVideo/main.go | 2 +- .../AsyncBatchAnnotateFiles/main.go | 2 +- .../AsyncBatchAnnotateImages/main.go | 2 +- .../BatchAnnotateFiles/main.go | 2 +- .../BatchAnnotateImages/main.go | 2 +- .../ImageAnnotatorClient/GetOperation/main.go | 2 +- .../AddProductToProductSet/main.go | 2 +- .../ProductSearchClient/CreateProduct/main.go | 2 +- .../CreateProductSet/main.go | 2 +- .../CreateReferenceImage/main.go | 2 +- .../ProductSearchClient/DeleteProduct/main.go | 2 +- .../DeleteProductSet/main.go | 2 +- .../DeleteReferenceImage/main.go | 2 +- .../ProductSearchClient/GetOperation/main.go | 2 +- .../ProductSearchClient/GetProduct/main.go | 2 +- .../ProductSearchClient/GetProductSet/main.go | 2 +- .../GetReferenceImage/main.go | 2 +- .../ImportProductSets/main.go | 2 +- .../ListProductSets/main.go | 2 +- .../ProductSearchClient/ListProducts/main.go | 2 +- .../ListProductsInProductSet/main.go | 2 +- .../ListReferenceImages/main.go | 2 +- .../ProductSearchClient/PurgeProducts/main.go | 2 +- .../RemoveProductFromProductSet/main.go | 2 +- .../ProductSearchClient/UpdateProduct/main.go | 2 +- .../UpdateProductSet/main.go | 2 +- ...ippet_metadata.google.cloud.vision.v1.json | 2 +- .../BatchAnnotateImages/main.go | 2 +- ...etadata.google.cloud.vision.v1p1beta1.json | 2 +- .../AddApplicationStreamInput/main.go | 2 +- .../AppPlatformClient/CancelOperation/main.go | 2 +- .../CreateApplication/main.go | 2 +- .../CreateApplicationInstances/main.go | 2 +- .../AppPlatformClient/CreateDraft/main.go | 2 +- .../AppPlatformClient/CreateProcessor/main.go | 2 +- .../DeleteApplication/main.go | 2 +- .../DeleteApplicationInstances/main.go | 2 +- .../AppPlatformClient/DeleteDraft/main.go | 2 +- .../AppPlatformClient/DeleteOperation/main.go | 2 +- .../AppPlatformClient/DeleteProcessor/main.go | 2 +- .../DeployApplication/main.go | 2 +- .../AppPlatformClient/GetApplication/main.go | 2 +- .../apiv1/AppPlatformClient/GetDraft/main.go | 2 +- .../AppPlatformClient/GetInstance/main.go | 2 +- .../AppPlatformClient/GetOperation/main.go | 2 +- .../AppPlatformClient/GetProcessor/main.go | 2 +- .../ListApplications/main.go | 2 +- .../AppPlatformClient/ListDrafts/main.go | 2 +- .../AppPlatformClient/ListInstances/main.go | 2 +- .../AppPlatformClient/ListOperations/main.go | 2 +- .../ListPrebuiltProcessors/main.go | 2 +- .../AppPlatformClient/ListProcessors/main.go | 2 +- .../RemoveApplicationStreamInput/main.go | 2 +- .../UndeployApplication/main.go | 2 +- .../UpdateApplication/main.go | 2 +- .../UpdateApplicationInstances/main.go | 2 +- .../UpdateApplicationStreamInput/main.go | 2 +- .../AppPlatformClient/UpdateDraft/main.go | 2 +- .../AppPlatformClient/UpdateProcessor/main.go | 2 +- .../HealthCheckClient/CancelOperation/main.go | 2 +- .../HealthCheckClient/DeleteOperation/main.go | 2 +- .../HealthCheckClient/GetOperation/main.go | 2 +- .../HealthCheckClient/HealthCheck/main.go | 2 +- .../HealthCheckClient/ListOperations/main.go | 2 +- .../BatchRunProcess/main.go | 2 +- .../CancelOperation/main.go | 2 +- .../CreateAnalysis/main.go | 2 +- .../CreateOperator/main.go | 2 +- .../CreateProcess/main.go | 2 +- .../DeleteAnalysis/main.go | 2 +- .../DeleteOperation/main.go | 2 +- .../DeleteOperator/main.go | 2 +- .../DeleteProcess/main.go | 2 +- .../GetAnalysis/main.go | 2 +- .../GetOperation/main.go | 2 +- .../GetOperator/main.go | 2 +- .../GetProcess/main.go | 2 +- .../ListAnalyses/main.go | 2 +- .../ListOperations/main.go | 2 +- .../ListOperators/main.go | 2 +- .../ListProcesses/main.go | 2 +- .../ListPublicOperators/main.go | 2 +- .../ResolveOperatorInfo/main.go | 2 +- .../UpdateAnalysis/main.go | 2 +- .../UpdateOperator/main.go | 2 +- .../UpdateProcess/main.go | 2 +- .../StreamingClient/AcquireLease/main.go | 2 +- .../StreamingClient/CancelOperation/main.go | 2 +- .../StreamingClient/DeleteOperation/main.go | 2 +- .../StreamingClient/GetOperation/main.go | 2 +- .../StreamingClient/ListOperations/main.go | 2 +- .../StreamingClient/ReceiveEvents/main.go | 2 +- .../StreamingClient/ReceivePackets/main.go | 2 +- .../StreamingClient/ReleaseLease/main.go | 2 +- .../apiv1/StreamingClient/RenewLease/main.go | 2 +- .../apiv1/StreamingClient/SendPackets/main.go | 2 +- .../StreamsClient/CancelOperation/main.go | 2 +- .../apiv1/StreamsClient/CreateCluster/main.go | 2 +- .../apiv1/StreamsClient/CreateEvent/main.go | 2 +- .../apiv1/StreamsClient/CreateSeries/main.go | 2 +- .../apiv1/StreamsClient/CreateStream/main.go | 2 +- .../apiv1/StreamsClient/DeleteCluster/main.go | 2 +- .../apiv1/StreamsClient/DeleteEvent/main.go | 2 +- .../StreamsClient/DeleteOperation/main.go | 2 +- .../apiv1/StreamsClient/DeleteSeries/main.go | 2 +- .../apiv1/StreamsClient/DeleteStream/main.go | 2 +- .../GenerateStreamHlsToken/main.go | 2 +- .../apiv1/StreamsClient/GetCluster/main.go | 2 +- .../apiv1/StreamsClient/GetEvent/main.go | 2 +- .../apiv1/StreamsClient/GetOperation/main.go | 2 +- .../apiv1/StreamsClient/GetSeries/main.go | 2 +- .../apiv1/StreamsClient/GetStream/main.go | 2 +- .../StreamsClient/GetStreamThumbnail/main.go | 2 +- .../apiv1/StreamsClient/ListClusters/main.go | 2 +- .../apiv1/StreamsClient/ListEvents/main.go | 2 +- .../StreamsClient/ListOperations/main.go | 2 +- .../apiv1/StreamsClient/ListSeries/main.go | 2 +- .../apiv1/StreamsClient/ListStreams/main.go | 2 +- .../StreamsClient/MaterializeChannel/main.go | 2 +- .../apiv1/StreamsClient/UpdateCluster/main.go | 2 +- .../apiv1/StreamsClient/UpdateEvent/main.go | 2 +- .../apiv1/StreamsClient/UpdateSeries/main.go | 2 +- .../apiv1/StreamsClient/UpdateStream/main.go | 2 +- .../WarehouseClient/AddCollectionItem/main.go | 2 +- .../WarehouseClient/AnalyzeAsset/main.go | 2 +- .../WarehouseClient/AnalyzeCorpus/main.go | 2 +- .../WarehouseClient/CancelOperation/main.go | 2 +- .../apiv1/WarehouseClient/ClipAsset/main.go | 2 +- .../WarehouseClient/CreateAnnotation/main.go | 2 +- .../apiv1/WarehouseClient/CreateAsset/main.go | 2 +- .../WarehouseClient/CreateCollection/main.go | 2 +- .../WarehouseClient/CreateCorpus/main.go | 2 +- .../WarehouseClient/CreateDataSchema/main.go | 2 +- .../apiv1/WarehouseClient/CreateIndex/main.go | 2 +- .../CreateIndexEndpoint/main.go | 2 +- .../CreateSearchConfig/main.go | 2 +- .../CreateSearchHypernym/main.go | 2 +- .../WarehouseClient/DeleteAnnotation/main.go | 2 +- .../apiv1/WarehouseClient/DeleteAsset/main.go | 2 +- .../WarehouseClient/DeleteCollection/main.go | 2 +- .../WarehouseClient/DeleteCorpus/main.go | 2 +- .../WarehouseClient/DeleteDataSchema/main.go | 2 +- .../apiv1/WarehouseClient/DeleteIndex/main.go | 2 +- .../DeleteIndexEndpoint/main.go | 2 +- .../WarehouseClient/DeleteOperation/main.go | 2 +- .../DeleteSearchConfig/main.go | 2 +- .../DeleteSearchHypernym/main.go | 2 +- .../apiv1/WarehouseClient/DeployIndex/main.go | 2 +- .../WarehouseClient/GenerateHlsUri/main.go | 2 +- .../GenerateRetrievalUrl/main.go | 2 +- .../WarehouseClient/GetAnnotation/main.go | 2 +- .../apiv1/WarehouseClient/GetAsset/main.go | 2 +- .../WarehouseClient/GetCollection/main.go | 2 +- .../apiv1/WarehouseClient/GetCorpus/main.go | 2 +- .../WarehouseClient/GetDataSchema/main.go | 2 +- .../apiv1/WarehouseClient/GetIndex/main.go | 2 +- .../WarehouseClient/GetIndexEndpoint/main.go | 2 +- .../WarehouseClient/GetOperation/main.go | 2 +- .../WarehouseClient/GetSearchConfig/main.go | 2 +- .../WarehouseClient/GetSearchHypernym/main.go | 2 +- .../WarehouseClient/ImportAssets/main.go | 2 +- .../apiv1/WarehouseClient/IndexAsset/main.go | 2 +- .../apiv1/WarehouseClient/IngestAsset/main.go | 2 +- .../WarehouseClient/ListAnnotations/main.go | 2 +- .../apiv1/WarehouseClient/ListAssets/main.go | 2 +- .../WarehouseClient/ListCollections/main.go | 2 +- .../apiv1/WarehouseClient/ListCorpora/main.go | 2 +- .../WarehouseClient/ListDataSchemas/main.go | 2 +- .../ListIndexEndpoints/main.go | 2 +- .../apiv1/WarehouseClient/ListIndexes/main.go | 2 +- .../WarehouseClient/ListOperations/main.go | 2 +- .../WarehouseClient/ListSearchConfigs/main.go | 2 +- .../ListSearchHypernyms/main.go | 2 +- .../RemoveCollectionItem/main.go | 2 +- .../WarehouseClient/RemoveIndexAsset/main.go | 2 +- .../WarehouseClient/SearchAssets/main.go | 2 +- .../SearchIndexEndpoint/main.go | 2 +- .../WarehouseClient/UndeployIndex/main.go | 2 +- .../WarehouseClient/UpdateAnnotation/main.go | 2 +- .../apiv1/WarehouseClient/UpdateAsset/main.go | 2 +- .../WarehouseClient/UpdateCollection/main.go | 2 +- .../WarehouseClient/UpdateCorpus/main.go | 2 +- .../WarehouseClient/UpdateDataSchema/main.go | 2 +- .../apiv1/WarehouseClient/UpdateIndex/main.go | 2 +- .../UpdateIndexEndpoint/main.go | 2 +- .../UpdateSearchConfig/main.go | 2 +- .../UpdateSearchHypernym/main.go | 2 +- .../apiv1/WarehouseClient/UploadAsset/main.go | 2 +- .../ViewCollectionItems/main.go | 2 +- .../WarehouseClient/ViewIndexedAssets/main.go | 2 +- ...pet_metadata.google.cloud.visionai.v1.json | 2 +- .../apiv1/Client/AddGroupMigration/main.go | 2 +- .../apiv1/Client/CancelCloneJob/main.go | 2 +- .../apiv1/Client/CancelCutoverJob/main.go | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apiv1/Client/CreateCloneJob/main.go | 2 +- .../apiv1/Client/CreateCutoverJob/main.go | 2 +- .../Client/CreateDatacenterConnector/main.go | 2 +- .../apiv1/Client/CreateGroup/main.go | 2 +- .../apiv1/Client/CreateMigratingVm/main.go | 2 +- .../apiv1/Client/CreateSource/main.go | 2 +- .../apiv1/Client/CreateTargetProject/main.go | 2 +- .../Client/CreateUtilizationReport/main.go | 2 +- .../Client/DeleteDatacenterConnector/main.go | 2 +- .../apiv1/Client/DeleteGroup/main.go | 2 +- .../apiv1/Client/DeleteMigratingVm/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../apiv1/Client/DeleteSource/main.go | 2 +- .../apiv1/Client/DeleteTargetProject/main.go | 2 +- .../Client/DeleteUtilizationReport/main.go | 2 +- .../apiv1/Client/FetchInventory/main.go | 2 +- .../apiv1/Client/FinalizeMigration/main.go | 2 +- .../apiv1/Client/GetCloneJob/main.go | 2 +- .../apiv1/Client/GetCutoverJob/main.go | 2 +- .../Client/GetDatacenterConnector/main.go | 2 +- .../vmmigration/apiv1/Client/GetGroup/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetMigratingVm/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/GetReplicationCycle/main.go | 2 +- .../apiv1/Client/GetSource/main.go | 2 +- .../apiv1/Client/GetTargetProject/main.go | 2 +- .../apiv1/Client/GetUtilizationReport/main.go | 2 +- .../apiv1/Client/ListCloneJobs/main.go | 2 +- .../apiv1/Client/ListCutoverJobs/main.go | 2 +- .../Client/ListDatacenterConnectors/main.go | 2 +- .../apiv1/Client/ListGroups/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListMigratingVms/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../Client/ListReplicationCycles/main.go | 2 +- .../apiv1/Client/ListSources/main.go | 2 +- .../apiv1/Client/ListTargetProjects/main.go | 2 +- .../Client/ListUtilizationReports/main.go | 2 +- .../apiv1/Client/PauseMigration/main.go | 2 +- .../apiv1/Client/RemoveGroupMigration/main.go | 2 +- .../apiv1/Client/ResumeMigration/main.go | 2 +- .../apiv1/Client/StartMigration/main.go | 2 +- .../apiv1/Client/UpdateGroup/main.go | 2 +- .../apiv1/Client/UpdateMigratingVm/main.go | 2 +- .../apiv1/Client/UpdateSource/main.go | 2 +- .../apiv1/Client/UpdateTargetProject/main.go | 2 +- .../apiv1/Client/UpgradeAppliance/main.go | 2 +- .../apiv1/Client/CreateCluster/main.go | 2 +- .../Client/CreateExternalAccessRule/main.go | 2 +- .../Client/CreateExternalAddress/main.go | 2 +- .../Client/CreateHcxActivationKey/main.go | 2 +- .../apiv1/Client/CreateLoggingServer/main.go | 2 +- .../CreateManagementDnsZoneBinding/main.go | 2 +- .../apiv1/Client/CreateNetworkPeering/main.go | 2 +- .../apiv1/Client/CreateNetworkPolicy/main.go | 2 +- .../apiv1/Client/CreatePrivateCloud/main.go | 2 +- .../Client/CreatePrivateConnection/main.go | 2 +- .../Client/CreateVmwareEngineNetwork/main.go | 2 +- .../apiv1/Client/DeleteCluster/main.go | 2 +- .../Client/DeleteExternalAccessRule/main.go | 2 +- .../Client/DeleteExternalAddress/main.go | 2 +- .../apiv1/Client/DeleteLoggingServer/main.go | 2 +- .../DeleteManagementDnsZoneBinding/main.go | 2 +- .../apiv1/Client/DeleteNetworkPeering/main.go | 2 +- .../apiv1/Client/DeleteNetworkPolicy/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../apiv1/Client/DeletePrivateCloud/main.go | 2 +- .../Client/DeletePrivateConnection/main.go | 2 +- .../Client/DeleteVmwareEngineNetwork/main.go | 2 +- .../main.go | 2 +- .../apiv1/Client/GetCluster/main.go | 2 +- .../apiv1/Client/GetDnsBindPermission/main.go | 2 +- .../apiv1/Client/GetDnsForwarding/main.go | 2 +- .../Client/GetExternalAccessRule/main.go | 2 +- .../apiv1/Client/GetExternalAddress/main.go | 2 +- .../apiv1/Client/GetHcxActivationKey/main.go | 2 +- .../apiv1/Client/GetIamPolicy/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetLoggingServer/main.go | 2 +- .../GetManagementDnsZoneBinding/main.go | 2 +- .../apiv1/Client/GetNetworkPeering/main.go | 2 +- .../apiv1/Client/GetNetworkPolicy/main.go | 2 +- .../vmwareengine/apiv1/Client/GetNode/main.go | 2 +- .../apiv1/Client/GetNodeType/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/GetPrivateCloud/main.go | 2 +- .../apiv1/Client/GetPrivateConnection/main.go | 2 +- .../apiv1/Client/GetSubnet/main.go | 2 +- .../Client/GetVmwareEngineNetwork/main.go | 2 +- .../Client/GrantDnsBindPermission/main.go | 2 +- .../apiv1/Client/ListClusters/main.go | 2 +- .../Client/ListExternalAccessRules/main.go | 2 +- .../Client/ListExternalAddresses/main.go | 2 +- .../Client/ListHcxActivationKeys/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListLoggingServers/main.go | 2 +- .../ListManagementDnsZoneBindings/main.go | 2 +- .../apiv1/Client/ListNetworkPeerings/main.go | 2 +- .../apiv1/Client/ListNetworkPolicies/main.go | 2 +- .../apiv1/Client/ListNodeTypes/main.go | 2 +- .../apiv1/Client/ListNodes/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/ListPeeringRoutes/main.go | 2 +- .../apiv1/Client/ListPrivateClouds/main.go | 2 +- .../main.go | 2 +- .../Client/ListPrivateConnections/main.go | 2 +- .../apiv1/Client/ListSubnets/main.go | 2 +- .../Client/ListVmwareEngineNetworks/main.go | 2 +- .../RepairManagementDnsZoneBinding/main.go | 2 +- .../apiv1/Client/ResetNsxCredentials/main.go | 2 +- .../Client/ResetVcenterCredentials/main.go | 2 +- .../Client/RevokeDnsBindPermission/main.go | 2 +- .../apiv1/Client/SetIamPolicy/main.go | 2 +- .../apiv1/Client/ShowNsxCredentials/main.go | 2 +- .../Client/ShowVcenterCredentials/main.go | 2 +- .../apiv1/Client/TestIamPermissions/main.go | 2 +- .../apiv1/Client/UndeletePrivateCloud/main.go | 2 +- .../apiv1/Client/UpdateCluster/main.go | 2 +- .../apiv1/Client/UpdateDnsForwarding/main.go | 2 +- .../Client/UpdateExternalAccessRule/main.go | 2 +- .../Client/UpdateExternalAddress/main.go | 2 +- .../apiv1/Client/UpdateLoggingServer/main.go | 2 +- .../UpdateManagementDnsZoneBinding/main.go | 2 +- .../apiv1/Client/UpdateNetworkPeering/main.go | 2 +- .../apiv1/Client/UpdateNetworkPolicy/main.go | 2 +- .../apiv1/Client/UpdatePrivateCloud/main.go | 2 +- .../Client/UpdatePrivateConnection/main.go | 2 +- .../apiv1/Client/UpdateSubnet/main.go | 2 +- .../Client/UpdateVmwareEngineNetwork/main.go | 2 +- ...metadata.google.cloud.vmwareengine.v1.json | 2 +- .../apiv1/Client/CreateConnector/main.go | 2 +- .../apiv1/Client/DeleteConnector/main.go | 2 +- .../apiv1/Client/GetConnector/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/ListConnectors/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../Client/ComputeThreatListDiff/main.go | 2 +- .../apiv1/Client/CreateSubmission/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../webrisk/apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../webrisk/apiv1/Client/SearchHashes/main.go | 2 +- .../webrisk/apiv1/Client/SearchUris/main.go | 2 +- .../webrisk/apiv1/Client/SubmitUri/main.go | 2 +- .../ComputeThreatListDiff/main.go | 2 +- .../SearchHashes/main.go | 2 +- .../SearchUris/main.go | 2 +- .../apiv1/Client/CreateScanConfig/main.go | 2 +- .../apiv1/Client/DeleteScanConfig/main.go | 2 +- .../apiv1/Client/GetFinding/main.go | 2 +- .../apiv1/Client/GetScanConfig/main.go | 2 +- .../apiv1/Client/GetScanRun/main.go | 2 +- .../apiv1/Client/ListCrawledUrls/main.go | 2 +- .../apiv1/Client/ListFindingTypeStats/main.go | 2 +- .../apiv1/Client/ListFindings/main.go | 2 +- .../apiv1/Client/ListScanConfigs/main.go | 2 +- .../apiv1/Client/ListScanRuns/main.go | 2 +- .../apiv1/Client/StartScanRun/main.go | 2 +- .../apiv1/Client/StopScanRun/main.go | 2 +- .../apiv1/Client/UpdateScanConfig/main.go | 2 +- .../apiv1/Client/CreateWorkflow/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../apiv1/Client/DeleteWorkflow/main.go | 2 +- .../apiv1/Client/GetLocation/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/GetWorkflow/main.go | 2 +- .../apiv1/Client/ListLocations/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../apiv1/Client/ListWorkflows/main.go | 2 +- .../apiv1/Client/UpdateWorkflow/main.go | 2 +- .../apiv1beta/Client/CreateWorkflow/main.go | 2 +- .../apiv1beta/Client/DeleteWorkflow/main.go | 2 +- .../apiv1beta/Client/GetWorkflow/main.go | 2 +- .../apiv1beta/Client/ListWorkflows/main.go | 2 +- .../apiv1beta/Client/UpdateWorkflow/main.go | 2 +- .../apiv1/Client/CancelExecution/main.go | 2 +- .../apiv1/Client/CreateExecution/main.go | 2 +- .../apiv1/Client/GetExecution/main.go | 2 +- .../apiv1/Client/ListExecutions/main.go | 2 +- .../apiv1beta/Client/CancelExecution/main.go | 2 +- .../apiv1beta/Client/CreateExecution/main.go | 2 +- .../apiv1beta/Client/GetExecution/main.go | 2 +- .../apiv1beta/Client/ListExecutions/main.go | 2 +- .../apiv1/Client/CancelOperation/main.go | 2 +- .../apiv1/Client/CreateWorkstation/main.go | 2 +- .../Client/CreateWorkstationCluster/main.go | 2 +- .../Client/CreateWorkstationConfig/main.go | 2 +- .../apiv1/Client/DeleteOperation/main.go | 2 +- .../apiv1/Client/DeleteWorkstation/main.go | 2 +- .../Client/DeleteWorkstationCluster/main.go | 2 +- .../Client/DeleteWorkstationConfig/main.go | 2 +- .../apiv1/Client/GenerateAccessToken/main.go | 2 +- .../apiv1/Client/GetIamPolicy/main.go | 2 +- .../apiv1/Client/GetOperation/main.go | 2 +- .../apiv1/Client/GetWorkstation/main.go | 2 +- .../Client/GetWorkstationCluster/main.go | 2 +- .../apiv1/Client/GetWorkstationConfig/main.go | 2 +- .../apiv1/Client/ListOperations/main.go | 2 +- .../ListUsableWorkstationConfigs/main.go | 2 +- .../Client/ListUsableWorkstations/main.go | 2 +- .../Client/ListWorkstationClusters/main.go | 2 +- .../Client/ListWorkstationConfigs/main.go | 2 +- .../apiv1/Client/ListWorkstations/main.go | 2 +- .../apiv1/Client/SetIamPolicy/main.go | 2 +- .../apiv1/Client/StartWorkstation/main.go | 2 +- .../apiv1/Client/StopWorkstation/main.go | 2 +- .../apiv1/Client/TestIamPermissions/main.go | 2 +- .../apiv1/Client/UpdateWorkstation/main.go | 2 +- .../Client/UpdateWorkstationCluster/main.go | 2 +- .../Client/UpdateWorkstationConfig/main.go | 2 +- ...metadata.google.cloud.workstations.v1.json | 2 +- .../apiv1beta/Client/CancelOperation/main.go | 2 +- .../Client/CreateWorkstation/main.go | 2 +- .../Client/CreateWorkstationCluster/main.go | 2 +- .../Client/CreateWorkstationConfig/main.go | 2 +- .../apiv1beta/Client/DeleteOperation/main.go | 2 +- .../Client/DeleteWorkstation/main.go | 2 +- .../Client/DeleteWorkstationCluster/main.go | 2 +- .../Client/DeleteWorkstationConfig/main.go | 2 +- .../Client/GenerateAccessToken/main.go | 2 +- .../apiv1beta/Client/GetIamPolicy/main.go | 2 +- .../apiv1beta/Client/GetOperation/main.go | 2 +- .../apiv1beta/Client/GetWorkstation/main.go | 2 +- .../Client/GetWorkstationCluster/main.go | 2 +- .../Client/GetWorkstationConfig/main.go | 2 +- .../apiv1beta/Client/ListOperations/main.go | 2 +- .../ListUsableWorkstationConfigs/main.go | 2 +- .../Client/ListUsableWorkstations/main.go | 2 +- .../Client/ListWorkstationClusters/main.go | 2 +- .../Client/ListWorkstationConfigs/main.go | 2 +- .../apiv1beta/Client/ListWorkstations/main.go | 2 +- .../apiv1beta/Client/SetIamPolicy/main.go | 2 +- .../apiv1beta/Client/StartWorkstation/main.go | 2 +- .../apiv1beta/Client/StopWorkstation/main.go | 2 +- .../Client/TestIamPermissions/main.go | 2 +- .../Client/UpdateWorkstation/main.go | 2 +- .../Client/UpdateWorkstationCluster/main.go | 2 +- .../Client/UpdateWorkstationConfig/main.go | 2 +- ...data.google.cloud.workstations.v1beta.json | 2 +- iot/apiv1/auxiliary.go | 2 +- iot/apiv1/auxiliary_go123.go | 2 +- iot/apiv1/device_manager_client.go | 2 +- ...evice_manager_client_example_go123_test.go | 2 +- .../device_manager_client_example_test.go | 2 +- iot/apiv1/doc.go | 2 +- iot/apiv1/helpers.go | 2 +- kms/apiv1/autokey_admin_client.go | 2 +- ...autokey_admin_client_example_go123_test.go | 2 +- .../autokey_admin_client_example_test.go | 2 +- kms/apiv1/autokey_client.go | 2 +- .../autokey_client_example_go123_test.go | 2 +- kms/apiv1/autokey_client_example_test.go | 2 +- kms/apiv1/auxiliary.go | 2 +- kms/apiv1/auxiliary_go123.go | 2 +- kms/apiv1/doc.go | 2 +- kms/apiv1/ekm_client.go | 2 +- kms/apiv1/ekm_client_example_go123_test.go | 2 +- kms/apiv1/ekm_client_example_test.go | 2 +- kms/apiv1/helpers.go | 2 +- kms/apiv1/key_management_client.go | 2 +- ...ey_management_client_example_go123_test.go | 2 +- .../key_management_client_example_test.go | 2 +- kms/inventory/apiv1/auxiliary.go | 2 +- kms/inventory/apiv1/auxiliary_go123.go | 2 +- kms/inventory/apiv1/doc.go | 2 +- kms/inventory/apiv1/helpers.go | 2 +- kms/inventory/apiv1/key_dashboard_client.go | 2 +- ...key_dashboard_client_example_go123_test.go | 2 +- .../key_dashboard_client_example_test.go | 2 +- kms/inventory/apiv1/key_tracking_client.go | 2 +- .../key_tracking_client_example_go123_test.go | 2 +- .../apiv1/key_tracking_client_example_test.go | 2 +- language/apiv1/auxiliary.go | 2 +- language/apiv1/auxiliary_go123.go | 2 +- language/apiv1/doc.go | 2 +- language/apiv1/helpers.go | 2 +- language/apiv1/language_client.go | 2 +- .../language_client_example_go123_test.go | 2 +- .../apiv1/language_client_example_test.go | 2 +- language/apiv1beta2/auxiliary.go | 2 +- language/apiv1beta2/auxiliary_go123.go | 2 +- language/apiv1beta2/doc.go | 2 +- language/apiv1beta2/helpers.go | 2 +- language/apiv1beta2/language_client.go | 2 +- .../language_client_example_go123_test.go | 2 +- .../language_client_example_test.go | 2 +- language/apiv2/auxiliary.go | 2 +- language/apiv2/auxiliary_go123.go | 2 +- language/apiv2/doc.go | 2 +- language/apiv2/helpers.go | 2 +- language/apiv2/language_client.go | 2 +- .../language_client_example_go123_test.go | 2 +- .../apiv2/language_client_example_test.go | 2 +- lifesciences/apiv2beta/auxiliary.go | 2 +- lifesciences/apiv2beta/auxiliary_go123.go | 2 +- lifesciences/apiv2beta/doc.go | 2 +- lifesciences/apiv2beta/helpers.go | 2 +- .../workflows_service_v2_beta_client.go | 2 +- ...rvice_v2_beta_client_example_go123_test.go | 2 +- ...ows_service_v2_beta_client_example_test.go | 2 +- logging/apiv2/auxiliary.go | 2 +- logging/apiv2/auxiliary_go123.go | 2 +- logging/apiv2/config_client.go | 2 +- .../apiv2/config_client_example_go123_test.go | 2 +- logging/apiv2/config_client_example_test.go | 2 +- logging/apiv2/doc.go | 2 +- logging/apiv2/helpers.go | 2 +- logging/apiv2/logging_client.go | 2 +- .../logging_client_example_go123_test.go | 2 +- logging/apiv2/logging_client_example_test.go | 2 +- logging/apiv2/metrics_client.go | 2 +- .../metrics_client_example_go123_test.go | 2 +- logging/apiv2/metrics_client_example_test.go | 2 +- longrunning/autogen/auxiliary.go | 2 +- longrunning/autogen/auxiliary_go123.go | 2 +- longrunning/autogen/doc.go | 2 +- longrunning/autogen/helpers.go | 2 +- longrunning/autogen/operations_client.go | 2 +- .../operations_client_example_go123_test.go | 2 +- .../autogen/operations_client_example_test.go | 2 +- managedidentities/apiv1/auxiliary.go | 2 +- managedidentities/apiv1/auxiliary_go123.go | 2 +- managedidentities/apiv1/doc.go | 2 +- managedidentities/apiv1/helpers.go | 2 +- .../apiv1/managed_identities_client.go | 2 +- ...ed_identities_client_example_go123_test.go | 2 +- .../managed_identities_client_example_test.go | 2 +- managedkafka/apiv1/auxiliary.go | 2 +- managedkafka/apiv1/auxiliary_go123.go | 2 +- managedkafka/apiv1/doc.go | 2 +- managedkafka/apiv1/helpers.go | 2 +- managedkafka/apiv1/managed_kafka_client.go | 2 +- ...managed_kafka_client_example_go123_test.go | 2 +- .../managed_kafka_client_example_test.go | 2 +- .../apiv1/address_validation_client.go | 2 +- ...ss_validation_client_example_go123_test.go | 2 +- .../address_validation_client_example_test.go | 2 +- maps/addressvalidation/apiv1/auxiliary.go | 2 +- .../apiv1/auxiliary_go123.go | 2 +- maps/addressvalidation/apiv1/doc.go | 2 +- maps/addressvalidation/apiv1/helpers.go | 2 +- .../apiv1/area_insights_client.go | 2 +- ...area_insights_client_example_go123_test.go | 2 +- .../area_insights_client_example_test.go | 2 +- maps/areainsights/apiv1/auxiliary.go | 2 +- maps/areainsights/apiv1/auxiliary_go123.go | 2 +- maps/areainsights/apiv1/doc.go | 2 +- maps/areainsights/apiv1/helpers.go | 2 +- maps/fleetengine/apiv1/auxiliary.go | 2 +- maps/fleetengine/apiv1/auxiliary_go123.go | 2 +- maps/fleetengine/apiv1/doc.go | 2 +- maps/fleetengine/apiv1/helpers.go | 2 +- maps/fleetengine/apiv1/trip_client.go | 2 +- .../apiv1/trip_client_example_go123_test.go | 2 +- .../apiv1/trip_client_example_test.go | 2 +- maps/fleetengine/apiv1/vehicle_client.go | 2 +- .../vehicle_client_example_go123_test.go | 2 +- .../apiv1/vehicle_client_example_test.go | 2 +- maps/fleetengine/delivery/apiv1/auxiliary.go | 2 +- .../delivery/apiv1/auxiliary_go123.go | 2 +- .../delivery/apiv1/delivery_client.go | 2 +- .../delivery_client_example_go123_test.go | 2 +- .../apiv1/delivery_client_example_test.go | 2 +- maps/fleetengine/delivery/apiv1/doc.go | 2 +- maps/fleetengine/delivery/apiv1/helpers.go | 2 +- maps/places/apiv1/auxiliary.go | 2 +- maps/places/apiv1/auxiliary_go123.go | 2 +- maps/places/apiv1/doc.go | 2 +- maps/places/apiv1/helpers.go | 2 +- maps/places/apiv1/places_client.go | 2 +- .../apiv1/places_client_example_go123_test.go | 2 +- .../apiv1/places_client_example_test.go | 2 +- maps/routeoptimization/apiv1/auxiliary.go | 2 +- .../apiv1/auxiliary_go123.go | 2 +- maps/routeoptimization/apiv1/doc.go | 2 +- maps/routeoptimization/apiv1/helpers.go | 2 +- .../apiv1/route_optimization_client.go | 2 +- ..._optimization_client_example_go123_test.go | 2 +- .../route_optimization_client_example_test.go | 2 +- maps/routing/apiv2/auxiliary.go | 2 +- maps/routing/apiv2/auxiliary_go123.go | 2 +- maps/routing/apiv2/doc.go | 2 +- maps/routing/apiv2/helpers.go | 2 +- maps/routing/apiv2/routes_client.go | 2 +- .../apiv2/routes_client_example_go123_test.go | 2 +- .../apiv2/routes_client_example_test.go | 2 +- maps/solar/apiv1/auxiliary.go | 2 +- maps/solar/apiv1/auxiliary_go123.go | 2 +- maps/solar/apiv1/doc.go | 2 +- maps/solar/apiv1/helpers.go | 2 +- maps/solar/apiv1/solar_client.go | 2 +- .../apiv1/solar_client_example_go123_test.go | 2 +- maps/solar/apiv1/solar_client_example_test.go | 2 +- mediatranslation/apiv1beta1/auxiliary.go | 2 +- .../apiv1beta1/auxiliary_go123.go | 2 +- mediatranslation/apiv1beta1/doc.go | 2 +- mediatranslation/apiv1beta1/helpers.go | 2 +- .../apiv1beta1/speech_translation_client.go | 2 +- ...h_translation_client_example_go123_test.go | 2 +- .../speech_translation_client_example_test.go | 2 +- memcache/apiv1/auxiliary.go | 2 +- memcache/apiv1/auxiliary_go123.go | 2 +- memcache/apiv1/cloud_memcache_client.go | 2 +- ...loud_memcache_client_example_go123_test.go | 2 +- .../cloud_memcache_client_example_test.go | 2 +- memcache/apiv1/doc.go | 2 +- memcache/apiv1/helpers.go | 2 +- memcache/apiv1beta2/auxiliary.go | 2 +- memcache/apiv1beta2/auxiliary_go123.go | 2 +- memcache/apiv1beta2/cloud_memcache_client.go | 2 +- ...loud_memcache_client_example_go123_test.go | 2 +- .../cloud_memcache_client_example_test.go | 2 +- memcache/apiv1beta2/doc.go | 2 +- memcache/apiv1beta2/helpers.go | 2 +- memorystore/apiv1/auxiliary.go | 2 +- memorystore/apiv1/auxiliary_go123.go | 2 +- memorystore/apiv1/doc.go | 2 +- memorystore/apiv1/helpers.go | 2 +- memorystore/apiv1/memorystore_client.go | 2 +- .../memorystore_client_example_go123_test.go | 2 +- .../apiv1/memorystore_client_example_test.go | 2 +- memorystore/apiv1beta/auxiliary.go | 2 +- memorystore/apiv1beta/auxiliary_go123.go | 2 +- memorystore/apiv1beta/doc.go | 2 +- memorystore/apiv1beta/helpers.go | 2 +- memorystore/apiv1beta/memorystore_client.go | 2 +- .../memorystore_client_example_go123_test.go | 2 +- .../memorystore_client_example_test.go | 2 +- metastore/apiv1/auxiliary.go | 2 +- metastore/apiv1/auxiliary_go123.go | 2 +- metastore/apiv1/dataproc_metastore_client.go | 2 +- ...roc_metastore_client_example_go123_test.go | 2 +- .../dataproc_metastore_client_example_test.go | 2 +- .../dataproc_metastore_federation_client.go | 2 +- ...re_federation_client_example_go123_test.go | 2 +- ...etastore_federation_client_example_test.go | 2 +- metastore/apiv1/doc.go | 2 +- metastore/apiv1/helpers.go | 2 +- metastore/apiv1alpha/auxiliary.go | 2 +- metastore/apiv1alpha/auxiliary_go123.go | 2 +- .../apiv1alpha/dataproc_metastore_client.go | 2 +- ...roc_metastore_client_example_go123_test.go | 2 +- .../dataproc_metastore_client_example_test.go | 2 +- .../dataproc_metastore_federation_client.go | 2 +- ...re_federation_client_example_go123_test.go | 2 +- ...etastore_federation_client_example_test.go | 2 +- metastore/apiv1alpha/doc.go | 2 +- metastore/apiv1alpha/helpers.go | 2 +- metastore/apiv1beta/auxiliary.go | 2 +- metastore/apiv1beta/auxiliary_go123.go | 2 +- .../apiv1beta/dataproc_metastore_client.go | 2 +- ...roc_metastore_client_example_go123_test.go | 2 +- .../dataproc_metastore_client_example_test.go | 2 +- .../dataproc_metastore_federation_client.go | 2 +- ...re_federation_client_example_go123_test.go | 2 +- ...etastore_federation_client_example_test.go | 2 +- metastore/apiv1beta/doc.go | 2 +- metastore/apiv1beta/helpers.go | 2 +- migrationcenter/apiv1/auxiliary.go | 2 +- migrationcenter/apiv1/auxiliary_go123.go | 2 +- migrationcenter/apiv1/doc.go | 2 +- migrationcenter/apiv1/helpers.go | 2 +- .../apiv1/migration_center_client.go | 2 +- ...ration_center_client_example_go123_test.go | 2 +- .../migration_center_client_example_test.go | 2 +- monitoring/apiv3/v2/alert_policy_client.go | 2 +- .../alert_policy_client_example_go123_test.go | 2 +- .../v2/alert_policy_client_example_test.go | 2 +- monitoring/apiv3/v2/auxiliary.go | 2 +- monitoring/apiv3/v2/auxiliary_go123.go | 2 +- monitoring/apiv3/v2/doc.go | 2 +- monitoring/apiv3/v2/group_client.go | 2 +- .../v2/group_client_example_go123_test.go | 2 +- .../apiv3/v2/group_client_example_test.go | 2 +- monitoring/apiv3/v2/helpers.go | 2 +- monitoring/apiv3/v2/metric_client.go | 2 +- .../v2/metric_client_example_go123_test.go | 2 +- .../apiv3/v2/metric_client_example_test.go | 2 +- .../apiv3/v2/notification_channel_client.go | 2 +- ...ation_channel_client_example_go123_test.go | 2 +- ...otification_channel_client_example_test.go | 2 +- monitoring/apiv3/v2/query_client.go | 2 +- .../v2/query_client_example_go123_test.go | 2 +- .../apiv3/v2/query_client_example_test.go | 2 +- .../apiv3/v2/service_monitoring_client.go | 2 +- ...ce_monitoring_client_example_go123_test.go | 2 +- .../service_monitoring_client_example_test.go | 2 +- monitoring/apiv3/v2/snooze_client.go | 2 +- .../v2/snooze_client_example_go123_test.go | 2 +- .../apiv3/v2/snooze_client_example_test.go | 2 +- monitoring/apiv3/v2/uptime_check_client.go | 2 +- .../uptime_check_client_example_go123_test.go | 2 +- .../v2/uptime_check_client_example_test.go | 2 +- monitoring/dashboard/apiv1/auxiliary.go | 2 +- monitoring/dashboard/apiv1/auxiliary_go123.go | 2 +- .../dashboard/apiv1/dashboards_client.go | 2 +- .../dashboards_client_example_go123_test.go | 2 +- .../apiv1/dashboards_client_example_test.go | 2 +- monitoring/dashboard/apiv1/doc.go | 2 +- monitoring/dashboard/apiv1/helpers.go | 2 +- monitoring/metricsscope/apiv1/auxiliary.go | 2 +- .../metricsscope/apiv1/auxiliary_go123.go | 2 +- monitoring/metricsscope/apiv1/doc.go | 2 +- monitoring/metricsscope/apiv1/helpers.go | 2 +- .../apiv1/metrics_scopes_client.go | 2 +- ...etrics_scopes_client_example_go123_test.go | 2 +- .../metrics_scopes_client_example_test.go | 2 +- netapp/apiv1/auxiliary.go | 2 +- netapp/apiv1/auxiliary_go123.go | 2 +- netapp/apiv1/doc.go | 2 +- netapp/apiv1/helpers.go | 2 +- netapp/apiv1/net_app_client.go | 2 +- .../net_app_client_example_go123_test.go | 2 +- netapp/apiv1/net_app_client_example_test.go | 2 +- networkconnectivity/apiv1/auxiliary.go | 2 +- networkconnectivity/apiv1/auxiliary_go123.go | 2 +- networkconnectivity/apiv1/doc.go | 2 +- networkconnectivity/apiv1/helpers.go | 2 +- networkconnectivity/apiv1/hub_client.go | 2 +- .../apiv1/hub_client_example_go123_test.go | 2 +- .../apiv1/hub_client_example_test.go | 2 +- .../apiv1/policy_based_routing_client.go | 2 +- ...based_routing_client_example_go123_test.go | 2 +- ...olicy_based_routing_client_example_test.go | 2 +- networkconnectivity/apiv1alpha1/auxiliary.go | 2 +- .../apiv1alpha1/auxiliary_go123.go | 2 +- networkconnectivity/apiv1alpha1/doc.go | 2 +- networkconnectivity/apiv1alpha1/helpers.go | 2 +- networkconnectivity/apiv1alpha1/hub_client.go | 2 +- .../hub_client_example_go123_test.go | 2 +- .../apiv1alpha1/hub_client_example_test.go | 2 +- networkmanagement/apiv1/auxiliary.go | 2 +- networkmanagement/apiv1/auxiliary_go123.go | 2 +- networkmanagement/apiv1/doc.go | 2 +- networkmanagement/apiv1/helpers.go | 2 +- .../apiv1/reachability_client.go | 2 +- .../reachability_client_example_go123_test.go | 2 +- .../apiv1/reachability_client_example_test.go | 2 +- networksecurity/apiv1beta1/auxiliary.go | 2 +- networksecurity/apiv1beta1/auxiliary_go123.go | 2 +- networksecurity/apiv1beta1/doc.go | 2 +- networksecurity/apiv1beta1/helpers.go | 2 +- .../apiv1beta1/network_security_client.go | 2 +- ...work_security_client_example_go123_test.go | 2 +- .../network_security_client_example_test.go | 2 +- networkservices/apiv1/auxiliary.go | 2 +- networkservices/apiv1/auxiliary_go123.go | 2 +- networkservices/apiv1/dep_client.go | 2 +- .../apiv1/dep_client_example_go123_test.go | 2 +- .../apiv1/dep_client_example_test.go | 2 +- networkservices/apiv1/doc.go | 2 +- networkservices/apiv1/helpers.go | 2 +- .../apiv1/network_services_client.go | 2 +- ...work_services_client_example_go123_test.go | 2 +- .../network_services_client_example_test.go | 2 +- notebooks/apiv1/auxiliary.go | 2 +- notebooks/apiv1/auxiliary_go123.go | 2 +- notebooks/apiv1/doc.go | 2 +- notebooks/apiv1/helpers.go | 2 +- notebooks/apiv1/managed_notebook_client.go | 2 +- ...aged_notebook_client_example_go123_test.go | 2 +- .../managed_notebook_client_example_test.go | 2 +- notebooks/apiv1/notebook_client.go | 2 +- .../notebook_client_example_go123_test.go | 2 +- .../apiv1/notebook_client_example_test.go | 2 +- notebooks/apiv1beta1/auxiliary.go | 2 +- notebooks/apiv1beta1/auxiliary_go123.go | 2 +- notebooks/apiv1beta1/doc.go | 2 +- notebooks/apiv1beta1/helpers.go | 2 +- notebooks/apiv1beta1/notebook_client.go | 2 +- .../notebook_client_example_go123_test.go | 2 +- .../notebook_client_example_test.go | 2 +- notebooks/apiv2/auxiliary.go | 2 +- notebooks/apiv2/auxiliary_go123.go | 2 +- notebooks/apiv2/doc.go | 2 +- notebooks/apiv2/helpers.go | 2 +- notebooks/apiv2/notebook_client.go | 2 +- .../notebook_client_example_go123_test.go | 2 +- .../apiv2/notebook_client_example_test.go | 2 +- optimization/apiv1/auxiliary.go | 2 +- optimization/apiv1/auxiliary_go123.go | 2 +- optimization/apiv1/doc.go | 2 +- optimization/apiv1/fleet_routing_client.go | 2 +- ...fleet_routing_client_example_go123_test.go | 2 +- .../fleet_routing_client_example_test.go | 2 +- optimization/apiv1/helpers.go | 2 +- oracledatabase/apiv1/auxiliary.go | 2 +- oracledatabase/apiv1/auxiliary_go123.go | 2 +- oracledatabase/apiv1/doc.go | 2 +- oracledatabase/apiv1/helpers.go | 2 +- .../apiv1/oracle_database_client.go | 2 +- ...acle_database_client_example_go123_test.go | 2 +- .../oracle_database_client_example_test.go | 2 +- .../apiv1/oracledatabasepb/vm_cluster.pb.go | 4 +- .../airflow/service/apiv1/auxiliary.go | 2 +- .../airflow/service/apiv1/auxiliary_go123.go | 2 +- orchestration/airflow/service/apiv1/doc.go | 2 +- .../service/apiv1/environments_client.go | 2 +- .../environments_client_example_go123_test.go | 2 +- .../apiv1/environments_client_example_test.go | 2 +- .../airflow/service/apiv1/helpers.go | 2 +- .../service/apiv1/image_versions_client.go | 2 +- ...mage_versions_client_example_go123_test.go | 2 +- .../image_versions_client_example_test.go | 2 +- orgpolicy/apiv2/auxiliary.go | 2 +- orgpolicy/apiv2/auxiliary_go123.go | 2 +- orgpolicy/apiv2/doc.go | 2 +- orgpolicy/apiv2/helpers.go | 2 +- orgpolicy/apiv2/org_policy_client.go | 2 +- .../org_policy_client_example_go123_test.go | 2 +- .../apiv2/org_policy_client_example_test.go | 2 +- .../apiv1/agent_endpoint_client.go | 2 +- ...gent_endpoint_client_example_go123_test.go | 2 +- .../agent_endpoint_client_example_test.go | 2 +- osconfig/agentendpoint/apiv1/auxiliary.go | 2 +- .../agentendpoint/apiv1/auxiliary_go123.go | 2 +- osconfig/agentendpoint/apiv1/doc.go | 2 +- osconfig/agentendpoint/apiv1/helpers.go | 2 +- .../apiv1beta/agent_endpoint_client.go | 2 +- ...gent_endpoint_client_example_go123_test.go | 2 +- .../agent_endpoint_client_example_test.go | 2 +- osconfig/agentendpoint/apiv1beta/auxiliary.go | 2 +- .../apiv1beta/auxiliary_go123.go | 2 +- osconfig/agentendpoint/apiv1beta/doc.go | 2 +- osconfig/agentendpoint/apiv1beta/helpers.go | 2 +- osconfig/apiv1/auxiliary.go | 2 +- osconfig/apiv1/auxiliary_go123.go | 2 +- osconfig/apiv1/doc.go | 2 +- osconfig/apiv1/helpers.go | 2 +- osconfig/apiv1/os_config_client.go | 2 +- .../os_config_client_example_go123_test.go | 2 +- .../apiv1/os_config_client_example_test.go | 2 +- osconfig/apiv1/os_config_zonal_client.go | 2 +- ..._config_zonal_client_example_go123_test.go | 2 +- .../os_config_zonal_client_example_test.go | 2 +- osconfig/apiv1alpha/auxiliary.go | 2 +- osconfig/apiv1alpha/auxiliary_go123.go | 2 +- osconfig/apiv1alpha/doc.go | 2 +- osconfig/apiv1alpha/helpers.go | 2 +- osconfig/apiv1alpha/os_config_zonal_client.go | 2 +- ..._config_zonal_client_example_go123_test.go | 2 +- .../os_config_zonal_client_example_test.go | 2 +- osconfig/apiv1beta/auxiliary.go | 2 +- osconfig/apiv1beta/auxiliary_go123.go | 2 +- osconfig/apiv1beta/doc.go | 2 +- osconfig/apiv1beta/helpers.go | 2 +- osconfig/apiv1beta/os_config_client.go | 2 +- .../os_config_client_example_go123_test.go | 2 +- .../os_config_client_example_test.go | 2 +- oslogin/apiv1/auxiliary.go | 2 +- oslogin/apiv1/auxiliary_go123.go | 2 +- oslogin/apiv1/doc.go | 2 +- oslogin/apiv1/helpers.go | 2 +- oslogin/apiv1/os_login_client.go | 2 +- .../os_login_client_example_go123_test.go | 2 +- oslogin/apiv1/os_login_client_example_test.go | 2 +- oslogin/apiv1beta/auxiliary.go | 2 +- oslogin/apiv1beta/auxiliary_go123.go | 2 +- oslogin/apiv1beta/doc.go | 2 +- oslogin/apiv1beta/helpers.go | 2 +- oslogin/apiv1beta/os_login_client.go | 2 +- .../os_login_client_example_go123_test.go | 2 +- .../apiv1beta/os_login_client_example_test.go | 2 +- parallelstore/apiv1/auxiliary.go | 2 +- parallelstore/apiv1/auxiliary_go123.go | 2 +- parallelstore/apiv1/doc.go | 2 +- parallelstore/apiv1/helpers.go | 2 +- parallelstore/apiv1/parallelstore_client.go | 2 +- ...parallelstore_client_example_go123_test.go | 2 +- .../parallelstore_client_example_test.go | 2 +- parallelstore/apiv1beta/auxiliary.go | 2 +- parallelstore/apiv1beta/auxiliary_go123.go | 2 +- parallelstore/apiv1beta/doc.go | 2 +- parallelstore/apiv1beta/helpers.go | 2 +- .../apiv1beta/parallelstore_client.go | 2 +- ...parallelstore_client_example_go123_test.go | 2 +- .../parallelstore_client_example_test.go | 2 +- phishingprotection/apiv1beta1/auxiliary.go | 2 +- .../apiv1beta1/auxiliary_go123.go | 2 +- phishingprotection/apiv1beta1/doc.go | 2 +- phishingprotection/apiv1beta1/helpers.go | 2 +- ...hing_protection_service_v1_beta1_client.go | 2 +- ...vice_v1_beta1_client_example_go123_test.go | 2 +- ...on_service_v1_beta1_client_example_test.go | 2 +- policysimulator/apiv1/auxiliary.go | 2 +- policysimulator/apiv1/auxiliary_go123.go | 2 +- policysimulator/apiv1/doc.go | 2 +- policysimulator/apiv1/helpers.go | 2 +- policysimulator/apiv1/simulator_client.go | 2 +- .../simulator_client_example_go123_test.go | 2 +- .../apiv1/simulator_client_example_test.go | 2 +- policytroubleshooter/apiv1/auxiliary.go | 2 +- policytroubleshooter/apiv1/auxiliary_go123.go | 2 +- policytroubleshooter/apiv1/doc.go | 2 +- policytroubleshooter/apiv1/helpers.go | 2 +- .../apiv1/iam_checker_client.go | 2 +- .../iam_checker_client_example_go123_test.go | 2 +- .../apiv1/iam_checker_client_example_test.go | 2 +- policytroubleshooter/iam/apiv3/auxiliary.go | 2 +- .../iam/apiv3/auxiliary_go123.go | 2 +- policytroubleshooter/iam/apiv3/doc.go | 2 +- policytroubleshooter/iam/apiv3/helpers.go | 2 +- .../iam/apiv3/policy_troubleshooter_client.go | 2 +- ...roubleshooter_client_example_go123_test.go | 2 +- ...licy_troubleshooter_client_example_test.go | 2 +- privatecatalog/apiv1beta1/auxiliary.go | 2 +- privatecatalog/apiv1beta1/auxiliary_go123.go | 2 +- privatecatalog/apiv1beta1/doc.go | 2 +- privatecatalog/apiv1beta1/helpers.go | 2 +- .../apiv1beta1/private_catalog_client.go | 2 +- ...ivate_catalog_client_example_go123_test.go | 2 +- .../private_catalog_client_example_test.go | 2 +- privilegedaccessmanager/apiv1/auxiliary.go | 2 +- .../apiv1/auxiliary_go123.go | 2 +- privilegedaccessmanager/apiv1/doc.go | 2 +- privilegedaccessmanager/apiv1/helpers.go | 2 +- .../apiv1/privileged_access_manager_client.go | 2 +- ...ccess_manager_client_example_go123_test.go | 2 +- ...eged_access_manager_client_example_test.go | 2 +- pubsub/apiv1/auxiliary.go | 2 +- pubsub/apiv1/auxiliary_go123.go | 2 +- pubsub/apiv1/doc.go | 2 +- pubsub/apiv1/helpers.go | 2 +- pubsub/apiv1/publisher_client.go | 2 +- .../publisher_client_example_go123_test.go | 2 +- pubsub/apiv1/publisher_client_example_test.go | 2 +- pubsub/apiv1/schema_client.go | 2 +- .../apiv1/schema_client_example_go123_test.go | 2 +- pubsub/apiv1/schema_client_example_test.go | 2 +- pubsub/apiv1/subscriber_client.go | 2 +- .../subscriber_client_example_go123_test.go | 2 +- .../apiv1/subscriber_client_example_test.go | 2 +- pubsublite/apiv1/admin_client.go | 2 +- .../apiv1/admin_client_example_go123_test.go | 2 +- pubsublite/apiv1/admin_client_example_test.go | 2 +- pubsublite/apiv1/auxiliary.go | 2 +- pubsublite/apiv1/auxiliary_go123.go | 2 +- pubsublite/apiv1/cursor_client.go | 2 +- .../apiv1/cursor_client_example_go123_test.go | 2 +- .../apiv1/cursor_client_example_test.go | 2 +- pubsublite/apiv1/doc.go | 2 +- pubsublite/apiv1/helpers.go | 2 +- .../apiv1/partition_assignment_client.go | 2 +- ...on_assignment_client_example_go123_test.go | 2 +- ...artition_assignment_client_example_test.go | 2 +- pubsublite/apiv1/publisher_client.go | 2 +- .../publisher_client_example_go123_test.go | 2 +- .../apiv1/publisher_client_example_test.go | 2 +- pubsublite/apiv1/subscriber_client.go | 2 +- .../subscriber_client_example_go123_test.go | 2 +- .../apiv1/subscriber_client_example_test.go | 2 +- pubsublite/apiv1/topic_stats_client.go | 2 +- .../topic_stats_client_example_go123_test.go | 2 +- .../apiv1/topic_stats_client_example_test.go | 2 +- rapidmigrationassessment/apiv1/auxiliary.go | 2 +- .../apiv1/auxiliary_go123.go | 2 +- rapidmigrationassessment/apiv1/doc.go | 2 +- rapidmigrationassessment/apiv1/helpers.go | 2 +- .../rapid_migration_assessment_client.go | 2 +- ...on_assessment_client_example_go123_test.go | 2 +- ...igration_assessment_client_example_test.go | 2 +- recaptchaenterprise/apiv1/auxiliary.go | 2 +- recaptchaenterprise/apiv1/auxiliary_go123.go | 2 +- recaptchaenterprise/apiv1/doc.go | 2 +- recaptchaenterprise/apiv1/helpers.go | 2 +- .../apiv1/recaptcha_enterprise_client.go | 2 +- ...ha_enterprise_client_example_go123_test.go | 2 +- ...ecaptcha_enterprise_client_example_test.go | 2 +- recaptchaenterprise/apiv1beta1/auxiliary.go | 2 +- .../apiv1beta1/auxiliary_go123.go | 2 +- recaptchaenterprise/apiv1beta1/doc.go | 2 +- recaptchaenterprise/apiv1beta1/helpers.go | 2 +- ...tcha_enterprise_service_v1_beta1_client.go | 2 +- ...vice_v1_beta1_client_example_go123_test.go | 2 +- ...se_service_v1_beta1_client_example_test.go | 2 +- recommendationengine/apiv1beta1/auxiliary.go | 2 +- .../apiv1beta1/auxiliary_go123.go | 2 +- .../apiv1beta1/catalog_client.go | 2 +- .../catalog_client_example_go123_test.go | 2 +- .../apiv1beta1/catalog_client_example_test.go | 2 +- recommendationengine/apiv1beta1/doc.go | 2 +- recommendationengine/apiv1beta1/helpers.go | 2 +- .../prediction_api_key_registry_client.go | 2 +- ..._key_registry_client_example_go123_test.go | 2 +- ...on_api_key_registry_client_example_test.go | 2 +- .../apiv1beta1/prediction_client.go | 2 +- .../prediction_client_example_go123_test.go | 2 +- .../prediction_client_example_test.go | 2 +- .../apiv1beta1/user_event_client.go | 2 +- .../user_event_client_example_go123_test.go | 2 +- .../user_event_client_example_test.go | 2 +- recommender/apiv1/auxiliary.go | 2 +- recommender/apiv1/auxiliary_go123.go | 2 +- recommender/apiv1/doc.go | 2 +- recommender/apiv1/helpers.go | 2 +- recommender/apiv1/recommender_client.go | 2 +- .../recommender_client_example_go123_test.go | 2 +- .../apiv1/recommender_client_example_test.go | 2 +- recommender/apiv1beta1/auxiliary.go | 2 +- recommender/apiv1beta1/auxiliary_go123.go | 2 +- recommender/apiv1beta1/doc.go | 2 +- recommender/apiv1beta1/helpers.go | 2 +- recommender/apiv1beta1/recommender_client.go | 2 +- .../recommender_client_example_go123_test.go | 2 +- .../recommender_client_example_test.go | 2 +- redis/apiv1/auxiliary.go | 2 +- redis/apiv1/auxiliary_go123.go | 2 +- redis/apiv1/cloud_redis_client.go | 2 +- .../cloud_redis_client_example_go123_test.go | 2 +- .../apiv1/cloud_redis_client_example_test.go | 2 +- redis/apiv1/doc.go | 2 +- redis/apiv1/helpers.go | 2 +- redis/apiv1beta1/auxiliary.go | 2 +- redis/apiv1beta1/auxiliary_go123.go | 2 +- redis/apiv1beta1/cloud_redis_client.go | 2 +- .../cloud_redis_client_example_go123_test.go | 2 +- .../cloud_redis_client_example_test.go | 2 +- redis/apiv1beta1/doc.go | 2 +- redis/apiv1beta1/helpers.go | 2 +- redis/cluster/apiv1/auxiliary.go | 2 +- redis/cluster/apiv1/auxiliary_go123.go | 2 +- .../apiv1/cloud_redis_cluster_client.go | 2 +- ...redis_cluster_client_example_go123_test.go | 2 +- ...cloud_redis_cluster_client_example_test.go | 2 +- redis/cluster/apiv1/doc.go | 2 +- redis/cluster/apiv1/helpers.go | 2 +- resourcemanager/apiv2/auxiliary.go | 2 +- resourcemanager/apiv2/auxiliary_go123.go | 2 +- resourcemanager/apiv2/doc.go | 2 +- resourcemanager/apiv2/folders_client.go | 2 +- .../folders_client_example_go123_test.go | 2 +- .../apiv2/folders_client_example_test.go | 2 +- resourcemanager/apiv2/helpers.go | 2 +- resourcemanager/apiv3/auxiliary.go | 2 +- resourcemanager/apiv3/auxiliary_go123.go | 2 +- resourcemanager/apiv3/doc.go | 2 +- resourcemanager/apiv3/folders_client.go | 2 +- .../folders_client_example_go123_test.go | 2 +- .../apiv3/folders_client_example_test.go | 2 +- resourcemanager/apiv3/helpers.go | 2 +- resourcemanager/apiv3/organizations_client.go | 2 +- ...organizations_client_example_go123_test.go | 2 +- .../organizations_client_example_test.go | 2 +- resourcemanager/apiv3/projects_client.go | 2 +- .../projects_client_example_go123_test.go | 2 +- .../apiv3/projects_client_example_test.go | 2 +- resourcemanager/apiv3/tag_bindings_client.go | 2 +- .../tag_bindings_client_example_go123_test.go | 2 +- .../apiv3/tag_bindings_client_example_test.go | 2 +- resourcemanager/apiv3/tag_holds_client.go | 2 +- .../tag_holds_client_example_go123_test.go | 2 +- .../apiv3/tag_holds_client_example_test.go | 2 +- resourcemanager/apiv3/tag_keys_client.go | 2 +- .../tag_keys_client_example_go123_test.go | 2 +- .../apiv3/tag_keys_client_example_test.go | 2 +- resourcemanager/apiv3/tag_values_client.go | 2 +- .../tag_values_client_example_go123_test.go | 2 +- .../apiv3/tag_values_client_example_test.go | 2 +- resourcesettings/apiv1/auxiliary.go | 2 +- resourcesettings/apiv1/auxiliary_go123.go | 2 +- resourcesettings/apiv1/doc.go | 2 +- resourcesettings/apiv1/helpers.go | 2 +- .../apiv1/resource_settings_client.go | 2 +- ...urce_settings_client_example_go123_test.go | 2 +- .../resource_settings_client_example_test.go | 2 +- retail/apiv2/analytics_client.go | 2 +- .../analytics_client_example_go123_test.go | 2 +- retail/apiv2/analytics_client_example_test.go | 2 +- retail/apiv2/auxiliary.go | 2 +- retail/apiv2/auxiliary_go123.go | 2 +- retail/apiv2/catalog_client.go | 2 +- .../catalog_client_example_go123_test.go | 2 +- retail/apiv2/catalog_client_example_test.go | 2 +- retail/apiv2/completion_client.go | 2 +- .../completion_client_example_go123_test.go | 2 +- .../apiv2/completion_client_example_test.go | 2 +- retail/apiv2/control_client.go | 2 +- .../control_client_example_go123_test.go | 2 +- retail/apiv2/control_client_example_test.go | 2 +- retail/apiv2/doc.go | 2 +- retail/apiv2/generative_question_client.go | 2 +- ...tive_question_client_example_go123_test.go | 2 +- ...generative_question_client_example_test.go | 2 +- retail/apiv2/helpers.go | 2 +- retail/apiv2/model_client.go | 2 +- .../apiv2/model_client_example_go123_test.go | 2 +- retail/apiv2/model_client_example_test.go | 2 +- retail/apiv2/prediction_client.go | 2 +- .../prediction_client_example_go123_test.go | 2 +- .../apiv2/prediction_client_example_test.go | 2 +- retail/apiv2/product_client.go | 2 +- .../product_client_example_go123_test.go | 2 +- retail/apiv2/product_client_example_test.go | 2 +- retail/apiv2/search_client.go | 2 +- .../apiv2/search_client_example_go123_test.go | 2 +- retail/apiv2/search_client_example_test.go | 2 +- retail/apiv2/serving_config_client.go | 2 +- ...erving_config_client_example_go123_test.go | 2 +- .../serving_config_client_example_test.go | 2 +- retail/apiv2/user_event_client.go | 2 +- .../user_event_client_example_go123_test.go | 2 +- .../apiv2/user_event_client_example_test.go | 2 +- retail/apiv2alpha/analytics_client.go | 2 +- .../analytics_client_example_go123_test.go | 2 +- .../analytics_client_example_test.go | 2 +- retail/apiv2alpha/auxiliary.go | 2 +- retail/apiv2alpha/auxiliary_go123.go | 2 +- retail/apiv2alpha/branch_client.go | 2 +- .../branch_client_example_go123_test.go | 2 +- .../apiv2alpha/branch_client_example_test.go | 2 +- retail/apiv2alpha/catalog_client.go | 2 +- .../catalog_client_example_go123_test.go | 2 +- .../apiv2alpha/catalog_client_example_test.go | 2 +- retail/apiv2alpha/completion_client.go | 2 +- .../completion_client_example_go123_test.go | 2 +- .../completion_client_example_test.go | 2 +- retail/apiv2alpha/control_client.go | 2 +- .../control_client_example_go123_test.go | 2 +- .../apiv2alpha/control_client_example_test.go | 2 +- retail/apiv2alpha/doc.go | 2 +- .../apiv2alpha/generative_question_client.go | 2 +- ...tive_question_client_example_go123_test.go | 2 +- ...generative_question_client_example_test.go | 2 +- retail/apiv2alpha/helpers.go | 2 +- .../merchant_center_account_link_client.go | 2 +- ..._account_link_client_example_go123_test.go | 2 +- ...center_account_link_client_example_test.go | 2 +- retail/apiv2alpha/model_client.go | 2 +- .../model_client_example_go123_test.go | 2 +- .../apiv2alpha/model_client_example_test.go | 2 +- retail/apiv2alpha/prediction_client.go | 2 +- .../prediction_client_example_go123_test.go | 2 +- .../prediction_client_example_test.go | 2 +- retail/apiv2alpha/product_client.go | 2 +- .../product_client_example_go123_test.go | 2 +- .../apiv2alpha/product_client_example_test.go | 2 +- retail/apiv2alpha/project_client.go | 2 +- .../project_client_example_go123_test.go | 2 +- .../apiv2alpha/project_client_example_test.go | 2 +- retail/apiv2alpha/search_client.go | 2 +- .../search_client_example_go123_test.go | 2 +- .../apiv2alpha/search_client_example_test.go | 2 +- retail/apiv2alpha/serving_config_client.go | 2 +- ...erving_config_client_example_go123_test.go | 2 +- .../serving_config_client_example_test.go | 2 +- retail/apiv2alpha/user_event_client.go | 2 +- .../user_event_client_example_go123_test.go | 2 +- .../user_event_client_example_test.go | 2 +- retail/apiv2beta/analytics_client.go | 2 +- .../analytics_client_example_go123_test.go | 2 +- .../analytics_client_example_test.go | 2 +- retail/apiv2beta/auxiliary.go | 2 +- retail/apiv2beta/auxiliary_go123.go | 2 +- retail/apiv2beta/catalog_client.go | 2 +- .../catalog_client_example_go123_test.go | 2 +- .../apiv2beta/catalog_client_example_test.go | 2 +- retail/apiv2beta/completion_client.go | 2 +- .../completion_client_example_go123_test.go | 2 +- .../completion_client_example_test.go | 2 +- retail/apiv2beta/control_client.go | 2 +- .../control_client_example_go123_test.go | 2 +- .../apiv2beta/control_client_example_test.go | 2 +- retail/apiv2beta/doc.go | 2 +- .../apiv2beta/generative_question_client.go | 2 +- ...tive_question_client_example_go123_test.go | 2 +- ...generative_question_client_example_test.go | 2 +- retail/apiv2beta/helpers.go | 2 +- retail/apiv2beta/model_client.go | 2 +- .../model_client_example_go123_test.go | 2 +- retail/apiv2beta/model_client_example_test.go | 2 +- retail/apiv2beta/prediction_client.go | 2 +- .../prediction_client_example_go123_test.go | 2 +- .../prediction_client_example_test.go | 2 +- retail/apiv2beta/product_client.go | 2 +- .../product_client_example_go123_test.go | 2 +- .../apiv2beta/product_client_example_test.go | 2 +- retail/apiv2beta/project_client.go | 2 +- .../project_client_example_go123_test.go | 2 +- .../apiv2beta/project_client_example_test.go | 2 +- retail/apiv2beta/search_client.go | 2 +- .../search_client_example_go123_test.go | 2 +- .../apiv2beta/search_client_example_test.go | 2 +- retail/apiv2beta/serving_config_client.go | 2 +- ...erving_config_client_example_go123_test.go | 2 +- .../serving_config_client_example_test.go | 2 +- retail/apiv2beta/user_event_client.go | 2 +- .../user_event_client_example_go123_test.go | 2 +- .../user_event_client_example_test.go | 2 +- run/apiv2/auxiliary.go | 2 +- run/apiv2/auxiliary_go123.go | 2 +- run/apiv2/builds_client.go | 2 +- run/apiv2/builds_client_example_go123_test.go | 2 +- run/apiv2/builds_client_example_test.go | 2 +- run/apiv2/doc.go | 2 +- run/apiv2/executions_client.go | 2 +- .../executions_client_example_go123_test.go | 2 +- run/apiv2/executions_client_example_test.go | 2 +- run/apiv2/helpers.go | 2 +- run/apiv2/jobs_client.go | 2 +- run/apiv2/jobs_client_example_go123_test.go | 2 +- run/apiv2/jobs_client_example_test.go | 2 +- run/apiv2/revisions_client.go | 2 +- .../revisions_client_example_go123_test.go | 2 +- run/apiv2/revisions_client_example_test.go | 2 +- run/apiv2/services_client.go | 2 +- .../services_client_example_go123_test.go | 2 +- run/apiv2/services_client_example_test.go | 2 +- run/apiv2/tasks_client.go | 2 +- run/apiv2/tasks_client_example_go123_test.go | 2 +- run/apiv2/tasks_client_example_test.go | 2 +- scheduler/apiv1/auxiliary.go | 2 +- scheduler/apiv1/auxiliary_go123.go | 2 +- scheduler/apiv1/cloud_scheduler_client.go | 2 +- ...oud_scheduler_client_example_go123_test.go | 2 +- .../cloud_scheduler_client_example_test.go | 2 +- scheduler/apiv1/doc.go | 2 +- scheduler/apiv1/helpers.go | 2 +- scheduler/apiv1beta1/auxiliary.go | 2 +- scheduler/apiv1beta1/auxiliary_go123.go | 2 +- .../apiv1beta1/cloud_scheduler_client.go | 2 +- ...oud_scheduler_client_example_go123_test.go | 2 +- .../cloud_scheduler_client_example_test.go | 2 +- scheduler/apiv1beta1/doc.go | 2 +- scheduler/apiv1beta1/helpers.go | 2 +- secretmanager/apiv1/auxiliary.go | 2 +- secretmanager/apiv1/auxiliary_go123.go | 2 +- secretmanager/apiv1/doc.go | 2 +- secretmanager/apiv1/helpers.go | 2 +- secretmanager/apiv1/secret_manager_client.go | 2 +- ...ecret_manager_client_example_go123_test.go | 2 +- .../secret_manager_client_example_test.go | 2 +- secretmanager/apiv1beta2/auxiliary.go | 2 +- secretmanager/apiv1beta2/auxiliary_go123.go | 2 +- secretmanager/apiv1beta2/doc.go | 2 +- secretmanager/apiv1beta2/helpers.go | 2 +- .../apiv1beta2/secret_manager_client.go | 2 +- ...ecret_manager_client_example_go123_test.go | 2 +- .../secret_manager_client_example_test.go | 2 +- securesourcemanager/apiv1/auxiliary.go | 2 +- securesourcemanager/apiv1/auxiliary_go123.go | 2 +- securesourcemanager/apiv1/doc.go | 2 +- securesourcemanager/apiv1/helpers.go | 2 +- .../apiv1/secure_source_manager_client.go | 2 +- ...ource_manager_client_example_go123_test.go | 2 +- ...cure_source_manager_client_example_test.go | 2 +- security/privateca/apiv1/auxiliary.go | 2 +- security/privateca/apiv1/auxiliary_go123.go | 2 +- .../apiv1/certificate_authority_client.go | 2 +- ...ate_authority_client_example_go123_test.go | 2 +- ...rtificate_authority_client_example_test.go | 2 +- security/privateca/apiv1/doc.go | 2 +- security/privateca/apiv1/helpers.go | 2 +- security/publicca/apiv1/auxiliary.go | 2 +- security/publicca/apiv1/auxiliary_go123.go | 2 +- security/publicca/apiv1/doc.go | 2 +- security/publicca/apiv1/helpers.go | 2 +- .../public_certificate_authority_client.go | 2 +- ...ate_authority_client_example_go123_test.go | 2 +- ...rtificate_authority_client_example_test.go | 2 +- security/publicca/apiv1beta1/auxiliary.go | 2 +- .../publicca/apiv1beta1/auxiliary_go123.go | 2 +- security/publicca/apiv1beta1/doc.go | 2 +- security/publicca/apiv1beta1/helpers.go | 2 +- .../public_certificate_authority_client.go | 2 +- ...ate_authority_client_example_go123_test.go | 2 +- ...rtificate_authority_client_example_test.go | 2 +- securitycenter/apiv1/auxiliary.go | 2 +- securitycenter/apiv1/auxiliary_go123.go | 2 +- securitycenter/apiv1/doc.go | 2 +- securitycenter/apiv1/helpers.go | 2 +- .../apiv1/security_center_client.go | 2 +- ...curity_center_client_example_go123_test.go | 2 +- .../security_center_client_example_test.go | 2 +- securitycenter/apiv1beta1/auxiliary.go | 2 +- securitycenter/apiv1beta1/auxiliary_go123.go | 2 +- securitycenter/apiv1beta1/doc.go | 2 +- securitycenter/apiv1beta1/helpers.go | 2 +- .../apiv1beta1/security_center_client.go | 2 +- ...curity_center_client_example_go123_test.go | 2 +- .../security_center_client_example_test.go | 2 +- securitycenter/apiv1p1beta1/auxiliary.go | 2 +- .../apiv1p1beta1/auxiliary_go123.go | 2 +- securitycenter/apiv1p1beta1/doc.go | 2 +- securitycenter/apiv1p1beta1/helpers.go | 2 +- .../apiv1p1beta1/security_center_client.go | 2 +- ...curity_center_client_example_go123_test.go | 2 +- .../security_center_client_example_test.go | 2 +- securitycenter/apiv2/auxiliary.go | 2 +- securitycenter/apiv2/auxiliary_go123.go | 2 +- securitycenter/apiv2/doc.go | 2 +- securitycenter/apiv2/helpers.go | 2 +- .../apiv2/security_center_client.go | 2 +- ...curity_center_client_example_go123_test.go | 2 +- .../security_center_client_example_test.go | 2 +- .../settings/apiv1beta1/auxiliary.go | 2 +- .../settings/apiv1beta1/auxiliary_go123.go | 2 +- securitycenter/settings/apiv1beta1/doc.go | 2 +- securitycenter/settings/apiv1beta1/helpers.go | 2 +- .../security_center_settings_client.go | 2 +- ...nter_settings_client_example_go123_test.go | 2 +- ...ity_center_settings_client_example_test.go | 2 +- securitycentermanagement/apiv1/auxiliary.go | 2 +- .../apiv1/auxiliary_go123.go | 2 +- securitycentermanagement/apiv1/doc.go | 2 +- securitycentermanagement/apiv1/helpers.go | 2 +- .../security_center_management_client.go | 2 +- ...er_management_client_example_go123_test.go | 2 +- ...y_center_management_client_example_test.go | 2 +- securityposture/apiv1/auxiliary.go | 2 +- securityposture/apiv1/auxiliary_go123.go | 2 +- securityposture/apiv1/doc.go | 2 +- securityposture/apiv1/helpers.go | 2 +- .../apiv1/security_posture_client.go | 2 +- ...urity_posture_client_example_go123_test.go | 2 +- .../security_posture_client_example_test.go | 2 +- servicecontrol/apiv1/auxiliary.go | 2 +- servicecontrol/apiv1/auxiliary_go123.go | 2 +- servicecontrol/apiv1/doc.go | 2 +- servicecontrol/apiv1/helpers.go | 2 +- .../apiv1/quota_controller_client.go | 2 +- ...ta_controller_client_example_go123_test.go | 2 +- .../quota_controller_client_example_test.go | 2 +- .../apiv1/service_controller_client.go | 2 +- ...ce_controller_client_example_go123_test.go | 2 +- .../service_controller_client_example_test.go | 2 +- servicedirectory/apiv1/auxiliary.go | 2 +- servicedirectory/apiv1/auxiliary_go123.go | 2 +- servicedirectory/apiv1/doc.go | 2 +- servicedirectory/apiv1/helpers.go | 2 +- servicedirectory/apiv1/lookup_client.go | 2 +- .../apiv1/lookup_client_example_go123_test.go | 2 +- .../apiv1/lookup_client_example_test.go | 2 +- servicedirectory/apiv1/registration_client.go | 2 +- .../registration_client_example_go123_test.go | 2 +- .../apiv1/registration_client_example_test.go | 2 +- servicedirectory/apiv1beta1/auxiliary.go | 2 +- .../apiv1beta1/auxiliary_go123.go | 2 +- servicedirectory/apiv1beta1/doc.go | 2 +- servicedirectory/apiv1beta1/helpers.go | 2 +- servicedirectory/apiv1beta1/lookup_client.go | 2 +- .../lookup_client_example_go123_test.go | 2 +- .../apiv1beta1/lookup_client_example_test.go | 2 +- .../apiv1beta1/registration_client.go | 2 +- .../registration_client_example_go123_test.go | 2 +- .../registration_client_example_test.go | 2 +- servicehealth/apiv1/auxiliary.go | 2 +- servicehealth/apiv1/auxiliary_go123.go | 2 +- servicehealth/apiv1/doc.go | 2 +- servicehealth/apiv1/helpers.go | 2 +- servicehealth/apiv1/service_health_client.go | 2 +- ...ervice_health_client_example_go123_test.go | 2 +- .../service_health_client_example_test.go | 2 +- servicemanagement/apiv1/auxiliary.go | 2 +- servicemanagement/apiv1/auxiliary_go123.go | 2 +- servicemanagement/apiv1/doc.go | 2 +- servicemanagement/apiv1/helpers.go | 2 +- .../apiv1/service_manager_client.go | 2 +- ...rvice_manager_client_example_go123_test.go | 2 +- .../service_manager_client_example_test.go | 2 +- serviceusage/apiv1/auxiliary.go | 2 +- serviceusage/apiv1/auxiliary_go123.go | 2 +- serviceusage/apiv1/doc.go | 2 +- serviceusage/apiv1/helpers.go | 2 +- serviceusage/apiv1/service_usage_client.go | 2 +- ...service_usage_client_example_go123_test.go | 2 +- .../service_usage_client_example_test.go | 2 +- shell/apiv1/auxiliary.go | 2 +- shell/apiv1/auxiliary_go123.go | 2 +- shell/apiv1/cloud_shell_client.go | 2 +- .../cloud_shell_client_example_go123_test.go | 2 +- .../apiv1/cloud_shell_client_example_test.go | 2 +- shell/apiv1/doc.go | 2 +- shell/apiv1/helpers.go | 2 +- shopping/css/apiv1/account_labels_client.go | 2 +- ...ccount_labels_client_example_go123_test.go | 2 +- .../account_labels_client_example_test.go | 2 +- shopping/css/apiv1/accounts_client.go | 2 +- .../accounts_client_example_go123_test.go | 2 +- .../css/apiv1/accounts_client_example_test.go | 2 +- shopping/css/apiv1/auxiliary.go | 2 +- shopping/css/apiv1/auxiliary_go123.go | 2 +- .../css/apiv1/css_product_inputs_client.go | 2 +- ...roduct_inputs_client_example_go123_test.go | 2 +- .../css_product_inputs_client_example_test.go | 2 +- shopping/css/apiv1/css_products_client.go | 2 +- .../css_products_client_example_go123_test.go | 2 +- .../apiv1/css_products_client_example_test.go | 2 +- shopping/css/apiv1/doc.go | 2 +- shopping/css/apiv1/helpers.go | 2 +- .../apiv1beta/account_issue_client.go | 2 +- ...account_issue_client_example_go123_test.go | 2 +- .../account_issue_client_example_test.go | 2 +- .../accounts/apiv1beta/account_tax_client.go | 2 +- .../account_tax_client_example_go123_test.go | 2 +- .../account_tax_client_example_test.go | 2 +- .../accounts/apiv1beta/accounts_client.go | 2 +- .../accounts_client_example_go123_test.go | 2 +- .../apiv1beta/accounts_client_example_test.go | 2 +- .../apiv1beta/autofeed_settings_client.go | 2 +- ...feed_settings_client_example_go123_test.go | 2 +- .../autofeed_settings_client_example_test.go | 2 +- .../merchant/accounts/apiv1beta/auxiliary.go | 2 +- .../accounts/apiv1beta/auxiliary_go123.go | 2 +- .../apiv1beta/business_identity_client.go | 2 +- ...ness_identity_client_example_go123_test.go | 2 +- .../business_identity_client_example_test.go | 2 +- .../apiv1beta/business_info_client.go | 2 +- ...business_info_client_example_go123_test.go | 2 +- .../business_info_client_example_test.go | 2 +- shopping/merchant/accounts/apiv1beta/doc.go | 2 +- .../apiv1beta/email_preferences_client.go | 2 +- ...l_preferences_client_example_go123_test.go | 2 +- .../email_preferences_client_example_test.go | 2 +- .../merchant/accounts/apiv1beta/helpers.go | 2 +- .../accounts/apiv1beta/homepage_client.go | 2 +- .../homepage_client_example_go123_test.go | 2 +- .../apiv1beta/homepage_client_example_test.go | 2 +- .../apiv1beta/online_return_policy_client.go | 2 +- ...return_policy_client_example_go123_test.go | 2 +- ...nline_return_policy_client_example_test.go | 2 +- .../accounts/apiv1beta/programs_client.go | 2 +- .../programs_client_example_go123_test.go | 2 +- .../apiv1beta/programs_client_example_test.go | 2 +- .../accounts/apiv1beta/regions_client.go | 2 +- .../regions_client_example_go123_test.go | 2 +- .../apiv1beta/regions_client_example_test.go | 2 +- .../apiv1beta/shipping_settings_client.go | 2 +- ...ping_settings_client_example_go123_test.go | 2 +- .../shipping_settings_client_example_test.go | 2 +- ...terms_of_service_agreement_state_client.go | 2 +- ...reement_state_client_example_go123_test.go | 2 +- ...ice_agreement_state_client_example_test.go | 2 +- .../apiv1beta/terms_of_service_client.go | 2 +- ...ms_of_service_client_example_go123_test.go | 2 +- .../terms_of_service_client_example_test.go | 2 +- .../accounts/apiv1beta/user_client.go | 2 +- .../user_client_example_go123_test.go | 2 +- .../apiv1beta/user_client_example_test.go | 2 +- .../conversions/apiv1beta/auxiliary.go | 2 +- .../conversions/apiv1beta/auxiliary_go123.go | 2 +- .../apiv1beta/conversion_sources_client.go | 2 +- ...rsion_sources_client_example_go123_test.go | 2 +- .../conversion_sources_client_example_test.go | 2 +- .../merchant/conversions/apiv1beta/doc.go | 2 +- .../merchant/conversions/apiv1beta/helpers.go | 2 +- .../datasources/apiv1beta/auxiliary.go | 2 +- .../datasources/apiv1beta/auxiliary_go123.go | 2 +- .../apiv1beta/data_sources_client.go | 2 +- .../data_sources_client_example_go123_test.go | 2 +- .../data_sources_client_example_test.go | 2 +- .../merchant/datasources/apiv1beta/doc.go | 2 +- .../apiv1beta/file_uploads_client.go | 2 +- .../file_uploads_client_example_go123_test.go | 2 +- .../file_uploads_client_example_test.go | 2 +- .../merchant/datasources/apiv1beta/helpers.go | 2 +- .../inventories/apiv1beta/auxiliary.go | 2 +- .../inventories/apiv1beta/auxiliary_go123.go | 2 +- .../merchant/inventories/apiv1beta/doc.go | 2 +- .../merchant/inventories/apiv1beta/helpers.go | 2 +- .../apiv1beta/local_inventory_client.go | 2 +- ...cal_inventory_client_example_go123_test.go | 2 +- .../local_inventory_client_example_test.go | 2 +- .../apiv1beta/regional_inventory_client.go | 2 +- ...nal_inventory_client_example_go123_test.go | 2 +- .../regional_inventory_client_example_test.go | 2 +- shopping/merchant/lfp/apiv1beta/auxiliary.go | 2 +- .../merchant/lfp/apiv1beta/auxiliary_go123.go | 2 +- shopping/merchant/lfp/apiv1beta/doc.go | 2 +- shopping/merchant/lfp/apiv1beta/helpers.go | 2 +- .../lfp/apiv1beta/lfp_inventory_client.go | 2 +- ...lfp_inventory_client_example_go123_test.go | 2 +- .../lfp_inventory_client_example_test.go | 2 +- .../merchant/lfp/apiv1beta/lfp_sale_client.go | 2 +- .../lfp_sale_client_example_go123_test.go | 2 +- .../apiv1beta/lfp_sale_client_example_test.go | 2 +- .../lfp/apiv1beta/lfp_store_client.go | 2 +- .../lfp_store_client_example_go123_test.go | 2 +- .../lfp_store_client_example_test.go | 2 +- .../notifications/apiv1beta/auxiliary.go | 2 +- .../apiv1beta/auxiliary_go123.go | 2 +- .../merchant/notifications/apiv1beta/doc.go | 2 +- .../notifications/apiv1beta/helpers.go | 2 +- .../apiv1beta/notifications_api_client.go | 2 +- ...fications_api_client_example_go123_test.go | 2 +- .../notifications_api_client_example_test.go | 2 +- .../merchant/products/apiv1beta/auxiliary.go | 2 +- .../products/apiv1beta/auxiliary_go123.go | 2 +- shopping/merchant/products/apiv1beta/doc.go | 2 +- .../merchant/products/apiv1beta/helpers.go | 2 +- .../apiv1beta/product_inputs_client.go | 2 +- ...roduct_inputs_client_example_go123_test.go | 2 +- .../product_inputs_client_example_test.go | 2 +- .../products/apiv1beta/products_client.go | 2 +- .../products_client_example_go123_test.go | 2 +- .../apiv1beta/products_client_example_test.go | 2 +- .../promotions/apiv1beta/auxiliary.go | 2 +- .../promotions/apiv1beta/auxiliary_go123.go | 2 +- shopping/merchant/promotions/apiv1beta/doc.go | 2 +- .../merchant/promotions/apiv1beta/helpers.go | 2 +- .../promotions/apiv1beta/promotions_client.go | 2 +- .../promotions_client_example_go123_test.go | 2 +- .../promotions_client_example_test.go | 2 +- .../merchant/quota/apiv1beta/auxiliary.go | 2 +- .../quota/apiv1beta/auxiliary_go123.go | 2 +- shopping/merchant/quota/apiv1beta/doc.go | 2 +- shopping/merchant/quota/apiv1beta/helpers.go | 2 +- .../merchant/quota/apiv1beta/quota_client.go | 2 +- .../quota_client_example_go123_test.go | 2 +- .../apiv1beta/quota_client_example_test.go | 2 +- .../merchant/reports/apiv1beta/auxiliary.go | 2 +- .../reports/apiv1beta/auxiliary_go123.go | 2 +- shopping/merchant/reports/apiv1beta/doc.go | 2 +- .../merchant/reports/apiv1beta/helpers.go | 2 +- .../reports/apiv1beta/report_client.go | 2 +- .../report_client_example_go123_test.go | 2 +- .../apiv1beta/report_client_example_test.go | 2 +- .../merchant/reviews/apiv1beta/auxiliary.go | 2 +- .../reviews/apiv1beta/auxiliary_go123.go | 2 +- shopping/merchant/reviews/apiv1beta/doc.go | 2 +- .../merchant/reviews/apiv1beta/helpers.go | 2 +- .../apiv1beta/merchant_reviews_client.go | 2 +- ...chant_reviews_client_example_go123_test.go | 2 +- .../merchant_reviews_client_example_test.go | 2 +- .../apiv1beta/product_reviews_client.go | 2 +- ...oduct_reviews_client_example_go123_test.go | 2 +- .../product_reviews_client_example_test.go | 2 +- spanner/admin/database/apiv1/auxiliary.go | 2 +- .../admin/database/apiv1/auxiliary_go123.go | 2 +- .../database/apiv1/database_admin_client.go | 2 +- ...atabase_admin_client_example_go123_test.go | 2 +- .../database_admin_client_example_test.go | 2 +- spanner/admin/database/apiv1/doc.go | 2 +- spanner/admin/database/apiv1/helpers.go | 2 +- spanner/admin/instance/apiv1/auxiliary.go | 2 +- .../admin/instance/apiv1/auxiliary_go123.go | 2 +- spanner/admin/instance/apiv1/doc.go | 2 +- spanner/admin/instance/apiv1/helpers.go | 2 +- .../instance/apiv1/instance_admin_client.go | 2 +- ...nstance_admin_client_example_go123_test.go | 2 +- .../instance_admin_client_example_test.go | 2 +- spanner/apiv1/auxiliary.go | 2 +- spanner/apiv1/auxiliary_go123.go | 2 +- spanner/apiv1/doc.go | 2 +- spanner/apiv1/helpers.go | 2 +- spanner/apiv1/spanner_client.go | 2 +- .../spanner_client_example_go123_test.go | 2 +- spanner/apiv1/spanner_client_example_test.go | 2 +- spanner/executor/apiv1/auxiliary.go | 2 +- spanner/executor/apiv1/auxiliary_go123.go | 2 +- spanner/executor/apiv1/doc.go | 2 +- spanner/executor/apiv1/helpers.go | 2 +- .../apiv1/spanner_executor_proxy_client.go | 2 +- ...xecutor_proxy_client_example_go123_test.go | 2 +- ...nner_executor_proxy_client_example_test.go | 2 +- speech/apiv1/adaptation_client.go | 2 +- .../adaptation_client_example_go123_test.go | 2 +- .../apiv1/adaptation_client_example_test.go | 2 +- speech/apiv1/auxiliary.go | 2 +- speech/apiv1/auxiliary_go123.go | 2 +- speech/apiv1/doc.go | 2 +- speech/apiv1/helpers.go | 2 +- speech/apiv1/speech_client.go | 2 +- .../apiv1/speech_client_example_go123_test.go | 2 +- speech/apiv1/speech_client_example_test.go | 2 +- speech/apiv1p1beta1/adaptation_client.go | 2 +- .../adaptation_client_example_go123_test.go | 2 +- .../adaptation_client_example_test.go | 2 +- speech/apiv1p1beta1/auxiliary.go | 2 +- speech/apiv1p1beta1/auxiliary_go123.go | 2 +- speech/apiv1p1beta1/doc.go | 2 +- speech/apiv1p1beta1/helpers.go | 2 +- speech/apiv1p1beta1/speech_client.go | 2 +- .../speech_client_example_go123_test.go | 2 +- .../speech_client_example_test.go | 2 +- speech/apiv2/auxiliary.go | 2 +- speech/apiv2/auxiliary_go123.go | 2 +- speech/apiv2/doc.go | 2 +- speech/apiv2/helpers.go | 2 +- speech/apiv2/speech_client.go | 2 +- .../apiv2/speech_client_example_go123_test.go | 2 +- speech/apiv2/speech_client_example_test.go | 2 +- storage/control/apiv2/auxiliary.go | 2 +- storage/control/apiv2/auxiliary_go123.go | 2 +- storage/control/apiv2/doc.go | 2 +- storage/control/apiv2/helpers.go | 2 +- .../control/apiv2/storage_control_client.go | 2 +- ...orage_control_client_example_go123_test.go | 2 +- .../storage_control_client_example_test.go | 2 +- storage/internal/apiv2/auxiliary.go | 2 +- storage/internal/apiv2/auxiliary_go123.go | 2 +- storage/internal/apiv2/doc.go | 2 +- storage/internal/apiv2/helpers.go | 2 +- storage/internal/apiv2/storage_client.go | 2 +- .../storage_client_example_go123_test.go | 2 +- .../apiv2/storage_client_example_test.go | 2 +- storageinsights/apiv1/auxiliary.go | 2 +- storageinsights/apiv1/auxiliary_go123.go | 2 +- storageinsights/apiv1/doc.go | 2 +- storageinsights/apiv1/helpers.go | 2 +- .../apiv1/storage_insights_client.go | 2 +- ...rage_insights_client_example_go123_test.go | 2 +- .../storage_insights_client_example_test.go | 2 +- storagetransfer/apiv1/auxiliary.go | 2 +- storagetransfer/apiv1/auxiliary_go123.go | 2 +- storagetransfer/apiv1/doc.go | 2 +- storagetransfer/apiv1/helpers.go | 2 +- .../apiv1/storage_transfer_client.go | 2 +- ...rage_transfer_client_example_go123_test.go | 2 +- .../storage_transfer_client_example_test.go | 2 +- streetview/publish/apiv1/auxiliary.go | 2 +- streetview/publish/apiv1/auxiliary_go123.go | 2 +- streetview/publish/apiv1/doc.go | 2 +- streetview/publish/apiv1/helpers.go | 2 +- .../apiv1/street_view_publish_client.go | 2 +- ..._view_publish_client_example_go123_test.go | 2 +- ...street_view_publish_client_example_test.go | 2 +- support/apiv2/auxiliary.go | 2 +- support/apiv2/auxiliary_go123.go | 2 +- support/apiv2/case_attachment_client.go | 2 +- ...se_attachment_client_example_go123_test.go | 2 +- .../case_attachment_client_example_test.go | 2 +- support/apiv2/case_client.go | 2 +- .../apiv2/case_client_example_go123_test.go | 2 +- support/apiv2/case_client_example_test.go | 2 +- support/apiv2/comment_client.go | 2 +- .../comment_client_example_go123_test.go | 2 +- support/apiv2/comment_client_example_test.go | 2 +- support/apiv2/doc.go | 2 +- support/apiv2/helpers.go | 2 +- talent/apiv4/auxiliary.go | 2 +- talent/apiv4/auxiliary_go123.go | 2 +- talent/apiv4/company_client.go | 2 +- .../company_client_example_go123_test.go | 2 +- talent/apiv4/company_client_example_test.go | 2 +- talent/apiv4/completion_client.go | 2 +- .../completion_client_example_go123_test.go | 2 +- .../apiv4/completion_client_example_test.go | 2 +- talent/apiv4/doc.go | 2 +- talent/apiv4/event_client.go | 2 +- .../apiv4/event_client_example_go123_test.go | 2 +- talent/apiv4/event_client_example_test.go | 2 +- talent/apiv4/helpers.go | 2 +- talent/apiv4/job_client.go | 2 +- talent/apiv4/job_client_example_go123_test.go | 2 +- talent/apiv4/job_client_example_test.go | 2 +- talent/apiv4/tenant_client.go | 2 +- .../apiv4/tenant_client_example_go123_test.go | 2 +- talent/apiv4/tenant_client_example_test.go | 2 +- talent/apiv4beta1/auxiliary.go | 2 +- talent/apiv4beta1/auxiliary_go123.go | 2 +- talent/apiv4beta1/company_client.go | 2 +- .../company_client_example_go123_test.go | 2 +- .../apiv4beta1/company_client_example_test.go | 2 +- talent/apiv4beta1/completion_client.go | 2 +- .../completion_client_example_go123_test.go | 2 +- .../completion_client_example_test.go | 2 +- talent/apiv4beta1/doc.go | 2 +- talent/apiv4beta1/event_client.go | 2 +- .../event_client_example_go123_test.go | 2 +- .../apiv4beta1/event_client_example_test.go | 2 +- talent/apiv4beta1/helpers.go | 2 +- talent/apiv4beta1/job_client.go | 2 +- .../job_client_example_go123_test.go | 2 +- talent/apiv4beta1/job_client_example_test.go | 2 +- talent/apiv4beta1/talentpb/job_service.pb.go | 847 ++++++++++-------- talent/apiv4beta1/tenant_client.go | 2 +- .../tenant_client_example_go123_test.go | 2 +- .../apiv4beta1/tenant_client_example_test.go | 2 +- telcoautomation/apiv1/auxiliary.go | 2 +- telcoautomation/apiv1/auxiliary_go123.go | 2 +- telcoautomation/apiv1/doc.go | 2 +- telcoautomation/apiv1/helpers.go | 2 +- .../apiv1/telco_automation_client.go | 2 +- ...co_automation_client_example_go123_test.go | 2 +- .../telco_automation_client_example_test.go | 2 +- texttospeech/apiv1/auxiliary.go | 2 +- texttospeech/apiv1/auxiliary_go123.go | 2 +- texttospeech/apiv1/doc.go | 2 +- texttospeech/apiv1/helpers.go | 2 +- texttospeech/apiv1/text_to_speech_client.go | 2 +- ...ext_to_speech_client_example_go123_test.go | 2 +- .../text_to_speech_client_example_test.go | 2 +- ..._to_speech_long_audio_synthesize_client.go | 2 +- ...io_synthesize_client_example_go123_test.go | 2 +- ...ng_audio_synthesize_client_example_test.go | 2 +- tpu/apiv1/auxiliary.go | 2 +- tpu/apiv1/auxiliary_go123.go | 2 +- tpu/apiv1/doc.go | 2 +- tpu/apiv1/helpers.go | 2 +- tpu/apiv1/tpu_client.go | 2 +- tpu/apiv1/tpu_client_example_go123_test.go | 2 +- tpu/apiv1/tpu_client_example_test.go | 2 +- trace/apiv1/auxiliary.go | 2 +- trace/apiv1/auxiliary_go123.go | 2 +- trace/apiv1/doc.go | 2 +- trace/apiv1/helpers.go | 2 +- trace/apiv1/trace_client.go | 2 +- .../apiv1/trace_client_example_go123_test.go | 2 +- trace/apiv1/trace_client_example_test.go | 2 +- trace/apiv2/auxiliary.go | 2 +- trace/apiv2/auxiliary_go123.go | 2 +- trace/apiv2/doc.go | 2 +- trace/apiv2/helpers.go | 2 +- trace/apiv2/trace_client.go | 2 +- .../apiv2/trace_client_example_go123_test.go | 2 +- trace/apiv2/trace_client_example_test.go | 2 +- translate/apiv3/auxiliary.go | 2 +- translate/apiv3/auxiliary_go123.go | 2 +- translate/apiv3/doc.go | 2 +- translate/apiv3/helpers.go | 2 +- translate/apiv3/translation_client.go | 2 +- .../translation_client_example_go123_test.go | 2 +- .../apiv3/translation_client_example_test.go | 2 +- video/livestream/apiv1/auxiliary.go | 2 +- video/livestream/apiv1/auxiliary_go123.go | 2 +- video/livestream/apiv1/doc.go | 2 +- video/livestream/apiv1/helpers.go | 2 +- video/livestream/apiv1/livestream_client.go | 2 +- .../livestream_client_example_go123_test.go | 2 +- .../apiv1/livestream_client_example_test.go | 2 +- video/stitcher/apiv1/auxiliary.go | 2 +- video/stitcher/apiv1/auxiliary_go123.go | 2 +- video/stitcher/apiv1/doc.go | 2 +- video/stitcher/apiv1/helpers.go | 2 +- video/stitcher/apiv1/video_stitcher_client.go | 2 +- ...ideo_stitcher_client_example_go123_test.go | 2 +- .../video_stitcher_client_example_test.go | 2 +- video/transcoder/apiv1/auxiliary.go | 2 +- video/transcoder/apiv1/auxiliary_go123.go | 2 +- video/transcoder/apiv1/doc.go | 2 +- video/transcoder/apiv1/helpers.go | 2 +- video/transcoder/apiv1/transcoder_client.go | 2 +- .../transcoder_client_example_go123_test.go | 2 +- .../apiv1/transcoder_client_example_test.go | 2 +- videointelligence/apiv1/auxiliary.go | 2 +- videointelligence/apiv1/auxiliary_go123.go | 2 +- videointelligence/apiv1/doc.go | 2 +- videointelligence/apiv1/helpers.go | 2 +- .../apiv1/video_intelligence_client.go | 2 +- ..._intelligence_client_example_go123_test.go | 2 +- .../video_intelligence_client_example_test.go | 2 +- videointelligence/apiv1beta2/auxiliary.go | 2 +- .../apiv1beta2/auxiliary_go123.go | 2 +- videointelligence/apiv1beta2/doc.go | 2 +- videointelligence/apiv1beta2/helpers.go | 2 +- .../apiv1beta2/video_intelligence_client.go | 2 +- ..._intelligence_client_example_go123_test.go | 2 +- .../video_intelligence_client_example_test.go | 2 +- videointelligence/apiv1p3beta1/auxiliary.go | 2 +- .../apiv1p3beta1/auxiliary_go123.go | 2 +- videointelligence/apiv1p3beta1/doc.go | 2 +- videointelligence/apiv1p3beta1/helpers.go | 2 +- .../streaming_video_intelligence_client.go | 2 +- ..._intelligence_client_example_go123_test.go | 2 +- ..._video_intelligence_client_example_test.go | 2 +- .../apiv1p3beta1/video_intelligence_client.go | 2 +- ..._intelligence_client_example_go123_test.go | 2 +- .../video_intelligence_client_example_test.go | 2 +- vision/apiv1/auxiliary.go | 2 +- vision/apiv1/auxiliary_go123.go | 2 +- vision/apiv1/doc.go | 2 +- vision/apiv1/helpers.go | 2 +- vision/apiv1/image_annotator_client.go | 2 +- ...age_annotator_client_example_go123_test.go | 2 +- .../image_annotator_client_example_test.go | 2 +- vision/apiv1/product_search_client.go | 2 +- ...roduct_search_client_example_go123_test.go | 2 +- .../product_search_client_example_test.go | 2 +- vision/apiv1p1beta1/auxiliary.go | 2 +- vision/apiv1p1beta1/auxiliary_go123.go | 2 +- vision/apiv1p1beta1/doc.go | 2 +- vision/apiv1p1beta1/helpers.go | 2 +- vision/apiv1p1beta1/image_annotator_client.go | 2 +- ...age_annotator_client_example_go123_test.go | 2 +- .../image_annotator_client_example_test.go | 2 +- visionai/apiv1/app_platform_client.go | 2 +- .../app_platform_client_example_go123_test.go | 2 +- .../apiv1/app_platform_client_example_test.go | 2 +- visionai/apiv1/auxiliary.go | 2 +- visionai/apiv1/auxiliary_go123.go | 2 +- visionai/apiv1/doc.go | 2 +- visionai/apiv1/health_check_client.go | 2 +- .../health_check_client_example_go123_test.go | 2 +- .../apiv1/health_check_client_example_test.go | 2 +- visionai/apiv1/helpers.go | 2 +- visionai/apiv1/live_video_analytics_client.go | 2 +- ...deo_analytics_client_example_go123_test.go | 2 +- ...ive_video_analytics_client_example_test.go | 2 +- visionai/apiv1/streaming_client.go | 2 +- .../streaming_client_example_go123_test.go | 2 +- .../apiv1/streaming_client_example_test.go | 2 +- visionai/apiv1/streams_client.go | 2 +- .../streams_client_example_go123_test.go | 2 +- visionai/apiv1/streams_client_example_test.go | 2 +- visionai/apiv1/warehouse_client.go | 2 +- .../warehouse_client_example_go123_test.go | 2 +- .../apiv1/warehouse_client_example_test.go | 2 +- vmmigration/apiv1/auxiliary.go | 2 +- vmmigration/apiv1/auxiliary_go123.go | 2 +- vmmigration/apiv1/doc.go | 2 +- vmmigration/apiv1/helpers.go | 2 +- vmmigration/apiv1/vm_migration_client.go | 2 +- .../vm_migration_client_example_go123_test.go | 2 +- .../apiv1/vm_migration_client_example_test.go | 2 +- vmwareengine/apiv1/auxiliary.go | 2 +- vmwareengine/apiv1/auxiliary_go123.go | 2 +- vmwareengine/apiv1/doc.go | 2 +- vmwareengine/apiv1/helpers.go | 2 +- vmwareengine/apiv1/vmware_engine_client.go | 2 +- ...vmware_engine_client_example_go123_test.go | 2 +- .../vmware_engine_client_example_test.go | 2 +- vpcaccess/apiv1/auxiliary.go | 2 +- vpcaccess/apiv1/auxiliary_go123.go | 2 +- vpcaccess/apiv1/doc.go | 2 +- vpcaccess/apiv1/helpers.go | 2 +- vpcaccess/apiv1/vpc_access_client.go | 2 +- .../vpc_access_client_example_go123_test.go | 2 +- .../apiv1/vpc_access_client_example_test.go | 2 +- webrisk/apiv1/auxiliary.go | 2 +- webrisk/apiv1/auxiliary_go123.go | 2 +- webrisk/apiv1/doc.go | 2 +- webrisk/apiv1/helpers.go | 2 +- webrisk/apiv1/web_risk_client.go | 2 +- .../web_risk_client_example_go123_test.go | 2 +- webrisk/apiv1/web_risk_client_example_test.go | 2 +- webrisk/apiv1beta1/auxiliary.go | 2 +- webrisk/apiv1beta1/auxiliary_go123.go | 2 +- webrisk/apiv1beta1/doc.go | 2 +- webrisk/apiv1beta1/helpers.go | 2 +- .../web_risk_service_v1_beta1_client.go | 2 +- ...vice_v1_beta1_client_example_go123_test.go | 2 +- ...sk_service_v1_beta1_client_example_test.go | 2 +- websecurityscanner/apiv1/auxiliary.go | 2 +- websecurityscanner/apiv1/auxiliary_go123.go | 2 +- websecurityscanner/apiv1/doc.go | 2 +- websecurityscanner/apiv1/helpers.go | 2 +- .../apiv1/web_security_scanner_client.go | 2 +- ...urity_scanner_client_example_go123_test.go | 2 +- ...eb_security_scanner_client_example_test.go | 2 +- workflows/apiv1/auxiliary.go | 2 +- workflows/apiv1/auxiliary_go123.go | 2 +- workflows/apiv1/doc.go | 2 +- workflows/apiv1/helpers.go | 2 +- workflows/apiv1/workflows_client.go | 2 +- .../workflows_client_example_go123_test.go | 2 +- .../apiv1/workflows_client_example_test.go | 2 +- workflows/apiv1beta/auxiliary.go | 2 +- workflows/apiv1beta/auxiliary_go123.go | 2 +- workflows/apiv1beta/doc.go | 2 +- workflows/apiv1beta/helpers.go | 2 +- workflows/apiv1beta/workflows_client.go | 2 +- .../workflows_client_example_go123_test.go | 2 +- .../workflows_client_example_test.go | 2 +- workflows/executions/apiv1/auxiliary.go | 2 +- workflows/executions/apiv1/auxiliary_go123.go | 2 +- workflows/executions/apiv1/doc.go | 2 +- .../executions/apiv1/executions_client.go | 2 +- .../executions_client_example_go123_test.go | 2 +- .../apiv1/executions_client_example_test.go | 2 +- workflows/executions/apiv1/helpers.go | 2 +- workflows/executions/apiv1beta/auxiliary.go | 2 +- .../executions/apiv1beta/auxiliary_go123.go | 2 +- workflows/executions/apiv1beta/doc.go | 2 +- .../executions/apiv1beta/executions_client.go | 2 +- .../executions_client_example_go123_test.go | 2 +- .../executions_client_example_test.go | 2 +- workflows/executions/apiv1beta/helpers.go | 2 +- workstations/apiv1/auxiliary.go | 2 +- workstations/apiv1/auxiliary_go123.go | 2 +- workstations/apiv1/doc.go | 2 +- workstations/apiv1/helpers.go | 2 +- workstations/apiv1/workstations_client.go | 2 +- .../workstations_client_example_go123_test.go | 2 +- .../apiv1/workstations_client_example_test.go | 2 +- workstations/apiv1beta/auxiliary.go | 2 +- workstations/apiv1beta/auxiliary_go123.go | 2 +- workstations/apiv1beta/doc.go | 2 +- workstations/apiv1beta/helpers.go | 2 +- workstations/apiv1beta/workstations_client.go | 2 +- .../workstations_client_example_go123_test.go | 2 +- .../workstations_client_example_test.go | 2 +- 12949 files changed, 13481 insertions(+), 13388 deletions(-) diff --git a/accessapproval/apiv1/access_approval_client.go b/accessapproval/apiv1/access_approval_client.go index 6506a68ccfa9..95c13cc91134 100755 --- a/accessapproval/apiv1/access_approval_client.go +++ b/accessapproval/apiv1/access_approval_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/accessapproval/apiv1/access_approval_client_example_go123_test.go b/accessapproval/apiv1/access_approval_client_example_go123_test.go index 961dfc07f7af..410f430470a2 100644 --- a/accessapproval/apiv1/access_approval_client_example_go123_test.go +++ b/accessapproval/apiv1/access_approval_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/accessapproval/apiv1/access_approval_client_example_test.go b/accessapproval/apiv1/access_approval_client_example_test.go index 5e947329ac63..a38972597afb 100644 --- a/accessapproval/apiv1/access_approval_client_example_test.go +++ b/accessapproval/apiv1/access_approval_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/accessapproval/apiv1/auxiliary.go b/accessapproval/apiv1/auxiliary.go index 138be5b07455..a9abc92786ef 100755 --- a/accessapproval/apiv1/auxiliary.go +++ b/accessapproval/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/accessapproval/apiv1/auxiliary_go123.go b/accessapproval/apiv1/auxiliary_go123.go index 28bf8490cd11..fb2709ab36cc 100755 --- a/accessapproval/apiv1/auxiliary_go123.go +++ b/accessapproval/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/accessapproval/apiv1/doc.go b/accessapproval/apiv1/doc.go index f5531cc060e2..52eebcb5c47c 100755 --- a/accessapproval/apiv1/doc.go +++ b/accessapproval/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/accessapproval/apiv1/helpers.go b/accessapproval/apiv1/helpers.go index 9113b3b8af3e..8729ab858753 100755 --- a/accessapproval/apiv1/helpers.go +++ b/accessapproval/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/accesscontextmanager/apiv1/access_context_manager_client.go b/accesscontextmanager/apiv1/access_context_manager_client.go index 51b400ab3378..fbf68348986d 100755 --- a/accesscontextmanager/apiv1/access_context_manager_client.go +++ b/accesscontextmanager/apiv1/access_context_manager_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/accesscontextmanager/apiv1/access_context_manager_client_example_go123_test.go b/accesscontextmanager/apiv1/access_context_manager_client_example_go123_test.go index 7ca20323cac0..be7ce6a0dd9a 100644 --- a/accesscontextmanager/apiv1/access_context_manager_client_example_go123_test.go +++ b/accesscontextmanager/apiv1/access_context_manager_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/accesscontextmanager/apiv1/access_context_manager_client_example_test.go b/accesscontextmanager/apiv1/access_context_manager_client_example_test.go index 69d620c8e597..a07d980038d6 100644 --- a/accesscontextmanager/apiv1/access_context_manager_client_example_test.go +++ b/accesscontextmanager/apiv1/access_context_manager_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/accesscontextmanager/apiv1/auxiliary.go b/accesscontextmanager/apiv1/auxiliary.go index bc89aa0ce599..b321907fc8e5 100755 --- a/accesscontextmanager/apiv1/auxiliary.go +++ b/accesscontextmanager/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/accesscontextmanager/apiv1/auxiliary_go123.go b/accesscontextmanager/apiv1/auxiliary_go123.go index 374e492b8ac2..729593659f1c 100755 --- a/accesscontextmanager/apiv1/auxiliary_go123.go +++ b/accesscontextmanager/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/accesscontextmanager/apiv1/doc.go b/accesscontextmanager/apiv1/doc.go index c0a731b3c60b..3d924b9e8c06 100755 --- a/accesscontextmanager/apiv1/doc.go +++ b/accesscontextmanager/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/accesscontextmanager/apiv1/helpers.go b/accesscontextmanager/apiv1/helpers.go index fcb33d6acf80..e5b0f1156fd6 100755 --- a/accesscontextmanager/apiv1/helpers.go +++ b/accesscontextmanager/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/advisorynotifications/apiv1/advisory_notifications_client.go b/advisorynotifications/apiv1/advisory_notifications_client.go index 07bf80db84b1..3a6f47c4c408 100755 --- a/advisorynotifications/apiv1/advisory_notifications_client.go +++ b/advisorynotifications/apiv1/advisory_notifications_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/advisorynotifications/apiv1/advisory_notifications_client_example_go123_test.go b/advisorynotifications/apiv1/advisory_notifications_client_example_go123_test.go index 2626c6cda63e..77df520c53ef 100644 --- a/advisorynotifications/apiv1/advisory_notifications_client_example_go123_test.go +++ b/advisorynotifications/apiv1/advisory_notifications_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/advisorynotifications/apiv1/advisory_notifications_client_example_test.go b/advisorynotifications/apiv1/advisory_notifications_client_example_test.go index afd18831f2de..840bd58a3be9 100644 --- a/advisorynotifications/apiv1/advisory_notifications_client_example_test.go +++ b/advisorynotifications/apiv1/advisory_notifications_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/advisorynotifications/apiv1/auxiliary.go b/advisorynotifications/apiv1/auxiliary.go index e2f1cd5f8e3d..309a1202f156 100755 --- a/advisorynotifications/apiv1/auxiliary.go +++ b/advisorynotifications/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/advisorynotifications/apiv1/auxiliary_go123.go b/advisorynotifications/apiv1/auxiliary_go123.go index d1603d0bf35f..080b6b7ba579 100755 --- a/advisorynotifications/apiv1/auxiliary_go123.go +++ b/advisorynotifications/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/advisorynotifications/apiv1/doc.go b/advisorynotifications/apiv1/doc.go index 3e65a44f5d26..ebaa110d5341 100755 --- a/advisorynotifications/apiv1/doc.go +++ b/advisorynotifications/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/advisorynotifications/apiv1/helpers.go b/advisorynotifications/apiv1/helpers.go index 91eeab123a76..deab59838cee 100755 --- a/advisorynotifications/apiv1/helpers.go +++ b/advisorynotifications/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1/auxiliary.go b/ai/generativelanguage/apiv1/auxiliary.go index 58d9a018be67..87192864501d 100755 --- a/ai/generativelanguage/apiv1/auxiliary.go +++ b/ai/generativelanguage/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1/auxiliary_go123.go b/ai/generativelanguage/apiv1/auxiliary_go123.go index 5da847edcf1c..5f70141b9f7f 100755 --- a/ai/generativelanguage/apiv1/auxiliary_go123.go +++ b/ai/generativelanguage/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1/doc.go b/ai/generativelanguage/apiv1/doc.go index 92e82a9b2795..65518aa12880 100755 --- a/ai/generativelanguage/apiv1/doc.go +++ b/ai/generativelanguage/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1/generative_client.go b/ai/generativelanguage/apiv1/generative_client.go index c70a08dfbf72..cf31a35b6233 100755 --- a/ai/generativelanguage/apiv1/generative_client.go +++ b/ai/generativelanguage/apiv1/generative_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1/generative_client_example_go123_test.go b/ai/generativelanguage/apiv1/generative_client_example_go123_test.go index ec303ed36b9d..cf8fd91c8644 100644 --- a/ai/generativelanguage/apiv1/generative_client_example_go123_test.go +++ b/ai/generativelanguage/apiv1/generative_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1/generative_client_example_test.go b/ai/generativelanguage/apiv1/generative_client_example_test.go index c758b741ca64..040642a20265 100644 --- a/ai/generativelanguage/apiv1/generative_client_example_test.go +++ b/ai/generativelanguage/apiv1/generative_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1/helpers.go b/ai/generativelanguage/apiv1/helpers.go index 101cfeee0c6f..e77bf1c5e0f2 100755 --- a/ai/generativelanguage/apiv1/helpers.go +++ b/ai/generativelanguage/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1/model_client.go b/ai/generativelanguage/apiv1/model_client.go index 428f12fb0e5b..5b82317ec84f 100755 --- a/ai/generativelanguage/apiv1/model_client.go +++ b/ai/generativelanguage/apiv1/model_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1/model_client_example_go123_test.go b/ai/generativelanguage/apiv1/model_client_example_go123_test.go index 67dc5f4ace28..046c6a88a7dd 100644 --- a/ai/generativelanguage/apiv1/model_client_example_go123_test.go +++ b/ai/generativelanguage/apiv1/model_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1/model_client_example_test.go b/ai/generativelanguage/apiv1/model_client_example_test.go index 6d43ef35cb69..9b95bbbbbb8f 100644 --- a/ai/generativelanguage/apiv1/model_client_example_test.go +++ b/ai/generativelanguage/apiv1/model_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/auxiliary.go b/ai/generativelanguage/apiv1beta/auxiliary.go index 693db19de416..c428d4a8a2da 100755 --- a/ai/generativelanguage/apiv1beta/auxiliary.go +++ b/ai/generativelanguage/apiv1beta/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/auxiliary_go123.go b/ai/generativelanguage/apiv1beta/auxiliary_go123.go index bfacd0e48221..6fa1071a77a3 100755 --- a/ai/generativelanguage/apiv1beta/auxiliary_go123.go +++ b/ai/generativelanguage/apiv1beta/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/cache_client.go b/ai/generativelanguage/apiv1beta/cache_client.go index 9811377ea5bc..561c8751e319 100755 --- a/ai/generativelanguage/apiv1beta/cache_client.go +++ b/ai/generativelanguage/apiv1beta/cache_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/cache_client_example_go123_test.go b/ai/generativelanguage/apiv1beta/cache_client_example_go123_test.go index 0a26559b906c..87fb198e089a 100644 --- a/ai/generativelanguage/apiv1beta/cache_client_example_go123_test.go +++ b/ai/generativelanguage/apiv1beta/cache_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/cache_client_example_test.go b/ai/generativelanguage/apiv1beta/cache_client_example_test.go index cdfb0f341f04..97341a34d0db 100644 --- a/ai/generativelanguage/apiv1beta/cache_client_example_test.go +++ b/ai/generativelanguage/apiv1beta/cache_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/discuss_client.go b/ai/generativelanguage/apiv1beta/discuss_client.go index 9f892b6d3783..3e014751ccd7 100755 --- a/ai/generativelanguage/apiv1beta/discuss_client.go +++ b/ai/generativelanguage/apiv1beta/discuss_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/discuss_client_example_go123_test.go b/ai/generativelanguage/apiv1beta/discuss_client_example_go123_test.go index fc8a51c5148a..9c8a99e176a1 100644 --- a/ai/generativelanguage/apiv1beta/discuss_client_example_go123_test.go +++ b/ai/generativelanguage/apiv1beta/discuss_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/discuss_client_example_test.go b/ai/generativelanguage/apiv1beta/discuss_client_example_test.go index cecb4a66be3d..9e407b57588b 100644 --- a/ai/generativelanguage/apiv1beta/discuss_client_example_test.go +++ b/ai/generativelanguage/apiv1beta/discuss_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/doc.go b/ai/generativelanguage/apiv1beta/doc.go index 0532289a3ccf..5789e09f4379 100755 --- a/ai/generativelanguage/apiv1beta/doc.go +++ b/ai/generativelanguage/apiv1beta/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/file_client.go b/ai/generativelanguage/apiv1beta/file_client.go index 242b0db529e3..a9a492a53ede 100755 --- a/ai/generativelanguage/apiv1beta/file_client.go +++ b/ai/generativelanguage/apiv1beta/file_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/file_client_example_go123_test.go b/ai/generativelanguage/apiv1beta/file_client_example_go123_test.go index 5dc0a05c8edb..bcc052dad993 100644 --- a/ai/generativelanguage/apiv1beta/file_client_example_go123_test.go +++ b/ai/generativelanguage/apiv1beta/file_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/file_client_example_test.go b/ai/generativelanguage/apiv1beta/file_client_example_test.go index 56c97b331655..4cdd9d12df5c 100644 --- a/ai/generativelanguage/apiv1beta/file_client_example_test.go +++ b/ai/generativelanguage/apiv1beta/file_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/generative_client.go b/ai/generativelanguage/apiv1beta/generative_client.go index bd0d619ea6d5..c1f386be674d 100755 --- a/ai/generativelanguage/apiv1beta/generative_client.go +++ b/ai/generativelanguage/apiv1beta/generative_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/generative_client_example_go123_test.go b/ai/generativelanguage/apiv1beta/generative_client_example_go123_test.go index 678da0b57033..0bf5027744c4 100644 --- a/ai/generativelanguage/apiv1beta/generative_client_example_go123_test.go +++ b/ai/generativelanguage/apiv1beta/generative_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/generative_client_example_test.go b/ai/generativelanguage/apiv1beta/generative_client_example_test.go index d3fa14b15b35..1b82fc344979 100644 --- a/ai/generativelanguage/apiv1beta/generative_client_example_test.go +++ b/ai/generativelanguage/apiv1beta/generative_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/helpers.go b/ai/generativelanguage/apiv1beta/helpers.go index 101cfeee0c6f..e77bf1c5e0f2 100755 --- a/ai/generativelanguage/apiv1beta/helpers.go +++ b/ai/generativelanguage/apiv1beta/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/model_client.go b/ai/generativelanguage/apiv1beta/model_client.go index 44c40eb451f0..90958feeef8e 100755 --- a/ai/generativelanguage/apiv1beta/model_client.go +++ b/ai/generativelanguage/apiv1beta/model_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/model_client_example_go123_test.go b/ai/generativelanguage/apiv1beta/model_client_example_go123_test.go index f1a093b1d48d..cd1e875e6240 100644 --- a/ai/generativelanguage/apiv1beta/model_client_example_go123_test.go +++ b/ai/generativelanguage/apiv1beta/model_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/model_client_example_test.go b/ai/generativelanguage/apiv1beta/model_client_example_test.go index dd513e7d6354..10d88a965bd5 100644 --- a/ai/generativelanguage/apiv1beta/model_client_example_test.go +++ b/ai/generativelanguage/apiv1beta/model_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/permission_client.go b/ai/generativelanguage/apiv1beta/permission_client.go index 56f43391cdda..dc3d6f6ba8ac 100755 --- a/ai/generativelanguage/apiv1beta/permission_client.go +++ b/ai/generativelanguage/apiv1beta/permission_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/permission_client_example_go123_test.go b/ai/generativelanguage/apiv1beta/permission_client_example_go123_test.go index 6efbb51f53eb..218949edfa68 100644 --- a/ai/generativelanguage/apiv1beta/permission_client_example_go123_test.go +++ b/ai/generativelanguage/apiv1beta/permission_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/permission_client_example_test.go b/ai/generativelanguage/apiv1beta/permission_client_example_test.go index bfad2d7ed9de..b4991e57fdea 100644 --- a/ai/generativelanguage/apiv1beta/permission_client_example_test.go +++ b/ai/generativelanguage/apiv1beta/permission_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/prediction_client.go b/ai/generativelanguage/apiv1beta/prediction_client.go index 5e4ed582837b..418e7cedb724 100755 --- a/ai/generativelanguage/apiv1beta/prediction_client.go +++ b/ai/generativelanguage/apiv1beta/prediction_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/prediction_client_example_go123_test.go b/ai/generativelanguage/apiv1beta/prediction_client_example_go123_test.go index d706385c16a9..10a630d87ccb 100644 --- a/ai/generativelanguage/apiv1beta/prediction_client_example_go123_test.go +++ b/ai/generativelanguage/apiv1beta/prediction_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/prediction_client_example_test.go b/ai/generativelanguage/apiv1beta/prediction_client_example_test.go index f7a5b1e1cb23..8066f16e4057 100644 --- a/ai/generativelanguage/apiv1beta/prediction_client_example_test.go +++ b/ai/generativelanguage/apiv1beta/prediction_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/retriever_client.go b/ai/generativelanguage/apiv1beta/retriever_client.go index e92173ada638..e8414adfc66d 100755 --- a/ai/generativelanguage/apiv1beta/retriever_client.go +++ b/ai/generativelanguage/apiv1beta/retriever_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/retriever_client_example_go123_test.go b/ai/generativelanguage/apiv1beta/retriever_client_example_go123_test.go index 6a88872266ec..040d4a85a88b 100644 --- a/ai/generativelanguage/apiv1beta/retriever_client_example_go123_test.go +++ b/ai/generativelanguage/apiv1beta/retriever_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/retriever_client_example_test.go b/ai/generativelanguage/apiv1beta/retriever_client_example_test.go index e53cac81d40b..d00b5becc490 100644 --- a/ai/generativelanguage/apiv1beta/retriever_client_example_test.go +++ b/ai/generativelanguage/apiv1beta/retriever_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/text_client.go b/ai/generativelanguage/apiv1beta/text_client.go index 2576e6b4cadc..67dd12ed10cb 100755 --- a/ai/generativelanguage/apiv1beta/text_client.go +++ b/ai/generativelanguage/apiv1beta/text_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/text_client_example_go123_test.go b/ai/generativelanguage/apiv1beta/text_client_example_go123_test.go index a77c12a163bb..5e3e9c42f0cb 100644 --- a/ai/generativelanguage/apiv1beta/text_client_example_go123_test.go +++ b/ai/generativelanguage/apiv1beta/text_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta/text_client_example_test.go b/ai/generativelanguage/apiv1beta/text_client_example_test.go index 000566903d4e..3cffee3b1f6c 100644 --- a/ai/generativelanguage/apiv1beta/text_client_example_test.go +++ b/ai/generativelanguage/apiv1beta/text_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta2/auxiliary.go b/ai/generativelanguage/apiv1beta2/auxiliary.go index aba9a84ba0d6..bc243b77fd6a 100755 --- a/ai/generativelanguage/apiv1beta2/auxiliary.go +++ b/ai/generativelanguage/apiv1beta2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta2/auxiliary_go123.go b/ai/generativelanguage/apiv1beta2/auxiliary_go123.go index 94c3bf3170cb..b108a647cf8b 100755 --- a/ai/generativelanguage/apiv1beta2/auxiliary_go123.go +++ b/ai/generativelanguage/apiv1beta2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta2/discuss_client.go b/ai/generativelanguage/apiv1beta2/discuss_client.go index 63df8b0ea576..aae573c24a55 100755 --- a/ai/generativelanguage/apiv1beta2/discuss_client.go +++ b/ai/generativelanguage/apiv1beta2/discuss_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta2/discuss_client_example_go123_test.go b/ai/generativelanguage/apiv1beta2/discuss_client_example_go123_test.go index 3f602dd4c7fd..d7ac312a9e53 100644 --- a/ai/generativelanguage/apiv1beta2/discuss_client_example_go123_test.go +++ b/ai/generativelanguage/apiv1beta2/discuss_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta2/discuss_client_example_test.go b/ai/generativelanguage/apiv1beta2/discuss_client_example_test.go index 139a64d2d3d8..b482804abfc0 100644 --- a/ai/generativelanguage/apiv1beta2/discuss_client_example_test.go +++ b/ai/generativelanguage/apiv1beta2/discuss_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta2/doc.go b/ai/generativelanguage/apiv1beta2/doc.go index 448678e4ecf5..e34736a10ee4 100755 --- a/ai/generativelanguage/apiv1beta2/doc.go +++ b/ai/generativelanguage/apiv1beta2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta2/helpers.go b/ai/generativelanguage/apiv1beta2/helpers.go index 101cfeee0c6f..e77bf1c5e0f2 100755 --- a/ai/generativelanguage/apiv1beta2/helpers.go +++ b/ai/generativelanguage/apiv1beta2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta2/model_client.go b/ai/generativelanguage/apiv1beta2/model_client.go index 9eee0fcf6dd5..650f020f9da8 100755 --- a/ai/generativelanguage/apiv1beta2/model_client.go +++ b/ai/generativelanguage/apiv1beta2/model_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta2/model_client_example_go123_test.go b/ai/generativelanguage/apiv1beta2/model_client_example_go123_test.go index 6973f090716f..f96214b0e9e0 100644 --- a/ai/generativelanguage/apiv1beta2/model_client_example_go123_test.go +++ b/ai/generativelanguage/apiv1beta2/model_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta2/model_client_example_test.go b/ai/generativelanguage/apiv1beta2/model_client_example_test.go index f34bbbe3b695..dbf83cd3020a 100644 --- a/ai/generativelanguage/apiv1beta2/model_client_example_test.go +++ b/ai/generativelanguage/apiv1beta2/model_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta2/text_client.go b/ai/generativelanguage/apiv1beta2/text_client.go index a160068f8ef3..3755e5bb901c 100755 --- a/ai/generativelanguage/apiv1beta2/text_client.go +++ b/ai/generativelanguage/apiv1beta2/text_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta2/text_client_example_go123_test.go b/ai/generativelanguage/apiv1beta2/text_client_example_go123_test.go index 3f602dd4c7fd..d7ac312a9e53 100644 --- a/ai/generativelanguage/apiv1beta2/text_client_example_go123_test.go +++ b/ai/generativelanguage/apiv1beta2/text_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ai/generativelanguage/apiv1beta2/text_client_example_test.go b/ai/generativelanguage/apiv1beta2/text_client_example_test.go index d0c2ead9735e..97822ca9b9e9 100644 --- a/ai/generativelanguage/apiv1beta2/text_client_example_test.go +++ b/ai/generativelanguage/apiv1beta2/text_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/auxiliary.go b/aiplatform/apiv1/auxiliary.go index c5f7772755e7..0f5ee74dee03 100755 --- a/aiplatform/apiv1/auxiliary.go +++ b/aiplatform/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/auxiliary_go123.go b/aiplatform/apiv1/auxiliary_go123.go index 084be520a4ab..cadcf0b05bea 100755 --- a/aiplatform/apiv1/auxiliary_go123.go +++ b/aiplatform/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/dataset_client.go b/aiplatform/apiv1/dataset_client.go index c009feeefae3..d6d3706d693a 100755 --- a/aiplatform/apiv1/dataset_client.go +++ b/aiplatform/apiv1/dataset_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/dataset_client_example_go123_test.go b/aiplatform/apiv1/dataset_client_example_go123_test.go index b756103ea72d..a1db8e2ff8a4 100644 --- a/aiplatform/apiv1/dataset_client_example_go123_test.go +++ b/aiplatform/apiv1/dataset_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/dataset_client_example_test.go b/aiplatform/apiv1/dataset_client_example_test.go index 812cf7f0dac0..f253ea217926 100644 --- a/aiplatform/apiv1/dataset_client_example_test.go +++ b/aiplatform/apiv1/dataset_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/deployment_resource_pool_client.go b/aiplatform/apiv1/deployment_resource_pool_client.go index 79f6bfea0fd1..a93ecf014177 100755 --- a/aiplatform/apiv1/deployment_resource_pool_client.go +++ b/aiplatform/apiv1/deployment_resource_pool_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/deployment_resource_pool_client_example_go123_test.go b/aiplatform/apiv1/deployment_resource_pool_client_example_go123_test.go index 1cf17c97c20f..9db53d9fdd7c 100644 --- a/aiplatform/apiv1/deployment_resource_pool_client_example_go123_test.go +++ b/aiplatform/apiv1/deployment_resource_pool_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/deployment_resource_pool_client_example_test.go b/aiplatform/apiv1/deployment_resource_pool_client_example_test.go index 263749d24002..9b2c924f840d 100644 --- a/aiplatform/apiv1/deployment_resource_pool_client_example_test.go +++ b/aiplatform/apiv1/deployment_resource_pool_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/doc.go b/aiplatform/apiv1/doc.go index 2ca8ceb1f31b..e8c16dddf58a 100755 --- a/aiplatform/apiv1/doc.go +++ b/aiplatform/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/endpoint_client.go b/aiplatform/apiv1/endpoint_client.go index ff6154a5e780..6c14a9676588 100755 --- a/aiplatform/apiv1/endpoint_client.go +++ b/aiplatform/apiv1/endpoint_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/endpoint_client_example_go123_test.go b/aiplatform/apiv1/endpoint_client_example_go123_test.go index d423cdf7f920..babddabe72c7 100644 --- a/aiplatform/apiv1/endpoint_client_example_go123_test.go +++ b/aiplatform/apiv1/endpoint_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/endpoint_client_example_test.go b/aiplatform/apiv1/endpoint_client_example_test.go index 07cfdfb5f3b3..40aa8aa7d3b3 100644 --- a/aiplatform/apiv1/endpoint_client_example_test.go +++ b/aiplatform/apiv1/endpoint_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/evaluation_client.go b/aiplatform/apiv1/evaluation_client.go index 8d203e35f901..45c920724340 100755 --- a/aiplatform/apiv1/evaluation_client.go +++ b/aiplatform/apiv1/evaluation_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/evaluation_client_example_go123_test.go b/aiplatform/apiv1/evaluation_client_example_go123_test.go index ba7edfcfb241..f9ff5eda53b2 100644 --- a/aiplatform/apiv1/evaluation_client_example_go123_test.go +++ b/aiplatform/apiv1/evaluation_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/evaluation_client_example_test.go b/aiplatform/apiv1/evaluation_client_example_test.go index 5fa3412216ef..01ad4a0a1195 100644 --- a/aiplatform/apiv1/evaluation_client_example_test.go +++ b/aiplatform/apiv1/evaluation_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/feature_online_store_admin_client.go b/aiplatform/apiv1/feature_online_store_admin_client.go index b65e51758cb7..bb2532e42c4d 100755 --- a/aiplatform/apiv1/feature_online_store_admin_client.go +++ b/aiplatform/apiv1/feature_online_store_admin_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/feature_online_store_admin_client_example_go123_test.go b/aiplatform/apiv1/feature_online_store_admin_client_example_go123_test.go index 59514fb2287e..d8d97f09ed0b 100644 --- a/aiplatform/apiv1/feature_online_store_admin_client_example_go123_test.go +++ b/aiplatform/apiv1/feature_online_store_admin_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/feature_online_store_admin_client_example_test.go b/aiplatform/apiv1/feature_online_store_admin_client_example_test.go index ab1db946d0a8..bfac5bfb7fdd 100644 --- a/aiplatform/apiv1/feature_online_store_admin_client_example_test.go +++ b/aiplatform/apiv1/feature_online_store_admin_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/feature_online_store_client.go b/aiplatform/apiv1/feature_online_store_client.go index 31ac5612a3a8..bff71d5d18c1 100755 --- a/aiplatform/apiv1/feature_online_store_client.go +++ b/aiplatform/apiv1/feature_online_store_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/feature_online_store_client_example_go123_test.go b/aiplatform/apiv1/feature_online_store_client_example_go123_test.go index 0b9632903714..5f76ad1c81df 100644 --- a/aiplatform/apiv1/feature_online_store_client_example_go123_test.go +++ b/aiplatform/apiv1/feature_online_store_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/feature_online_store_client_example_test.go b/aiplatform/apiv1/feature_online_store_client_example_test.go index a5ec690ba1ea..2fa4d3899415 100644 --- a/aiplatform/apiv1/feature_online_store_client_example_test.go +++ b/aiplatform/apiv1/feature_online_store_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/feature_registry_client.go b/aiplatform/apiv1/feature_registry_client.go index 1b3d4647ef8b..ee9171d863fc 100755 --- a/aiplatform/apiv1/feature_registry_client.go +++ b/aiplatform/apiv1/feature_registry_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/feature_registry_client_example_go123_test.go b/aiplatform/apiv1/feature_registry_client_example_go123_test.go index d6f7fb6da70c..dd8e9de50f60 100644 --- a/aiplatform/apiv1/feature_registry_client_example_go123_test.go +++ b/aiplatform/apiv1/feature_registry_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/feature_registry_client_example_test.go b/aiplatform/apiv1/feature_registry_client_example_test.go index 574c6df81c55..442fc6349438 100644 --- a/aiplatform/apiv1/feature_registry_client_example_test.go +++ b/aiplatform/apiv1/feature_registry_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/featurestore_client.go b/aiplatform/apiv1/featurestore_client.go index 423657382ed5..43ba24a07ebe 100755 --- a/aiplatform/apiv1/featurestore_client.go +++ b/aiplatform/apiv1/featurestore_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/featurestore_client_example_go123_test.go b/aiplatform/apiv1/featurestore_client_example_go123_test.go index f0b63275c07d..65daadee29f3 100644 --- a/aiplatform/apiv1/featurestore_client_example_go123_test.go +++ b/aiplatform/apiv1/featurestore_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/featurestore_client_example_test.go b/aiplatform/apiv1/featurestore_client_example_test.go index 9709b60ef515..6e3fbcbaae61 100644 --- a/aiplatform/apiv1/featurestore_client_example_test.go +++ b/aiplatform/apiv1/featurestore_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/featurestore_online_serving_client.go b/aiplatform/apiv1/featurestore_online_serving_client.go index c87905ecad31..42ed533eccda 100755 --- a/aiplatform/apiv1/featurestore_online_serving_client.go +++ b/aiplatform/apiv1/featurestore_online_serving_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/featurestore_online_serving_client_example_go123_test.go b/aiplatform/apiv1/featurestore_online_serving_client_example_go123_test.go index 4b4f2b391b35..29f5de701af5 100644 --- a/aiplatform/apiv1/featurestore_online_serving_client_example_go123_test.go +++ b/aiplatform/apiv1/featurestore_online_serving_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/featurestore_online_serving_client_example_test.go b/aiplatform/apiv1/featurestore_online_serving_client_example_test.go index 385238decbd0..095390393167 100644 --- a/aiplatform/apiv1/featurestore_online_serving_client_example_test.go +++ b/aiplatform/apiv1/featurestore_online_serving_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/gen_ai_tuning_client.go b/aiplatform/apiv1/gen_ai_tuning_client.go index acf354c0b3af..3f6737791296 100755 --- a/aiplatform/apiv1/gen_ai_tuning_client.go +++ b/aiplatform/apiv1/gen_ai_tuning_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/gen_ai_tuning_client_example_go123_test.go b/aiplatform/apiv1/gen_ai_tuning_client_example_go123_test.go index 916c4bc97ea8..11424011ff1a 100644 --- a/aiplatform/apiv1/gen_ai_tuning_client_example_go123_test.go +++ b/aiplatform/apiv1/gen_ai_tuning_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/gen_ai_tuning_client_example_test.go b/aiplatform/apiv1/gen_ai_tuning_client_example_test.go index 6c7dec049fbe..500403d9b678 100644 --- a/aiplatform/apiv1/gen_ai_tuning_client_example_test.go +++ b/aiplatform/apiv1/gen_ai_tuning_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/helpers.go b/aiplatform/apiv1/helpers.go index 2e7f7875c402..3e3c3d071097 100755 --- a/aiplatform/apiv1/helpers.go +++ b/aiplatform/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/index_client.go b/aiplatform/apiv1/index_client.go index 92613b37e1c7..401adcda5aba 100755 --- a/aiplatform/apiv1/index_client.go +++ b/aiplatform/apiv1/index_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/index_client_example_go123_test.go b/aiplatform/apiv1/index_client_example_go123_test.go index 4949c32c5add..f9fe5eb0600c 100644 --- a/aiplatform/apiv1/index_client_example_go123_test.go +++ b/aiplatform/apiv1/index_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/index_client_example_test.go b/aiplatform/apiv1/index_client_example_test.go index f2970d609b0e..a55c941174b9 100644 --- a/aiplatform/apiv1/index_client_example_test.go +++ b/aiplatform/apiv1/index_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/index_endpoint_client.go b/aiplatform/apiv1/index_endpoint_client.go index ff82b6534a56..e42f5e6fa2f2 100755 --- a/aiplatform/apiv1/index_endpoint_client.go +++ b/aiplatform/apiv1/index_endpoint_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/index_endpoint_client_example_go123_test.go b/aiplatform/apiv1/index_endpoint_client_example_go123_test.go index b82dcff11f48..f6a38210ac1d 100644 --- a/aiplatform/apiv1/index_endpoint_client_example_go123_test.go +++ b/aiplatform/apiv1/index_endpoint_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/index_endpoint_client_example_test.go b/aiplatform/apiv1/index_endpoint_client_example_test.go index b6e1533bde32..216c7df0047b 100644 --- a/aiplatform/apiv1/index_endpoint_client_example_test.go +++ b/aiplatform/apiv1/index_endpoint_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/job_client.go b/aiplatform/apiv1/job_client.go index 9c5f3571239e..64a0fef6a38f 100755 --- a/aiplatform/apiv1/job_client.go +++ b/aiplatform/apiv1/job_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/job_client_example_go123_test.go b/aiplatform/apiv1/job_client_example_go123_test.go index 2f90edacc214..c39f32592a77 100644 --- a/aiplatform/apiv1/job_client_example_go123_test.go +++ b/aiplatform/apiv1/job_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/job_client_example_test.go b/aiplatform/apiv1/job_client_example_test.go index 578b221766f8..46bcdaef4f66 100644 --- a/aiplatform/apiv1/job_client_example_test.go +++ b/aiplatform/apiv1/job_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/llm_utility_client.go b/aiplatform/apiv1/llm_utility_client.go index f44abf7c47aa..563c748412ad 100755 --- a/aiplatform/apiv1/llm_utility_client.go +++ b/aiplatform/apiv1/llm_utility_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/llm_utility_client_example_go123_test.go b/aiplatform/apiv1/llm_utility_client_example_go123_test.go index 6b3886553115..773ed02ae806 100644 --- a/aiplatform/apiv1/llm_utility_client_example_go123_test.go +++ b/aiplatform/apiv1/llm_utility_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/llm_utility_client_example_test.go b/aiplatform/apiv1/llm_utility_client_example_test.go index e7ca3de9583d..7e84e1d761bc 100644 --- a/aiplatform/apiv1/llm_utility_client_example_test.go +++ b/aiplatform/apiv1/llm_utility_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/match_client.go b/aiplatform/apiv1/match_client.go index db75d6863662..12c6247f9c20 100755 --- a/aiplatform/apiv1/match_client.go +++ b/aiplatform/apiv1/match_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/match_client_example_go123_test.go b/aiplatform/apiv1/match_client_example_go123_test.go index 89ff794185b8..066397c892f4 100644 --- a/aiplatform/apiv1/match_client_example_go123_test.go +++ b/aiplatform/apiv1/match_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/match_client_example_test.go b/aiplatform/apiv1/match_client_example_test.go index a94d1252c98e..bbbdabd46f6e 100644 --- a/aiplatform/apiv1/match_client_example_test.go +++ b/aiplatform/apiv1/match_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/metadata_client.go b/aiplatform/apiv1/metadata_client.go index f673a6df6389..36e0556c1b91 100755 --- a/aiplatform/apiv1/metadata_client.go +++ b/aiplatform/apiv1/metadata_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/metadata_client_example_go123_test.go b/aiplatform/apiv1/metadata_client_example_go123_test.go index 1fa75a8507a4..a4e4051f1812 100644 --- a/aiplatform/apiv1/metadata_client_example_go123_test.go +++ b/aiplatform/apiv1/metadata_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/metadata_client_example_test.go b/aiplatform/apiv1/metadata_client_example_test.go index 5407b3ef4894..6a849f96fd6a 100644 --- a/aiplatform/apiv1/metadata_client_example_test.go +++ b/aiplatform/apiv1/metadata_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/migration_client.go b/aiplatform/apiv1/migration_client.go index 195d7bad3c6f..b610e7a0116e 100755 --- a/aiplatform/apiv1/migration_client.go +++ b/aiplatform/apiv1/migration_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/migration_client_example_go123_test.go b/aiplatform/apiv1/migration_client_example_go123_test.go index e05e9f8bf3f9..46c9ac38b854 100644 --- a/aiplatform/apiv1/migration_client_example_go123_test.go +++ b/aiplatform/apiv1/migration_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/migration_client_example_test.go b/aiplatform/apiv1/migration_client_example_test.go index a49e9982faeb..abd312866acf 100644 --- a/aiplatform/apiv1/migration_client_example_test.go +++ b/aiplatform/apiv1/migration_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/model_client.go b/aiplatform/apiv1/model_client.go index 10263cd690a9..02e9098f5b97 100755 --- a/aiplatform/apiv1/model_client.go +++ b/aiplatform/apiv1/model_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/model_client_example_go123_test.go b/aiplatform/apiv1/model_client_example_go123_test.go index 358942542a9b..35f72326d0c7 100644 --- a/aiplatform/apiv1/model_client_example_go123_test.go +++ b/aiplatform/apiv1/model_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/model_client_example_test.go b/aiplatform/apiv1/model_client_example_test.go index 887372b4cb49..363b53bed230 100644 --- a/aiplatform/apiv1/model_client_example_test.go +++ b/aiplatform/apiv1/model_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/model_garden_client.go b/aiplatform/apiv1/model_garden_client.go index 0efd34a2a3bf..86a97e87db7f 100755 --- a/aiplatform/apiv1/model_garden_client.go +++ b/aiplatform/apiv1/model_garden_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/model_garden_client_example_go123_test.go b/aiplatform/apiv1/model_garden_client_example_go123_test.go index 6696e9e8e494..00b14363dcec 100644 --- a/aiplatform/apiv1/model_garden_client_example_go123_test.go +++ b/aiplatform/apiv1/model_garden_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/model_garden_client_example_test.go b/aiplatform/apiv1/model_garden_client_example_test.go index bd034ae5f073..0adbe7861109 100644 --- a/aiplatform/apiv1/model_garden_client_example_test.go +++ b/aiplatform/apiv1/model_garden_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/notebook_client.go b/aiplatform/apiv1/notebook_client.go index 7f06ed50da12..39603aa4578d 100755 --- a/aiplatform/apiv1/notebook_client.go +++ b/aiplatform/apiv1/notebook_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/notebook_client_example_go123_test.go b/aiplatform/apiv1/notebook_client_example_go123_test.go index 197da954e3de..43c803b9866c 100644 --- a/aiplatform/apiv1/notebook_client_example_go123_test.go +++ b/aiplatform/apiv1/notebook_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/notebook_client_example_test.go b/aiplatform/apiv1/notebook_client_example_test.go index 18cb464d08b5..5ac319ba66b7 100644 --- a/aiplatform/apiv1/notebook_client_example_test.go +++ b/aiplatform/apiv1/notebook_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/persistent_resource_client.go b/aiplatform/apiv1/persistent_resource_client.go index b061b60c9a3b..fe792a3115f3 100755 --- a/aiplatform/apiv1/persistent_resource_client.go +++ b/aiplatform/apiv1/persistent_resource_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/persistent_resource_client_example_go123_test.go b/aiplatform/apiv1/persistent_resource_client_example_go123_test.go index 931592a6672d..6a02b32a9271 100644 --- a/aiplatform/apiv1/persistent_resource_client_example_go123_test.go +++ b/aiplatform/apiv1/persistent_resource_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/persistent_resource_client_example_test.go b/aiplatform/apiv1/persistent_resource_client_example_test.go index 668ceb1f2ca5..7e356663a0cf 100644 --- a/aiplatform/apiv1/persistent_resource_client_example_test.go +++ b/aiplatform/apiv1/persistent_resource_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/pipeline_client.go b/aiplatform/apiv1/pipeline_client.go index c648e26b9671..b4af10728fc6 100755 --- a/aiplatform/apiv1/pipeline_client.go +++ b/aiplatform/apiv1/pipeline_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/pipeline_client_example_go123_test.go b/aiplatform/apiv1/pipeline_client_example_go123_test.go index e0f010ad2977..96b85c51a11a 100644 --- a/aiplatform/apiv1/pipeline_client_example_go123_test.go +++ b/aiplatform/apiv1/pipeline_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/pipeline_client_example_test.go b/aiplatform/apiv1/pipeline_client_example_test.go index 9468af8b60a4..16360f8ca33e 100644 --- a/aiplatform/apiv1/pipeline_client_example_test.go +++ b/aiplatform/apiv1/pipeline_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/prediction_client.go b/aiplatform/apiv1/prediction_client.go index 9613fffac846..9241eb8ade72 100755 --- a/aiplatform/apiv1/prediction_client.go +++ b/aiplatform/apiv1/prediction_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/prediction_client_example_go123_test.go b/aiplatform/apiv1/prediction_client_example_go123_test.go index a6cac2f92a41..23eac24b94f4 100644 --- a/aiplatform/apiv1/prediction_client_example_go123_test.go +++ b/aiplatform/apiv1/prediction_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/prediction_client_example_test.go b/aiplatform/apiv1/prediction_client_example_test.go index 9fd35d474abf..2016532ec4eb 100644 --- a/aiplatform/apiv1/prediction_client_example_test.go +++ b/aiplatform/apiv1/prediction_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/schedule_client.go b/aiplatform/apiv1/schedule_client.go index bc30ffb10321..40eacf014c58 100755 --- a/aiplatform/apiv1/schedule_client.go +++ b/aiplatform/apiv1/schedule_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/schedule_client_example_go123_test.go b/aiplatform/apiv1/schedule_client_example_go123_test.go index 5d9e87c11084..d1b887d7836a 100644 --- a/aiplatform/apiv1/schedule_client_example_go123_test.go +++ b/aiplatform/apiv1/schedule_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/schedule_client_example_test.go b/aiplatform/apiv1/schedule_client_example_test.go index 7197bdcf7c47..dab0711c8bff 100644 --- a/aiplatform/apiv1/schedule_client_example_test.go +++ b/aiplatform/apiv1/schedule_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/specialist_pool_client.go b/aiplatform/apiv1/specialist_pool_client.go index 0446a91380f7..78e9705704c7 100755 --- a/aiplatform/apiv1/specialist_pool_client.go +++ b/aiplatform/apiv1/specialist_pool_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/specialist_pool_client_example_go123_test.go b/aiplatform/apiv1/specialist_pool_client_example_go123_test.go index a4fbc3aefdf9..05305efc1014 100644 --- a/aiplatform/apiv1/specialist_pool_client_example_go123_test.go +++ b/aiplatform/apiv1/specialist_pool_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/specialist_pool_client_example_test.go b/aiplatform/apiv1/specialist_pool_client_example_test.go index 3e5cba6345c5..00ccad3c42c6 100644 --- a/aiplatform/apiv1/specialist_pool_client_example_test.go +++ b/aiplatform/apiv1/specialist_pool_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/tensorboard_client.go b/aiplatform/apiv1/tensorboard_client.go index a697fe531f61..4981b195d0cf 100755 --- a/aiplatform/apiv1/tensorboard_client.go +++ b/aiplatform/apiv1/tensorboard_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/tensorboard_client_example_go123_test.go b/aiplatform/apiv1/tensorboard_client_example_go123_test.go index d3efd571c449..c998b664221c 100644 --- a/aiplatform/apiv1/tensorboard_client_example_go123_test.go +++ b/aiplatform/apiv1/tensorboard_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/tensorboard_client_example_test.go b/aiplatform/apiv1/tensorboard_client_example_test.go index 73b467cce3d9..f7e6bc187994 100644 --- a/aiplatform/apiv1/tensorboard_client_example_test.go +++ b/aiplatform/apiv1/tensorboard_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/vertex_rag_client.go b/aiplatform/apiv1/vertex_rag_client.go index 520776c712f3..760cccf9a55c 100755 --- a/aiplatform/apiv1/vertex_rag_client.go +++ b/aiplatform/apiv1/vertex_rag_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/vertex_rag_client_example_go123_test.go b/aiplatform/apiv1/vertex_rag_client_example_go123_test.go index 19baabad92a9..08339ef9254c 100644 --- a/aiplatform/apiv1/vertex_rag_client_example_go123_test.go +++ b/aiplatform/apiv1/vertex_rag_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/vertex_rag_client_example_test.go b/aiplatform/apiv1/vertex_rag_client_example_test.go index 038e9a038b45..79e0c3766ba4 100644 --- a/aiplatform/apiv1/vertex_rag_client_example_test.go +++ b/aiplatform/apiv1/vertex_rag_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/vertex_rag_data_client.go b/aiplatform/apiv1/vertex_rag_data_client.go index b0af1b64c60b..658a4730a55e 100755 --- a/aiplatform/apiv1/vertex_rag_data_client.go +++ b/aiplatform/apiv1/vertex_rag_data_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/vertex_rag_data_client_example_go123_test.go b/aiplatform/apiv1/vertex_rag_data_client_example_go123_test.go index 468de9a92f73..3ed70f14af72 100644 --- a/aiplatform/apiv1/vertex_rag_data_client_example_go123_test.go +++ b/aiplatform/apiv1/vertex_rag_data_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/vertex_rag_data_client_example_test.go b/aiplatform/apiv1/vertex_rag_data_client_example_test.go index 5884487ed089..eeec08e4f5ff 100644 --- a/aiplatform/apiv1/vertex_rag_data_client_example_test.go +++ b/aiplatform/apiv1/vertex_rag_data_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/vizier_client.go b/aiplatform/apiv1/vizier_client.go index 648a47b32b02..e51b30d01afe 100755 --- a/aiplatform/apiv1/vizier_client.go +++ b/aiplatform/apiv1/vizier_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/vizier_client_example_go123_test.go b/aiplatform/apiv1/vizier_client_example_go123_test.go index 5a3ec0ae19d2..8db9e4aa957a 100644 --- a/aiplatform/apiv1/vizier_client_example_go123_test.go +++ b/aiplatform/apiv1/vizier_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1/vizier_client_example_test.go b/aiplatform/apiv1/vizier_client_example_test.go index dfb2b0575d7a..74111b56b8ff 100644 --- a/aiplatform/apiv1/vizier_client_example_test.go +++ b/aiplatform/apiv1/vizier_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/auxiliary.go b/aiplatform/apiv1beta1/auxiliary.go index 3e0183787ce2..b36da1676105 100755 --- a/aiplatform/apiv1beta1/auxiliary.go +++ b/aiplatform/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/auxiliary_go123.go b/aiplatform/apiv1beta1/auxiliary_go123.go index 8827b319fe7a..34f55c071183 100755 --- a/aiplatform/apiv1beta1/auxiliary_go123.go +++ b/aiplatform/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/dataset_client.go b/aiplatform/apiv1beta1/dataset_client.go index 91481e4f205c..9ab01048ee44 100755 --- a/aiplatform/apiv1beta1/dataset_client.go +++ b/aiplatform/apiv1beta1/dataset_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/dataset_client_example_go123_test.go b/aiplatform/apiv1beta1/dataset_client_example_go123_test.go index 99968fbc189d..d4202f12de50 100644 --- a/aiplatform/apiv1beta1/dataset_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/dataset_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/dataset_client_example_test.go b/aiplatform/apiv1beta1/dataset_client_example_test.go index 259f6a970b48..c0bc25a53b7e 100644 --- a/aiplatform/apiv1beta1/dataset_client_example_test.go +++ b/aiplatform/apiv1beta1/dataset_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/deployment_resource_pool_client.go b/aiplatform/apiv1beta1/deployment_resource_pool_client.go index 545741e75112..f30a06cedd02 100755 --- a/aiplatform/apiv1beta1/deployment_resource_pool_client.go +++ b/aiplatform/apiv1beta1/deployment_resource_pool_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/deployment_resource_pool_client_example_go123_test.go b/aiplatform/apiv1beta1/deployment_resource_pool_client_example_go123_test.go index 1bc05522a63b..c8d819500506 100644 --- a/aiplatform/apiv1beta1/deployment_resource_pool_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/deployment_resource_pool_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/deployment_resource_pool_client_example_test.go b/aiplatform/apiv1beta1/deployment_resource_pool_client_example_test.go index 4fcdc1ba3e18..aa0ca28f837f 100644 --- a/aiplatform/apiv1beta1/deployment_resource_pool_client_example_test.go +++ b/aiplatform/apiv1beta1/deployment_resource_pool_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/doc.go b/aiplatform/apiv1beta1/doc.go index 10e54d5628d5..f8ee9ce30863 100755 --- a/aiplatform/apiv1beta1/doc.go +++ b/aiplatform/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/endpoint_client.go b/aiplatform/apiv1beta1/endpoint_client.go index 8a86ddf4a549..a8893130c309 100755 --- a/aiplatform/apiv1beta1/endpoint_client.go +++ b/aiplatform/apiv1beta1/endpoint_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/endpoint_client_example_go123_test.go b/aiplatform/apiv1beta1/endpoint_client_example_go123_test.go index 419e63596ba2..edfd74d91ef5 100644 --- a/aiplatform/apiv1beta1/endpoint_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/endpoint_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/endpoint_client_example_test.go b/aiplatform/apiv1beta1/endpoint_client_example_test.go index ec695ad8323d..3d4a2d2eec44 100644 --- a/aiplatform/apiv1beta1/endpoint_client_example_test.go +++ b/aiplatform/apiv1beta1/endpoint_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/evaluation_client.go b/aiplatform/apiv1beta1/evaluation_client.go index b89a2186a63d..a4d440de69ec 100755 --- a/aiplatform/apiv1beta1/evaluation_client.go +++ b/aiplatform/apiv1beta1/evaluation_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/evaluation_client_example_go123_test.go b/aiplatform/apiv1beta1/evaluation_client_example_go123_test.go index 1a996236f364..9629fe5b7f3e 100644 --- a/aiplatform/apiv1beta1/evaluation_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/evaluation_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/evaluation_client_example_test.go b/aiplatform/apiv1beta1/evaluation_client_example_test.go index db3ca876853a..cf72541d7d9c 100644 --- a/aiplatform/apiv1beta1/evaluation_client_example_test.go +++ b/aiplatform/apiv1beta1/evaluation_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/extension_execution_client.go b/aiplatform/apiv1beta1/extension_execution_client.go index dbca5169c748..563a5e3efa85 100755 --- a/aiplatform/apiv1beta1/extension_execution_client.go +++ b/aiplatform/apiv1beta1/extension_execution_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/extension_execution_client_example_go123_test.go b/aiplatform/apiv1beta1/extension_execution_client_example_go123_test.go index 8432522390c9..edcb12ab3651 100644 --- a/aiplatform/apiv1beta1/extension_execution_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/extension_execution_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/extension_execution_client_example_test.go b/aiplatform/apiv1beta1/extension_execution_client_example_test.go index 880ccf8e8912..8e97a6026c15 100644 --- a/aiplatform/apiv1beta1/extension_execution_client_example_test.go +++ b/aiplatform/apiv1beta1/extension_execution_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/extension_registry_client.go b/aiplatform/apiv1beta1/extension_registry_client.go index 5cb421a75ee4..91e6a6ac2797 100755 --- a/aiplatform/apiv1beta1/extension_registry_client.go +++ b/aiplatform/apiv1beta1/extension_registry_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/extension_registry_client_example_go123_test.go b/aiplatform/apiv1beta1/extension_registry_client_example_go123_test.go index 8e80ac01f917..8d5d74836dd4 100644 --- a/aiplatform/apiv1beta1/extension_registry_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/extension_registry_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/extension_registry_client_example_test.go b/aiplatform/apiv1beta1/extension_registry_client_example_test.go index 0e568e6accbb..ea3c92770596 100644 --- a/aiplatform/apiv1beta1/extension_registry_client_example_test.go +++ b/aiplatform/apiv1beta1/extension_registry_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/feature_online_store_admin_client.go b/aiplatform/apiv1beta1/feature_online_store_admin_client.go index b84ea05e9d6f..8302d8506164 100755 --- a/aiplatform/apiv1beta1/feature_online_store_admin_client.go +++ b/aiplatform/apiv1beta1/feature_online_store_admin_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/feature_online_store_admin_client_example_go123_test.go b/aiplatform/apiv1beta1/feature_online_store_admin_client_example_go123_test.go index b66d3b6086e0..7baa3ac2405f 100644 --- a/aiplatform/apiv1beta1/feature_online_store_admin_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/feature_online_store_admin_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/feature_online_store_admin_client_example_test.go b/aiplatform/apiv1beta1/feature_online_store_admin_client_example_test.go index 88610738b154..4bc2d2e7628c 100644 --- a/aiplatform/apiv1beta1/feature_online_store_admin_client_example_test.go +++ b/aiplatform/apiv1beta1/feature_online_store_admin_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/feature_online_store_client.go b/aiplatform/apiv1beta1/feature_online_store_client.go index 69dc85fcb138..b1c56ca8317c 100755 --- a/aiplatform/apiv1beta1/feature_online_store_client.go +++ b/aiplatform/apiv1beta1/feature_online_store_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/feature_online_store_client_example_go123_test.go b/aiplatform/apiv1beta1/feature_online_store_client_example_go123_test.go index d659633726ab..29c12192df2f 100644 --- a/aiplatform/apiv1beta1/feature_online_store_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/feature_online_store_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/feature_online_store_client_example_test.go b/aiplatform/apiv1beta1/feature_online_store_client_example_test.go index 246f617e84fe..9884385f1a8f 100644 --- a/aiplatform/apiv1beta1/feature_online_store_client_example_test.go +++ b/aiplatform/apiv1beta1/feature_online_store_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/feature_registry_client.go b/aiplatform/apiv1beta1/feature_registry_client.go index f525d41512db..7013e6771fcb 100755 --- a/aiplatform/apiv1beta1/feature_registry_client.go +++ b/aiplatform/apiv1beta1/feature_registry_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/feature_registry_client_example_go123_test.go b/aiplatform/apiv1beta1/feature_registry_client_example_go123_test.go index 2a96c9669e4a..aa53664947f4 100644 --- a/aiplatform/apiv1beta1/feature_registry_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/feature_registry_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/feature_registry_client_example_test.go b/aiplatform/apiv1beta1/feature_registry_client_example_test.go index e19488c55ee9..3a4515c76651 100644 --- a/aiplatform/apiv1beta1/feature_registry_client_example_test.go +++ b/aiplatform/apiv1beta1/feature_registry_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/featurestore_client.go b/aiplatform/apiv1beta1/featurestore_client.go index 1373c1d398d7..919055667824 100755 --- a/aiplatform/apiv1beta1/featurestore_client.go +++ b/aiplatform/apiv1beta1/featurestore_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/featurestore_client_example_go123_test.go b/aiplatform/apiv1beta1/featurestore_client_example_go123_test.go index 9198e6a547c4..c7e4f7ffb5a2 100644 --- a/aiplatform/apiv1beta1/featurestore_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/featurestore_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/featurestore_client_example_test.go b/aiplatform/apiv1beta1/featurestore_client_example_test.go index 9f19799b91ac..d5d336e6319c 100644 --- a/aiplatform/apiv1beta1/featurestore_client_example_test.go +++ b/aiplatform/apiv1beta1/featurestore_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/featurestore_online_serving_client.go b/aiplatform/apiv1beta1/featurestore_online_serving_client.go index 5a1ef39aa7c4..7b080d08efcc 100755 --- a/aiplatform/apiv1beta1/featurestore_online_serving_client.go +++ b/aiplatform/apiv1beta1/featurestore_online_serving_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/featurestore_online_serving_client_example_go123_test.go b/aiplatform/apiv1beta1/featurestore_online_serving_client_example_go123_test.go index 9221b79a1cad..74bfa65b253e 100644 --- a/aiplatform/apiv1beta1/featurestore_online_serving_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/featurestore_online_serving_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/featurestore_online_serving_client_example_test.go b/aiplatform/apiv1beta1/featurestore_online_serving_client_example_test.go index 68ac9d7907fe..7d7a7d9720b1 100644 --- a/aiplatform/apiv1beta1/featurestore_online_serving_client_example_test.go +++ b/aiplatform/apiv1beta1/featurestore_online_serving_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/gen_ai_cache_client.go b/aiplatform/apiv1beta1/gen_ai_cache_client.go index 46802f9fbe58..09f74fe51571 100755 --- a/aiplatform/apiv1beta1/gen_ai_cache_client.go +++ b/aiplatform/apiv1beta1/gen_ai_cache_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/gen_ai_cache_client_example_go123_test.go b/aiplatform/apiv1beta1/gen_ai_cache_client_example_go123_test.go index b1204be180ce..b6a5e09d0981 100644 --- a/aiplatform/apiv1beta1/gen_ai_cache_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/gen_ai_cache_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/gen_ai_cache_client_example_test.go b/aiplatform/apiv1beta1/gen_ai_cache_client_example_test.go index 66341ba7f2e4..4fe1bdeba9e2 100644 --- a/aiplatform/apiv1beta1/gen_ai_cache_client_example_test.go +++ b/aiplatform/apiv1beta1/gen_ai_cache_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/gen_ai_tuning_client.go b/aiplatform/apiv1beta1/gen_ai_tuning_client.go index 4423a7ca17d9..d0a341450f22 100755 --- a/aiplatform/apiv1beta1/gen_ai_tuning_client.go +++ b/aiplatform/apiv1beta1/gen_ai_tuning_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/gen_ai_tuning_client_example_go123_test.go b/aiplatform/apiv1beta1/gen_ai_tuning_client_example_go123_test.go index ee96b7fa8376..defd53be880a 100644 --- a/aiplatform/apiv1beta1/gen_ai_tuning_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/gen_ai_tuning_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/gen_ai_tuning_client_example_test.go b/aiplatform/apiv1beta1/gen_ai_tuning_client_example_test.go index 84c9f3c28d02..cd9621ad92d3 100644 --- a/aiplatform/apiv1beta1/gen_ai_tuning_client_example_test.go +++ b/aiplatform/apiv1beta1/gen_ai_tuning_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/helpers.go b/aiplatform/apiv1beta1/helpers.go index b6618b503385..21b1a9c45739 100755 --- a/aiplatform/apiv1beta1/helpers.go +++ b/aiplatform/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/index_client.go b/aiplatform/apiv1beta1/index_client.go index 581ffd28a321..4246e8405db8 100755 --- a/aiplatform/apiv1beta1/index_client.go +++ b/aiplatform/apiv1beta1/index_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/index_client_example_go123_test.go b/aiplatform/apiv1beta1/index_client_example_go123_test.go index b1a169896450..f51c8699d954 100644 --- a/aiplatform/apiv1beta1/index_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/index_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/index_client_example_test.go b/aiplatform/apiv1beta1/index_client_example_test.go index 841a690f8982..e46aacc5d43c 100644 --- a/aiplatform/apiv1beta1/index_client_example_test.go +++ b/aiplatform/apiv1beta1/index_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/index_endpoint_client.go b/aiplatform/apiv1beta1/index_endpoint_client.go index b92123f5ee7b..902ca6a85a28 100755 --- a/aiplatform/apiv1beta1/index_endpoint_client.go +++ b/aiplatform/apiv1beta1/index_endpoint_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/index_endpoint_client_example_go123_test.go b/aiplatform/apiv1beta1/index_endpoint_client_example_go123_test.go index df77b0d80c0f..d3727a6d4878 100644 --- a/aiplatform/apiv1beta1/index_endpoint_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/index_endpoint_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/index_endpoint_client_example_test.go b/aiplatform/apiv1beta1/index_endpoint_client_example_test.go index 01964cc52ada..fcb509d2f858 100644 --- a/aiplatform/apiv1beta1/index_endpoint_client_example_test.go +++ b/aiplatform/apiv1beta1/index_endpoint_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/job_client.go b/aiplatform/apiv1beta1/job_client.go index 4dfac38d7ae9..6839ab3e1c1d 100755 --- a/aiplatform/apiv1beta1/job_client.go +++ b/aiplatform/apiv1beta1/job_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/job_client_example_go123_test.go b/aiplatform/apiv1beta1/job_client_example_go123_test.go index 9f59cbd6d792..604bbbff0bba 100644 --- a/aiplatform/apiv1beta1/job_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/job_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/job_client_example_test.go b/aiplatform/apiv1beta1/job_client_example_test.go index 1943b0cc12f0..85fac5e2fef8 100644 --- a/aiplatform/apiv1beta1/job_client_example_test.go +++ b/aiplatform/apiv1beta1/job_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/llm_utility_client.go b/aiplatform/apiv1beta1/llm_utility_client.go index 666b2333f96d..8afdf611ee93 100755 --- a/aiplatform/apiv1beta1/llm_utility_client.go +++ b/aiplatform/apiv1beta1/llm_utility_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/llm_utility_client_example_go123_test.go b/aiplatform/apiv1beta1/llm_utility_client_example_go123_test.go index e0af70cb9b94..dd365d4addf8 100644 --- a/aiplatform/apiv1beta1/llm_utility_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/llm_utility_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/llm_utility_client_example_test.go b/aiplatform/apiv1beta1/llm_utility_client_example_test.go index 257291f0e790..8db6d947ef7f 100644 --- a/aiplatform/apiv1beta1/llm_utility_client_example_test.go +++ b/aiplatform/apiv1beta1/llm_utility_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/match_client.go b/aiplatform/apiv1beta1/match_client.go index ee94bb139593..b48cb52e58c8 100755 --- a/aiplatform/apiv1beta1/match_client.go +++ b/aiplatform/apiv1beta1/match_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/match_client_example_go123_test.go b/aiplatform/apiv1beta1/match_client_example_go123_test.go index f7e99420e1e4..af80b0f1f244 100644 --- a/aiplatform/apiv1beta1/match_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/match_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/match_client_example_test.go b/aiplatform/apiv1beta1/match_client_example_test.go index 2ec09c425bbe..c63d3c490e66 100644 --- a/aiplatform/apiv1beta1/match_client_example_test.go +++ b/aiplatform/apiv1beta1/match_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/metadata_client.go b/aiplatform/apiv1beta1/metadata_client.go index 8cea233c2fc5..e9ee6a120554 100755 --- a/aiplatform/apiv1beta1/metadata_client.go +++ b/aiplatform/apiv1beta1/metadata_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/metadata_client_example_go123_test.go b/aiplatform/apiv1beta1/metadata_client_example_go123_test.go index ea3dfadcef37..165f5add1bca 100644 --- a/aiplatform/apiv1beta1/metadata_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/metadata_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/metadata_client_example_test.go b/aiplatform/apiv1beta1/metadata_client_example_test.go index 36f44649edec..d6657c5d0027 100644 --- a/aiplatform/apiv1beta1/metadata_client_example_test.go +++ b/aiplatform/apiv1beta1/metadata_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/migration_client.go b/aiplatform/apiv1beta1/migration_client.go index a8f115e1d9bd..4d0ec79727dc 100755 --- a/aiplatform/apiv1beta1/migration_client.go +++ b/aiplatform/apiv1beta1/migration_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/migration_client_example_go123_test.go b/aiplatform/apiv1beta1/migration_client_example_go123_test.go index 3b02aa2aee97..2b6e026b4ce8 100644 --- a/aiplatform/apiv1beta1/migration_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/migration_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/migration_client_example_test.go b/aiplatform/apiv1beta1/migration_client_example_test.go index f62cac9fcdfb..d3a259df58b2 100644 --- a/aiplatform/apiv1beta1/migration_client_example_test.go +++ b/aiplatform/apiv1beta1/migration_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/model_client.go b/aiplatform/apiv1beta1/model_client.go index a55d46478ee7..86bdd55ab4be 100755 --- a/aiplatform/apiv1beta1/model_client.go +++ b/aiplatform/apiv1beta1/model_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/model_client_example_go123_test.go b/aiplatform/apiv1beta1/model_client_example_go123_test.go index 11395244ed48..c5e6008c5e92 100644 --- a/aiplatform/apiv1beta1/model_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/model_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/model_client_example_test.go b/aiplatform/apiv1beta1/model_client_example_test.go index c6acb545b014..15d52bf1bc2c 100644 --- a/aiplatform/apiv1beta1/model_client_example_test.go +++ b/aiplatform/apiv1beta1/model_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/model_garden_client.go b/aiplatform/apiv1beta1/model_garden_client.go index 97c7e1f18c0b..ef33a59d4b62 100755 --- a/aiplatform/apiv1beta1/model_garden_client.go +++ b/aiplatform/apiv1beta1/model_garden_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/model_garden_client_example_go123_test.go b/aiplatform/apiv1beta1/model_garden_client_example_go123_test.go index 17be37e20c4d..2c3a721ee9db 100644 --- a/aiplatform/apiv1beta1/model_garden_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/model_garden_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/model_garden_client_example_test.go b/aiplatform/apiv1beta1/model_garden_client_example_test.go index 5b11e67f5a8d..c43b4f2dbd56 100644 --- a/aiplatform/apiv1beta1/model_garden_client_example_test.go +++ b/aiplatform/apiv1beta1/model_garden_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/model_monitoring_client.go b/aiplatform/apiv1beta1/model_monitoring_client.go index c7342b4de5d1..ddb2fc713467 100755 --- a/aiplatform/apiv1beta1/model_monitoring_client.go +++ b/aiplatform/apiv1beta1/model_monitoring_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/model_monitoring_client_example_go123_test.go b/aiplatform/apiv1beta1/model_monitoring_client_example_go123_test.go index d74f5b5d1f33..53c92faf7ccb 100644 --- a/aiplatform/apiv1beta1/model_monitoring_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/model_monitoring_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/model_monitoring_client_example_test.go b/aiplatform/apiv1beta1/model_monitoring_client_example_test.go index 14589a8147fd..751bf0568992 100644 --- a/aiplatform/apiv1beta1/model_monitoring_client_example_test.go +++ b/aiplatform/apiv1beta1/model_monitoring_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/notebook_client.go b/aiplatform/apiv1beta1/notebook_client.go index aed896318a43..ceeb88225c64 100755 --- a/aiplatform/apiv1beta1/notebook_client.go +++ b/aiplatform/apiv1beta1/notebook_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/notebook_client_example_go123_test.go b/aiplatform/apiv1beta1/notebook_client_example_go123_test.go index 267d6a4b1359..f91d8257e120 100644 --- a/aiplatform/apiv1beta1/notebook_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/notebook_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/notebook_client_example_test.go b/aiplatform/apiv1beta1/notebook_client_example_test.go index b2d9267595e7..fe84907ce999 100644 --- a/aiplatform/apiv1beta1/notebook_client_example_test.go +++ b/aiplatform/apiv1beta1/notebook_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/persistent_resource_client.go b/aiplatform/apiv1beta1/persistent_resource_client.go index 7db74cb51696..44e707b92634 100755 --- a/aiplatform/apiv1beta1/persistent_resource_client.go +++ b/aiplatform/apiv1beta1/persistent_resource_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/persistent_resource_client_example_go123_test.go b/aiplatform/apiv1beta1/persistent_resource_client_example_go123_test.go index 51194fe482a2..6f93b57b10ff 100644 --- a/aiplatform/apiv1beta1/persistent_resource_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/persistent_resource_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/persistent_resource_client_example_test.go b/aiplatform/apiv1beta1/persistent_resource_client_example_test.go index 1577dee94833..a1247a4cf3b5 100644 --- a/aiplatform/apiv1beta1/persistent_resource_client_example_test.go +++ b/aiplatform/apiv1beta1/persistent_resource_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/pipeline_client.go b/aiplatform/apiv1beta1/pipeline_client.go index 2626d39c747f..ef925136e925 100755 --- a/aiplatform/apiv1beta1/pipeline_client.go +++ b/aiplatform/apiv1beta1/pipeline_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/pipeline_client_example_go123_test.go b/aiplatform/apiv1beta1/pipeline_client_example_go123_test.go index c292db95de35..4c168ea0d5c9 100644 --- a/aiplatform/apiv1beta1/pipeline_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/pipeline_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/pipeline_client_example_test.go b/aiplatform/apiv1beta1/pipeline_client_example_test.go index 18b2dfcb67fe..ff09b7c6a184 100644 --- a/aiplatform/apiv1beta1/pipeline_client_example_test.go +++ b/aiplatform/apiv1beta1/pipeline_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/prediction_client.go b/aiplatform/apiv1beta1/prediction_client.go index e63c1f4a0091..6b6b49108922 100755 --- a/aiplatform/apiv1beta1/prediction_client.go +++ b/aiplatform/apiv1beta1/prediction_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/prediction_client_example_go123_test.go b/aiplatform/apiv1beta1/prediction_client_example_go123_test.go index effc0d389302..2f7f5d995174 100644 --- a/aiplatform/apiv1beta1/prediction_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/prediction_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/prediction_client_example_test.go b/aiplatform/apiv1beta1/prediction_client_example_test.go index c368087def04..c1b3d47d1870 100644 --- a/aiplatform/apiv1beta1/prediction_client_example_test.go +++ b/aiplatform/apiv1beta1/prediction_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/reasoning_engine_client.go b/aiplatform/apiv1beta1/reasoning_engine_client.go index 6590d189902f..9a8744929ce3 100755 --- a/aiplatform/apiv1beta1/reasoning_engine_client.go +++ b/aiplatform/apiv1beta1/reasoning_engine_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/reasoning_engine_client_example_go123_test.go b/aiplatform/apiv1beta1/reasoning_engine_client_example_go123_test.go index 07c0a4a159e6..729371e1eeab 100644 --- a/aiplatform/apiv1beta1/reasoning_engine_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/reasoning_engine_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/reasoning_engine_client_example_test.go b/aiplatform/apiv1beta1/reasoning_engine_client_example_test.go index 7c0c2739f4c3..aeaf168b8e9b 100644 --- a/aiplatform/apiv1beta1/reasoning_engine_client_example_test.go +++ b/aiplatform/apiv1beta1/reasoning_engine_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/reasoning_engine_execution_client.go b/aiplatform/apiv1beta1/reasoning_engine_execution_client.go index d4ea7ba5185d..9df9e3f61021 100755 --- a/aiplatform/apiv1beta1/reasoning_engine_execution_client.go +++ b/aiplatform/apiv1beta1/reasoning_engine_execution_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/reasoning_engine_execution_client_example_go123_test.go b/aiplatform/apiv1beta1/reasoning_engine_execution_client_example_go123_test.go index ebd4a110f44f..058a8263c7c8 100644 --- a/aiplatform/apiv1beta1/reasoning_engine_execution_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/reasoning_engine_execution_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/reasoning_engine_execution_client_example_test.go b/aiplatform/apiv1beta1/reasoning_engine_execution_client_example_test.go index 0270fff07d53..5abcde156f73 100644 --- a/aiplatform/apiv1beta1/reasoning_engine_execution_client_example_test.go +++ b/aiplatform/apiv1beta1/reasoning_engine_execution_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/schedule_client.go b/aiplatform/apiv1beta1/schedule_client.go index 3a55159de9e0..38f76c98eaf2 100755 --- a/aiplatform/apiv1beta1/schedule_client.go +++ b/aiplatform/apiv1beta1/schedule_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/schedule_client_example_go123_test.go b/aiplatform/apiv1beta1/schedule_client_example_go123_test.go index 61d793dc9a1c..5544c3228eb4 100644 --- a/aiplatform/apiv1beta1/schedule_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/schedule_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/schedule_client_example_test.go b/aiplatform/apiv1beta1/schedule_client_example_test.go index aeefbcd2e255..2cd4d051b0ac 100644 --- a/aiplatform/apiv1beta1/schedule_client_example_test.go +++ b/aiplatform/apiv1beta1/schedule_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/specialist_pool_client.go b/aiplatform/apiv1beta1/specialist_pool_client.go index a6562f1f2d1a..f7fcb238391f 100755 --- a/aiplatform/apiv1beta1/specialist_pool_client.go +++ b/aiplatform/apiv1beta1/specialist_pool_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/specialist_pool_client_example_go123_test.go b/aiplatform/apiv1beta1/specialist_pool_client_example_go123_test.go index 03b0d4a115e0..19ca43726e18 100644 --- a/aiplatform/apiv1beta1/specialist_pool_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/specialist_pool_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/specialist_pool_client_example_test.go b/aiplatform/apiv1beta1/specialist_pool_client_example_test.go index 7bedcd73bc23..7504aacc0d88 100644 --- a/aiplatform/apiv1beta1/specialist_pool_client_example_test.go +++ b/aiplatform/apiv1beta1/specialist_pool_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/tensorboard_client.go b/aiplatform/apiv1beta1/tensorboard_client.go index f06b54906485..8b81fcf3ab7a 100755 --- a/aiplatform/apiv1beta1/tensorboard_client.go +++ b/aiplatform/apiv1beta1/tensorboard_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/tensorboard_client_example_go123_test.go b/aiplatform/apiv1beta1/tensorboard_client_example_go123_test.go index b85494bfe62b..5cbe1a0436a4 100644 --- a/aiplatform/apiv1beta1/tensorboard_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/tensorboard_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/tensorboard_client_example_test.go b/aiplatform/apiv1beta1/tensorboard_client_example_test.go index e01db400ac47..6e5b95cff9b4 100644 --- a/aiplatform/apiv1beta1/tensorboard_client_example_test.go +++ b/aiplatform/apiv1beta1/tensorboard_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/vertex_rag_client.go b/aiplatform/apiv1beta1/vertex_rag_client.go index 1c948e9bd343..31fbbf8f617e 100755 --- a/aiplatform/apiv1beta1/vertex_rag_client.go +++ b/aiplatform/apiv1beta1/vertex_rag_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/vertex_rag_client_example_go123_test.go b/aiplatform/apiv1beta1/vertex_rag_client_example_go123_test.go index 89bba1a8e6b5..1c8840a1164c 100644 --- a/aiplatform/apiv1beta1/vertex_rag_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/vertex_rag_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/vertex_rag_client_example_test.go b/aiplatform/apiv1beta1/vertex_rag_client_example_test.go index 02c5092aceab..d7af69cac058 100644 --- a/aiplatform/apiv1beta1/vertex_rag_client_example_test.go +++ b/aiplatform/apiv1beta1/vertex_rag_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/vertex_rag_data_client.go b/aiplatform/apiv1beta1/vertex_rag_data_client.go index 401cd0b06b18..72f40e8e3d97 100755 --- a/aiplatform/apiv1beta1/vertex_rag_data_client.go +++ b/aiplatform/apiv1beta1/vertex_rag_data_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/vertex_rag_data_client_example_go123_test.go b/aiplatform/apiv1beta1/vertex_rag_data_client_example_go123_test.go index 5c3c98b2e686..a560d013ef85 100644 --- a/aiplatform/apiv1beta1/vertex_rag_data_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/vertex_rag_data_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/vertex_rag_data_client_example_test.go b/aiplatform/apiv1beta1/vertex_rag_data_client_example_test.go index 39bbde8cc0d9..97055d82961a 100644 --- a/aiplatform/apiv1beta1/vertex_rag_data_client_example_test.go +++ b/aiplatform/apiv1beta1/vertex_rag_data_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/vizier_client.go b/aiplatform/apiv1beta1/vizier_client.go index 80744e39b6ca..b6f7b4d04022 100755 --- a/aiplatform/apiv1beta1/vizier_client.go +++ b/aiplatform/apiv1beta1/vizier_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/vizier_client_example_go123_test.go b/aiplatform/apiv1beta1/vizier_client_example_go123_test.go index 0e60c28c9abf..2dd3d7550089 100644 --- a/aiplatform/apiv1beta1/vizier_client_example_go123_test.go +++ b/aiplatform/apiv1beta1/vizier_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/aiplatform/apiv1beta1/vizier_client_example_test.go b/aiplatform/apiv1beta1/vizier_client_example_test.go index 4d6b8f9b033a..387e12fbe437 100644 --- a/aiplatform/apiv1beta1/vizier_client_example_test.go +++ b/aiplatform/apiv1beta1/vizier_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/alloydb/apiv1/alloydb_admin_client.go b/alloydb/apiv1/alloydb_admin_client.go index 7f15d1104271..77dc6db7624b 100755 --- a/alloydb/apiv1/alloydb_admin_client.go +++ b/alloydb/apiv1/alloydb_admin_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/alloydb/apiv1/alloydb_admin_client_example_go123_test.go b/alloydb/apiv1/alloydb_admin_client_example_go123_test.go index 88c4770522d7..f42fa168a819 100644 --- a/alloydb/apiv1/alloydb_admin_client_example_go123_test.go +++ b/alloydb/apiv1/alloydb_admin_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/alloydb/apiv1/alloydb_admin_client_example_test.go b/alloydb/apiv1/alloydb_admin_client_example_test.go index 6dab3400eb2b..e25926b4646c 100644 --- a/alloydb/apiv1/alloydb_admin_client_example_test.go +++ b/alloydb/apiv1/alloydb_admin_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/alloydb/apiv1/auxiliary.go b/alloydb/apiv1/auxiliary.go index c3fb69d90828..b83ea100c15d 100755 --- a/alloydb/apiv1/auxiliary.go +++ b/alloydb/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/alloydb/apiv1/auxiliary_go123.go b/alloydb/apiv1/auxiliary_go123.go index 09546e084d7e..ca465998c25d 100755 --- a/alloydb/apiv1/auxiliary_go123.go +++ b/alloydb/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/alloydb/apiv1/doc.go b/alloydb/apiv1/doc.go index 913108da46c5..e136b2694485 100755 --- a/alloydb/apiv1/doc.go +++ b/alloydb/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/alloydb/apiv1/helpers.go b/alloydb/apiv1/helpers.go index df94a97ef621..55ba7fc71a47 100755 --- a/alloydb/apiv1/helpers.go +++ b/alloydb/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/alloydb/apiv1alpha/alloydb_admin_client.go b/alloydb/apiv1alpha/alloydb_admin_client.go index e476f0b1adfc..cef914b8e339 100755 --- a/alloydb/apiv1alpha/alloydb_admin_client.go +++ b/alloydb/apiv1alpha/alloydb_admin_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/alloydb/apiv1alpha/alloydb_admin_client_example_go123_test.go b/alloydb/apiv1alpha/alloydb_admin_client_example_go123_test.go index b94044e9466a..9727fa642c6d 100644 --- a/alloydb/apiv1alpha/alloydb_admin_client_example_go123_test.go +++ b/alloydb/apiv1alpha/alloydb_admin_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/alloydb/apiv1alpha/alloydb_admin_client_example_test.go b/alloydb/apiv1alpha/alloydb_admin_client_example_test.go index 94f33ae1bec9..db871fce9f8a 100644 --- a/alloydb/apiv1alpha/alloydb_admin_client_example_test.go +++ b/alloydb/apiv1alpha/alloydb_admin_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/alloydb/apiv1alpha/auxiliary.go b/alloydb/apiv1alpha/auxiliary.go index cc30d7c2d793..9b24e692834c 100755 --- a/alloydb/apiv1alpha/auxiliary.go +++ b/alloydb/apiv1alpha/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/alloydb/apiv1alpha/auxiliary_go123.go b/alloydb/apiv1alpha/auxiliary_go123.go index edd32e5b79b7..c6835382232f 100755 --- a/alloydb/apiv1alpha/auxiliary_go123.go +++ b/alloydb/apiv1alpha/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/alloydb/apiv1alpha/doc.go b/alloydb/apiv1alpha/doc.go index c6a2671d3379..34305f1b7863 100755 --- a/alloydb/apiv1alpha/doc.go +++ b/alloydb/apiv1alpha/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/alloydb/apiv1alpha/helpers.go b/alloydb/apiv1alpha/helpers.go index df94a97ef621..55ba7fc71a47 100755 --- a/alloydb/apiv1alpha/helpers.go +++ b/alloydb/apiv1alpha/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/alloydb/apiv1beta/alloydb_admin_client.go b/alloydb/apiv1beta/alloydb_admin_client.go index 5dde041bf957..81ea3a5df7a3 100755 --- a/alloydb/apiv1beta/alloydb_admin_client.go +++ b/alloydb/apiv1beta/alloydb_admin_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/alloydb/apiv1beta/alloydb_admin_client_example_go123_test.go b/alloydb/apiv1beta/alloydb_admin_client_example_go123_test.go index a7f3250a78d0..948c6e564b86 100644 --- a/alloydb/apiv1beta/alloydb_admin_client_example_go123_test.go +++ b/alloydb/apiv1beta/alloydb_admin_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/alloydb/apiv1beta/alloydb_admin_client_example_test.go b/alloydb/apiv1beta/alloydb_admin_client_example_test.go index 8a9e327550ed..80ed09f4326d 100644 --- a/alloydb/apiv1beta/alloydb_admin_client_example_test.go +++ b/alloydb/apiv1beta/alloydb_admin_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/alloydb/apiv1beta/auxiliary.go b/alloydb/apiv1beta/auxiliary.go index 58080ca78694..cd903a7a0e3f 100755 --- a/alloydb/apiv1beta/auxiliary.go +++ b/alloydb/apiv1beta/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/alloydb/apiv1beta/auxiliary_go123.go b/alloydb/apiv1beta/auxiliary_go123.go index 3743285800a8..1e20fd4bd6f6 100755 --- a/alloydb/apiv1beta/auxiliary_go123.go +++ b/alloydb/apiv1beta/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/alloydb/apiv1beta/doc.go b/alloydb/apiv1beta/doc.go index 60f2cf723a8d..7ab1b5af7daa 100755 --- a/alloydb/apiv1beta/doc.go +++ b/alloydb/apiv1beta/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/alloydb/apiv1beta/helpers.go b/alloydb/apiv1beta/helpers.go index df94a97ef621..55ba7fc71a47 100755 --- a/alloydb/apiv1beta/helpers.go +++ b/alloydb/apiv1beta/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/analytics/admin/apiv1alpha/analytics_admin_client.go b/analytics/admin/apiv1alpha/analytics_admin_client.go index d3f1358f97f8..906c4cfacee1 100755 --- a/analytics/admin/apiv1alpha/analytics_admin_client.go +++ b/analytics/admin/apiv1alpha/analytics_admin_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/analytics/admin/apiv1alpha/analytics_admin_client_example_go123_test.go b/analytics/admin/apiv1alpha/analytics_admin_client_example_go123_test.go index 9a403d66058e..832b6229c715 100644 --- a/analytics/admin/apiv1alpha/analytics_admin_client_example_go123_test.go +++ b/analytics/admin/apiv1alpha/analytics_admin_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/analytics/admin/apiv1alpha/analytics_admin_client_example_test.go b/analytics/admin/apiv1alpha/analytics_admin_client_example_test.go index 0ef9953c93bf..b0b25b3e31d6 100644 --- a/analytics/admin/apiv1alpha/analytics_admin_client_example_test.go +++ b/analytics/admin/apiv1alpha/analytics_admin_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/analytics/admin/apiv1alpha/auxiliary.go b/analytics/admin/apiv1alpha/auxiliary.go index ed240d83308a..55c2ba65b0e1 100755 --- a/analytics/admin/apiv1alpha/auxiliary.go +++ b/analytics/admin/apiv1alpha/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/analytics/admin/apiv1alpha/auxiliary_go123.go b/analytics/admin/apiv1alpha/auxiliary_go123.go index 93236c2c0bb6..e20d13e06156 100755 --- a/analytics/admin/apiv1alpha/auxiliary_go123.go +++ b/analytics/admin/apiv1alpha/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/analytics/admin/apiv1alpha/doc.go b/analytics/admin/apiv1alpha/doc.go index 9200d6418194..88407871b63d 100755 --- a/analytics/admin/apiv1alpha/doc.go +++ b/analytics/admin/apiv1alpha/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/analytics/admin/apiv1alpha/helpers.go b/analytics/admin/apiv1alpha/helpers.go index 6b43620a5ac0..cf3f7f5451a0 100755 --- a/analytics/admin/apiv1alpha/helpers.go +++ b/analytics/admin/apiv1alpha/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apigateway/apiv1/api_gateway_client.go b/apigateway/apiv1/api_gateway_client.go index aa73315fb9ee..2675ce414f7e 100755 --- a/apigateway/apiv1/api_gateway_client.go +++ b/apigateway/apiv1/api_gateway_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apigateway/apiv1/api_gateway_client_example_go123_test.go b/apigateway/apiv1/api_gateway_client_example_go123_test.go index 7c8f48edbf8c..12819693ced8 100644 --- a/apigateway/apiv1/api_gateway_client_example_go123_test.go +++ b/apigateway/apiv1/api_gateway_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apigateway/apiv1/api_gateway_client_example_test.go b/apigateway/apiv1/api_gateway_client_example_test.go index 451c14a49ee3..b1fbab720eab 100644 --- a/apigateway/apiv1/api_gateway_client_example_test.go +++ b/apigateway/apiv1/api_gateway_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apigateway/apiv1/auxiliary.go b/apigateway/apiv1/auxiliary.go index 874db64c08f4..e6ac01e2fb04 100755 --- a/apigateway/apiv1/auxiliary.go +++ b/apigateway/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apigateway/apiv1/auxiliary_go123.go b/apigateway/apiv1/auxiliary_go123.go index 3f5a6900e2ce..a6a97e377a83 100755 --- a/apigateway/apiv1/auxiliary_go123.go +++ b/apigateway/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apigateway/apiv1/doc.go b/apigateway/apiv1/doc.go index 62590150619a..d2d30ef30608 100755 --- a/apigateway/apiv1/doc.go +++ b/apigateway/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apigateway/apiv1/helpers.go b/apigateway/apiv1/helpers.go index 331568e0b11e..f0506f945810 100755 --- a/apigateway/apiv1/helpers.go +++ b/apigateway/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apigeeconnect/apiv1/auxiliary.go b/apigeeconnect/apiv1/auxiliary.go index a6ef46b53a83..d931661a6438 100755 --- a/apigeeconnect/apiv1/auxiliary.go +++ b/apigeeconnect/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apigeeconnect/apiv1/auxiliary_go123.go b/apigeeconnect/apiv1/auxiliary_go123.go index 5dd0d5021f49..be937d0d0da8 100755 --- a/apigeeconnect/apiv1/auxiliary_go123.go +++ b/apigeeconnect/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apigeeconnect/apiv1/connection_client.go b/apigeeconnect/apiv1/connection_client.go index 82914efd59bb..6063ac92c03b 100755 --- a/apigeeconnect/apiv1/connection_client.go +++ b/apigeeconnect/apiv1/connection_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apigeeconnect/apiv1/connection_client_example_go123_test.go b/apigeeconnect/apiv1/connection_client_example_go123_test.go index a4bba47fd3f6..f9357cc19901 100644 --- a/apigeeconnect/apiv1/connection_client_example_go123_test.go +++ b/apigeeconnect/apiv1/connection_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apigeeconnect/apiv1/connection_client_example_test.go b/apigeeconnect/apiv1/connection_client_example_test.go index fd6961735d42..bb4945fff250 100644 --- a/apigeeconnect/apiv1/connection_client_example_test.go +++ b/apigeeconnect/apiv1/connection_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apigeeconnect/apiv1/doc.go b/apigeeconnect/apiv1/doc.go index 820ab45aae3d..8f75451f1dd6 100755 --- a/apigeeconnect/apiv1/doc.go +++ b/apigeeconnect/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apigeeconnect/apiv1/helpers.go b/apigeeconnect/apiv1/helpers.go index e20e8a97c76e..47b11d9c78d0 100755 --- a/apigeeconnect/apiv1/helpers.go +++ b/apigeeconnect/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apigeeconnect/apiv1/tether_client.go b/apigeeconnect/apiv1/tether_client.go index 58be3fa1d476..734881daae8b 100755 --- a/apigeeconnect/apiv1/tether_client.go +++ b/apigeeconnect/apiv1/tether_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apigeeconnect/apiv1/tether_client_example_go123_test.go b/apigeeconnect/apiv1/tether_client_example_go123_test.go index 583686fb715f..7d6cf75b8ff0 100644 --- a/apigeeconnect/apiv1/tether_client_example_go123_test.go +++ b/apigeeconnect/apiv1/tether_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apigeeconnect/apiv1/tether_client_example_test.go b/apigeeconnect/apiv1/tether_client_example_test.go index f081825c8efa..ecc71891b597 100644 --- a/apigeeconnect/apiv1/tether_client_example_test.go +++ b/apigeeconnect/apiv1/tether_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apigeeregistry/apiv1/auxiliary.go b/apigeeregistry/apiv1/auxiliary.go index f297518559f2..ac6a81c58f28 100755 --- a/apigeeregistry/apiv1/auxiliary.go +++ b/apigeeregistry/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apigeeregistry/apiv1/auxiliary_go123.go b/apigeeregistry/apiv1/auxiliary_go123.go index cfbb0181b505..36339d1f3205 100755 --- a/apigeeregistry/apiv1/auxiliary_go123.go +++ b/apigeeregistry/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apigeeregistry/apiv1/doc.go b/apigeeregistry/apiv1/doc.go index c007053b3c5f..6cb6ac78561b 100755 --- a/apigeeregistry/apiv1/doc.go +++ b/apigeeregistry/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apigeeregistry/apiv1/helpers.go b/apigeeregistry/apiv1/helpers.go index 0e0cb33c6499..0f1540f8180a 100755 --- a/apigeeregistry/apiv1/helpers.go +++ b/apigeeregistry/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apigeeregistry/apiv1/provisioning_client.go b/apigeeregistry/apiv1/provisioning_client.go index 3771c8337abe..fa7ebff88b9d 100755 --- a/apigeeregistry/apiv1/provisioning_client.go +++ b/apigeeregistry/apiv1/provisioning_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apigeeregistry/apiv1/provisioning_client_example_go123_test.go b/apigeeregistry/apiv1/provisioning_client_example_go123_test.go index 2414a4e1e589..62f14ecc98a0 100644 --- a/apigeeregistry/apiv1/provisioning_client_example_go123_test.go +++ b/apigeeregistry/apiv1/provisioning_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apigeeregistry/apiv1/provisioning_client_example_test.go b/apigeeregistry/apiv1/provisioning_client_example_test.go index f3c1af482317..1d892f5279cf 100644 --- a/apigeeregistry/apiv1/provisioning_client_example_test.go +++ b/apigeeregistry/apiv1/provisioning_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apigeeregistry/apiv1/registry_client.go b/apigeeregistry/apiv1/registry_client.go index 8287b11c7ca1..8b6879ca62b0 100755 --- a/apigeeregistry/apiv1/registry_client.go +++ b/apigeeregistry/apiv1/registry_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apigeeregistry/apiv1/registry_client_example_go123_test.go b/apigeeregistry/apiv1/registry_client_example_go123_test.go index a9e8921a091f..2dffac7b66f2 100644 --- a/apigeeregistry/apiv1/registry_client_example_go123_test.go +++ b/apigeeregistry/apiv1/registry_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apigeeregistry/apiv1/registry_client_example_test.go b/apigeeregistry/apiv1/registry_client_example_test.go index e5446a93dced..a2e81474aacf 100644 --- a/apigeeregistry/apiv1/registry_client_example_test.go +++ b/apigeeregistry/apiv1/registry_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apihub/apiv1/api_hub_client.go b/apihub/apiv1/api_hub_client.go index 87978de755a3..2f4448a545ac 100755 --- a/apihub/apiv1/api_hub_client.go +++ b/apihub/apiv1/api_hub_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apihub/apiv1/api_hub_client_example_go123_test.go b/apihub/apiv1/api_hub_client_example_go123_test.go index 0beacd278966..4cc31423c9de 100644 --- a/apihub/apiv1/api_hub_client_example_go123_test.go +++ b/apihub/apiv1/api_hub_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apihub/apiv1/api_hub_client_example_test.go b/apihub/apiv1/api_hub_client_example_test.go index 3fd94ecd96a4..c32b8e331c39 100644 --- a/apihub/apiv1/api_hub_client_example_test.go +++ b/apihub/apiv1/api_hub_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apihub/apiv1/api_hub_dependencies_client.go b/apihub/apiv1/api_hub_dependencies_client.go index a58a0cc27c83..2f924eb85392 100755 --- a/apihub/apiv1/api_hub_dependencies_client.go +++ b/apihub/apiv1/api_hub_dependencies_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apihub/apiv1/api_hub_dependencies_client_example_go123_test.go b/apihub/apiv1/api_hub_dependencies_client_example_go123_test.go index 206ab2def495..3ae5bf0170dd 100644 --- a/apihub/apiv1/api_hub_dependencies_client_example_go123_test.go +++ b/apihub/apiv1/api_hub_dependencies_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apihub/apiv1/api_hub_dependencies_client_example_test.go b/apihub/apiv1/api_hub_dependencies_client_example_test.go index da86cdbb664e..59a7af3ab3a4 100644 --- a/apihub/apiv1/api_hub_dependencies_client_example_test.go +++ b/apihub/apiv1/api_hub_dependencies_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apihub/apiv1/api_hub_plugin_client.go b/apihub/apiv1/api_hub_plugin_client.go index 39c6205c23ea..86d2e373815c 100755 --- a/apihub/apiv1/api_hub_plugin_client.go +++ b/apihub/apiv1/api_hub_plugin_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apihub/apiv1/api_hub_plugin_client_example_go123_test.go b/apihub/apiv1/api_hub_plugin_client_example_go123_test.go index e588eb8cce14..4ed974919a46 100644 --- a/apihub/apiv1/api_hub_plugin_client_example_go123_test.go +++ b/apihub/apiv1/api_hub_plugin_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apihub/apiv1/api_hub_plugin_client_example_test.go b/apihub/apiv1/api_hub_plugin_client_example_test.go index a011621f5582..3124e87abc73 100644 --- a/apihub/apiv1/api_hub_plugin_client_example_test.go +++ b/apihub/apiv1/api_hub_plugin_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apihub/apiv1/auxiliary.go b/apihub/apiv1/auxiliary.go index 5cc39d5d3614..81088fbc60a3 100755 --- a/apihub/apiv1/auxiliary.go +++ b/apihub/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apihub/apiv1/auxiliary_go123.go b/apihub/apiv1/auxiliary_go123.go index 70b5145b1df7..2fe9c913f1c0 100755 --- a/apihub/apiv1/auxiliary_go123.go +++ b/apihub/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apihub/apiv1/doc.go b/apihub/apiv1/doc.go index cfcabe03c387..b3c3929886ce 100755 --- a/apihub/apiv1/doc.go +++ b/apihub/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apihub/apiv1/helpers.go b/apihub/apiv1/helpers.go index 6b090c3ca5f8..724bec686f86 100755 --- a/apihub/apiv1/helpers.go +++ b/apihub/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apihub/apiv1/host_project_registration_client.go b/apihub/apiv1/host_project_registration_client.go index b003d1ab38d8..798157982db7 100755 --- a/apihub/apiv1/host_project_registration_client.go +++ b/apihub/apiv1/host_project_registration_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apihub/apiv1/host_project_registration_client_example_go123_test.go b/apihub/apiv1/host_project_registration_client_example_go123_test.go index b978b3123d4d..09e82db6e3d2 100644 --- a/apihub/apiv1/host_project_registration_client_example_go123_test.go +++ b/apihub/apiv1/host_project_registration_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apihub/apiv1/host_project_registration_client_example_test.go b/apihub/apiv1/host_project_registration_client_example_test.go index 2f3481fadf94..481578dffb73 100644 --- a/apihub/apiv1/host_project_registration_client_example_test.go +++ b/apihub/apiv1/host_project_registration_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apihub/apiv1/linting_client.go b/apihub/apiv1/linting_client.go index f69aaef4dec6..ee1c32810ba1 100755 --- a/apihub/apiv1/linting_client.go +++ b/apihub/apiv1/linting_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apihub/apiv1/linting_client_example_go123_test.go b/apihub/apiv1/linting_client_example_go123_test.go index 9bc99525e0a4..78fc027ba787 100644 --- a/apihub/apiv1/linting_client_example_go123_test.go +++ b/apihub/apiv1/linting_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apihub/apiv1/linting_client_example_test.go b/apihub/apiv1/linting_client_example_test.go index 6a92c611439f..bc31dd192d2b 100644 --- a/apihub/apiv1/linting_client_example_test.go +++ b/apihub/apiv1/linting_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apihub/apiv1/provisioning_client.go b/apihub/apiv1/provisioning_client.go index 6ce24985456b..02a7b815dd5e 100755 --- a/apihub/apiv1/provisioning_client.go +++ b/apihub/apiv1/provisioning_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apihub/apiv1/provisioning_client_example_go123_test.go b/apihub/apiv1/provisioning_client_example_go123_test.go index 5b7df4c16e30..6edd9e00ae4b 100644 --- a/apihub/apiv1/provisioning_client_example_go123_test.go +++ b/apihub/apiv1/provisioning_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apihub/apiv1/provisioning_client_example_test.go b/apihub/apiv1/provisioning_client_example_test.go index 85e55ea83880..ab171f362bfa 100644 --- a/apihub/apiv1/provisioning_client_example_test.go +++ b/apihub/apiv1/provisioning_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apihub/apiv1/runtime_project_attachment_client.go b/apihub/apiv1/runtime_project_attachment_client.go index 3d6f5f784854..3146393ce621 100755 --- a/apihub/apiv1/runtime_project_attachment_client.go +++ b/apihub/apiv1/runtime_project_attachment_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apihub/apiv1/runtime_project_attachment_client_example_go123_test.go b/apihub/apiv1/runtime_project_attachment_client_example_go123_test.go index 72d536ed59ed..b1285cb78ee7 100644 --- a/apihub/apiv1/runtime_project_attachment_client_example_go123_test.go +++ b/apihub/apiv1/runtime_project_attachment_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apihub/apiv1/runtime_project_attachment_client_example_test.go b/apihub/apiv1/runtime_project_attachment_client_example_test.go index 5d07687d0f5f..4d2e0f6348d8 100644 --- a/apihub/apiv1/runtime_project_attachment_client_example_test.go +++ b/apihub/apiv1/runtime_project_attachment_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apikeys/apiv2/api_keys_client.go b/apikeys/apiv2/api_keys_client.go index 76915831441f..4ec6b67f0105 100755 --- a/apikeys/apiv2/api_keys_client.go +++ b/apikeys/apiv2/api_keys_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apikeys/apiv2/api_keys_client_example_go123_test.go b/apikeys/apiv2/api_keys_client_example_go123_test.go index b4bb6387d102..c1dca4579357 100644 --- a/apikeys/apiv2/api_keys_client_example_go123_test.go +++ b/apikeys/apiv2/api_keys_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apikeys/apiv2/api_keys_client_example_test.go b/apikeys/apiv2/api_keys_client_example_test.go index 2546bfb0f95e..026259a6c818 100644 --- a/apikeys/apiv2/api_keys_client_example_test.go +++ b/apikeys/apiv2/api_keys_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apikeys/apiv2/auxiliary.go b/apikeys/apiv2/auxiliary.go index 8943b2482275..a902075847f7 100755 --- a/apikeys/apiv2/auxiliary.go +++ b/apikeys/apiv2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apikeys/apiv2/auxiliary_go123.go b/apikeys/apiv2/auxiliary_go123.go index e9ca3000fe10..0b66cf344724 100755 --- a/apikeys/apiv2/auxiliary_go123.go +++ b/apikeys/apiv2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apikeys/apiv2/doc.go b/apikeys/apiv2/doc.go index b5042f53bc0b..220f6df70230 100755 --- a/apikeys/apiv2/doc.go +++ b/apikeys/apiv2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apikeys/apiv2/helpers.go b/apikeys/apiv2/helpers.go index 62fcc3871c97..5c6e2ffb8af2 100755 --- a/apikeys/apiv2/helpers.go +++ b/apikeys/apiv2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/appengine/apiv1/applications_client.go b/appengine/apiv1/applications_client.go index 0da4f178b58f..a7f18ae4497a 100755 --- a/appengine/apiv1/applications_client.go +++ b/appengine/apiv1/applications_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/appengine/apiv1/applications_client_example_go123_test.go b/appengine/apiv1/applications_client_example_go123_test.go index 355832b3c2a4..e7c70d38ad4b 100644 --- a/appengine/apiv1/applications_client_example_go123_test.go +++ b/appengine/apiv1/applications_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/appengine/apiv1/applications_client_example_test.go b/appengine/apiv1/applications_client_example_test.go index 10d5dfa63e2f..b18f1ae25467 100644 --- a/appengine/apiv1/applications_client_example_test.go +++ b/appengine/apiv1/applications_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/appengine/apiv1/authorized_certificates_client.go b/appengine/apiv1/authorized_certificates_client.go index 41d8404363f0..a0d47cddaf23 100755 --- a/appengine/apiv1/authorized_certificates_client.go +++ b/appengine/apiv1/authorized_certificates_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/appengine/apiv1/authorized_certificates_client_example_go123_test.go b/appengine/apiv1/authorized_certificates_client_example_go123_test.go index 663a32bfccdc..bd100fd9efd6 100644 --- a/appengine/apiv1/authorized_certificates_client_example_go123_test.go +++ b/appengine/apiv1/authorized_certificates_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/appengine/apiv1/authorized_certificates_client_example_test.go b/appengine/apiv1/authorized_certificates_client_example_test.go index 8c5bbb8392e5..321497fb8a2b 100644 --- a/appengine/apiv1/authorized_certificates_client_example_test.go +++ b/appengine/apiv1/authorized_certificates_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/appengine/apiv1/authorized_domains_client.go b/appengine/apiv1/authorized_domains_client.go index 1a1e37594ef0..bdc9000d1182 100755 --- a/appengine/apiv1/authorized_domains_client.go +++ b/appengine/apiv1/authorized_domains_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/appengine/apiv1/authorized_domains_client_example_go123_test.go b/appengine/apiv1/authorized_domains_client_example_go123_test.go index e12812234510..0b221dccfc3c 100644 --- a/appengine/apiv1/authorized_domains_client_example_go123_test.go +++ b/appengine/apiv1/authorized_domains_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/appengine/apiv1/authorized_domains_client_example_test.go b/appengine/apiv1/authorized_domains_client_example_test.go index b4c106eba35b..ffd35a60e2da 100644 --- a/appengine/apiv1/authorized_domains_client_example_test.go +++ b/appengine/apiv1/authorized_domains_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/appengine/apiv1/auxiliary.go b/appengine/apiv1/auxiliary.go index ce29a2094376..045600595fec 100755 --- a/appengine/apiv1/auxiliary.go +++ b/appengine/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/appengine/apiv1/auxiliary_go123.go b/appengine/apiv1/auxiliary_go123.go index a440f5ebe4b7..ddbfc3791639 100755 --- a/appengine/apiv1/auxiliary_go123.go +++ b/appengine/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/appengine/apiv1/doc.go b/appengine/apiv1/doc.go index f6bdc13c1142..6f46179b16ce 100755 --- a/appengine/apiv1/doc.go +++ b/appengine/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/appengine/apiv1/domain_mappings_client.go b/appengine/apiv1/domain_mappings_client.go index 658682d99487..1d7a42fcc11c 100755 --- a/appengine/apiv1/domain_mappings_client.go +++ b/appengine/apiv1/domain_mappings_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/appengine/apiv1/domain_mappings_client_example_go123_test.go b/appengine/apiv1/domain_mappings_client_example_go123_test.go index 9840894be461..ab3f23c94e7a 100644 --- a/appengine/apiv1/domain_mappings_client_example_go123_test.go +++ b/appengine/apiv1/domain_mappings_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/appengine/apiv1/domain_mappings_client_example_test.go b/appengine/apiv1/domain_mappings_client_example_test.go index ea4f08bf3ddf..952e68f99430 100644 --- a/appengine/apiv1/domain_mappings_client_example_test.go +++ b/appengine/apiv1/domain_mappings_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/appengine/apiv1/firewall_client.go b/appengine/apiv1/firewall_client.go index 7d426fac2a85..80832abe7b1f 100755 --- a/appengine/apiv1/firewall_client.go +++ b/appengine/apiv1/firewall_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/appengine/apiv1/firewall_client_example_go123_test.go b/appengine/apiv1/firewall_client_example_go123_test.go index a9330ebfaffb..d435a82300ff 100644 --- a/appengine/apiv1/firewall_client_example_go123_test.go +++ b/appengine/apiv1/firewall_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/appengine/apiv1/firewall_client_example_test.go b/appengine/apiv1/firewall_client_example_test.go index 288fea8bcb8e..7fd67c1a76c7 100644 --- a/appengine/apiv1/firewall_client_example_test.go +++ b/appengine/apiv1/firewall_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/appengine/apiv1/helpers.go b/appengine/apiv1/helpers.go index 8a15933d458b..7da006dd2c9a 100755 --- a/appengine/apiv1/helpers.go +++ b/appengine/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/appengine/apiv1/instances_client.go b/appengine/apiv1/instances_client.go index 61687c7793f1..9f22d350d51b 100755 --- a/appengine/apiv1/instances_client.go +++ b/appengine/apiv1/instances_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/appengine/apiv1/instances_client_example_go123_test.go b/appengine/apiv1/instances_client_example_go123_test.go index 1fbfc5fbde10..6738a27430e5 100644 --- a/appengine/apiv1/instances_client_example_go123_test.go +++ b/appengine/apiv1/instances_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/appengine/apiv1/instances_client_example_test.go b/appengine/apiv1/instances_client_example_test.go index 2ad15a019a06..ea98be7e49bc 100644 --- a/appengine/apiv1/instances_client_example_test.go +++ b/appengine/apiv1/instances_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/appengine/apiv1/services_client.go b/appengine/apiv1/services_client.go index 5e38dfda849b..c0d061be0482 100755 --- a/appengine/apiv1/services_client.go +++ b/appengine/apiv1/services_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/appengine/apiv1/services_client_example_go123_test.go b/appengine/apiv1/services_client_example_go123_test.go index 245341b021b3..c13d2c5c43af 100644 --- a/appengine/apiv1/services_client_example_go123_test.go +++ b/appengine/apiv1/services_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/appengine/apiv1/services_client_example_test.go b/appengine/apiv1/services_client_example_test.go index e3148644fdff..a965600e34c3 100644 --- a/appengine/apiv1/services_client_example_test.go +++ b/appengine/apiv1/services_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/appengine/apiv1/versions_client.go b/appengine/apiv1/versions_client.go index a3e03274a57a..1f5188c8229c 100755 --- a/appengine/apiv1/versions_client.go +++ b/appengine/apiv1/versions_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/appengine/apiv1/versions_client_example_go123_test.go b/appengine/apiv1/versions_client_example_go123_test.go index 2af0c30f5b95..1ea53aa40f40 100644 --- a/appengine/apiv1/versions_client_example_go123_test.go +++ b/appengine/apiv1/versions_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/appengine/apiv1/versions_client_example_test.go b/appengine/apiv1/versions_client_example_test.go index 5561ae890b60..890b6041c622 100644 --- a/appengine/apiv1/versions_client_example_test.go +++ b/appengine/apiv1/versions_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apphub/apiv1/app_hub_client.go b/apphub/apiv1/app_hub_client.go index dfcd9094ef70..5a4a0de2a2c8 100755 --- a/apphub/apiv1/app_hub_client.go +++ b/apphub/apiv1/app_hub_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apphub/apiv1/app_hub_client_example_go123_test.go b/apphub/apiv1/app_hub_client_example_go123_test.go index b4005ccd80db..a9737dfcb4f2 100644 --- a/apphub/apiv1/app_hub_client_example_go123_test.go +++ b/apphub/apiv1/app_hub_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apphub/apiv1/app_hub_client_example_test.go b/apphub/apiv1/app_hub_client_example_test.go index 182807d3130b..f94feaf9df00 100644 --- a/apphub/apiv1/app_hub_client_example_test.go +++ b/apphub/apiv1/app_hub_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apphub/apiv1/auxiliary.go b/apphub/apiv1/auxiliary.go index fa8fda1902bc..0f7a91bfa21c 100755 --- a/apphub/apiv1/auxiliary.go +++ b/apphub/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apphub/apiv1/auxiliary_go123.go b/apphub/apiv1/auxiliary_go123.go index 04c962454bb7..55075e3999e2 100755 --- a/apphub/apiv1/auxiliary_go123.go +++ b/apphub/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apphub/apiv1/doc.go b/apphub/apiv1/doc.go index 47be1f67dbd3..e8e55d546a84 100755 --- a/apphub/apiv1/doc.go +++ b/apphub/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apphub/apiv1/helpers.go b/apphub/apiv1/helpers.go index 8c8258f996b1..6fe7233637e4 100755 --- a/apphub/apiv1/helpers.go +++ b/apphub/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apps/events/subscriptions/apiv1/auxiliary.go b/apps/events/subscriptions/apiv1/auxiliary.go index 480c448965c6..c331fd02c8b4 100755 --- a/apps/events/subscriptions/apiv1/auxiliary.go +++ b/apps/events/subscriptions/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apps/events/subscriptions/apiv1/auxiliary_go123.go b/apps/events/subscriptions/apiv1/auxiliary_go123.go index ae235628fc5c..66790f3b8ac3 100755 --- a/apps/events/subscriptions/apiv1/auxiliary_go123.go +++ b/apps/events/subscriptions/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apps/events/subscriptions/apiv1/doc.go b/apps/events/subscriptions/apiv1/doc.go index e3a570f8f5ca..bba2f8bec25c 100755 --- a/apps/events/subscriptions/apiv1/doc.go +++ b/apps/events/subscriptions/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apps/events/subscriptions/apiv1/helpers.go b/apps/events/subscriptions/apiv1/helpers.go index 9e723e668639..f7495ae9dc18 100755 --- a/apps/events/subscriptions/apiv1/helpers.go +++ b/apps/events/subscriptions/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apps/events/subscriptions/apiv1/subscriptions_client.go b/apps/events/subscriptions/apiv1/subscriptions_client.go index 38aab59de58f..1cee918156af 100755 --- a/apps/events/subscriptions/apiv1/subscriptions_client.go +++ b/apps/events/subscriptions/apiv1/subscriptions_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apps/events/subscriptions/apiv1/subscriptions_client_example_go123_test.go b/apps/events/subscriptions/apiv1/subscriptions_client_example_go123_test.go index f84d9156cf77..c6b4c0d2a4a8 100644 --- a/apps/events/subscriptions/apiv1/subscriptions_client_example_go123_test.go +++ b/apps/events/subscriptions/apiv1/subscriptions_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apps/events/subscriptions/apiv1/subscriptions_client_example_test.go b/apps/events/subscriptions/apiv1/subscriptions_client_example_test.go index 60730274ccb8..f31ed643bf25 100644 --- a/apps/events/subscriptions/apiv1/subscriptions_client_example_test.go +++ b/apps/events/subscriptions/apiv1/subscriptions_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apps/meet/apiv2/auxiliary.go b/apps/meet/apiv2/auxiliary.go index 8c7f93046e0c..6385d5578980 100755 --- a/apps/meet/apiv2/auxiliary.go +++ b/apps/meet/apiv2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apps/meet/apiv2/auxiliary_go123.go b/apps/meet/apiv2/auxiliary_go123.go index 8e67742a04a0..1e1de815c9b0 100755 --- a/apps/meet/apiv2/auxiliary_go123.go +++ b/apps/meet/apiv2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apps/meet/apiv2/conference_records_client.go b/apps/meet/apiv2/conference_records_client.go index a02042bbe9d6..deef1b79291b 100755 --- a/apps/meet/apiv2/conference_records_client.go +++ b/apps/meet/apiv2/conference_records_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apps/meet/apiv2/conference_records_client_example_go123_test.go b/apps/meet/apiv2/conference_records_client_example_go123_test.go index 53c38877bd34..821c94bf9a79 100644 --- a/apps/meet/apiv2/conference_records_client_example_go123_test.go +++ b/apps/meet/apiv2/conference_records_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apps/meet/apiv2/conference_records_client_example_test.go b/apps/meet/apiv2/conference_records_client_example_test.go index cbc288cb3b53..809d3e2da5af 100644 --- a/apps/meet/apiv2/conference_records_client_example_test.go +++ b/apps/meet/apiv2/conference_records_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apps/meet/apiv2/doc.go b/apps/meet/apiv2/doc.go index eb66c3a17c05..83fabf89982f 100755 --- a/apps/meet/apiv2/doc.go +++ b/apps/meet/apiv2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apps/meet/apiv2/helpers.go b/apps/meet/apiv2/helpers.go index 86e836d61a37..2f18f081d81c 100755 --- a/apps/meet/apiv2/helpers.go +++ b/apps/meet/apiv2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apps/meet/apiv2/spaces_client.go b/apps/meet/apiv2/spaces_client.go index 71e7861aed54..bf8578afe373 100755 --- a/apps/meet/apiv2/spaces_client.go +++ b/apps/meet/apiv2/spaces_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apps/meet/apiv2/spaces_client_example_go123_test.go b/apps/meet/apiv2/spaces_client_example_go123_test.go index 288b16dc4567..479ff7ecf2c3 100644 --- a/apps/meet/apiv2/spaces_client_example_go123_test.go +++ b/apps/meet/apiv2/spaces_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apps/meet/apiv2/spaces_client_example_test.go b/apps/meet/apiv2/spaces_client_example_test.go index f30030e0dc30..ae78e8ddc092 100644 --- a/apps/meet/apiv2/spaces_client_example_test.go +++ b/apps/meet/apiv2/spaces_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apps/meet/apiv2beta/auxiliary.go b/apps/meet/apiv2beta/auxiliary.go index 28146518f50f..5a952c3962bf 100755 --- a/apps/meet/apiv2beta/auxiliary.go +++ b/apps/meet/apiv2beta/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apps/meet/apiv2beta/auxiliary_go123.go b/apps/meet/apiv2beta/auxiliary_go123.go index 5546fb0de106..a9ecb65ed787 100755 --- a/apps/meet/apiv2beta/auxiliary_go123.go +++ b/apps/meet/apiv2beta/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apps/meet/apiv2beta/conference_records_client.go b/apps/meet/apiv2beta/conference_records_client.go index a387ddb1aa80..4e600af8ff15 100755 --- a/apps/meet/apiv2beta/conference_records_client.go +++ b/apps/meet/apiv2beta/conference_records_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apps/meet/apiv2beta/conference_records_client_example_go123_test.go b/apps/meet/apiv2beta/conference_records_client_example_go123_test.go index 35413ade3d4a..c793a881ca74 100644 --- a/apps/meet/apiv2beta/conference_records_client_example_go123_test.go +++ b/apps/meet/apiv2beta/conference_records_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apps/meet/apiv2beta/conference_records_client_example_test.go b/apps/meet/apiv2beta/conference_records_client_example_test.go index 6b54aa970685..f27cbe526bfa 100644 --- a/apps/meet/apiv2beta/conference_records_client_example_test.go +++ b/apps/meet/apiv2beta/conference_records_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apps/meet/apiv2beta/doc.go b/apps/meet/apiv2beta/doc.go index e4ba8be41b18..44b3f1f02622 100755 --- a/apps/meet/apiv2beta/doc.go +++ b/apps/meet/apiv2beta/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apps/meet/apiv2beta/helpers.go b/apps/meet/apiv2beta/helpers.go index 2c170dee662a..9c5b4499de92 100755 --- a/apps/meet/apiv2beta/helpers.go +++ b/apps/meet/apiv2beta/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apps/meet/apiv2beta/spaces_client.go b/apps/meet/apiv2beta/spaces_client.go index c8824771b1f4..8677bbdbeda5 100755 --- a/apps/meet/apiv2beta/spaces_client.go +++ b/apps/meet/apiv2beta/spaces_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apps/meet/apiv2beta/spaces_client_example_go123_test.go b/apps/meet/apiv2beta/spaces_client_example_go123_test.go index 288b16dc4567..479ff7ecf2c3 100644 --- a/apps/meet/apiv2beta/spaces_client_example_go123_test.go +++ b/apps/meet/apiv2beta/spaces_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/apps/meet/apiv2beta/spaces_client_example_test.go b/apps/meet/apiv2beta/spaces_client_example_test.go index 1c011b92d9fd..66afa8466a89 100644 --- a/apps/meet/apiv2beta/spaces_client_example_test.go +++ b/apps/meet/apiv2beta/spaces_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/area120/tables/apiv1alpha1/auxiliary.go b/area120/tables/apiv1alpha1/auxiliary.go index e27f04ce810a..1e9ec8d596bf 100755 --- a/area120/tables/apiv1alpha1/auxiliary.go +++ b/area120/tables/apiv1alpha1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/area120/tables/apiv1alpha1/auxiliary_go123.go b/area120/tables/apiv1alpha1/auxiliary_go123.go index 808e1885674f..b4d91aaca5b0 100755 --- a/area120/tables/apiv1alpha1/auxiliary_go123.go +++ b/area120/tables/apiv1alpha1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/area120/tables/apiv1alpha1/doc.go b/area120/tables/apiv1alpha1/doc.go index a3ae8a6198cf..2c453fa49510 100755 --- a/area120/tables/apiv1alpha1/doc.go +++ b/area120/tables/apiv1alpha1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/area120/tables/apiv1alpha1/helpers.go b/area120/tables/apiv1alpha1/helpers.go index c6696070bd99..c01897acfb3c 100755 --- a/area120/tables/apiv1alpha1/helpers.go +++ b/area120/tables/apiv1alpha1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/area120/tables/apiv1alpha1/tables_client.go b/area120/tables/apiv1alpha1/tables_client.go index fae6143f8ab2..0b9f28c5644b 100755 --- a/area120/tables/apiv1alpha1/tables_client.go +++ b/area120/tables/apiv1alpha1/tables_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/area120/tables/apiv1alpha1/tables_client_example_go123_test.go b/area120/tables/apiv1alpha1/tables_client_example_go123_test.go index 90484b036068..6da57015c783 100644 --- a/area120/tables/apiv1alpha1/tables_client_example_go123_test.go +++ b/area120/tables/apiv1alpha1/tables_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/area120/tables/apiv1alpha1/tables_client_example_test.go b/area120/tables/apiv1alpha1/tables_client_example_test.go index 706856194b21..4441ef6a1a0a 100644 --- a/area120/tables/apiv1alpha1/tables_client_example_test.go +++ b/area120/tables/apiv1alpha1/tables_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/artifactregistry/apiv1/artifact_registry_client.go b/artifactregistry/apiv1/artifact_registry_client.go index 8e6e6192f027..a142d07b1f96 100755 --- a/artifactregistry/apiv1/artifact_registry_client.go +++ b/artifactregistry/apiv1/artifact_registry_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/artifactregistry/apiv1/artifact_registry_client_example_go123_test.go b/artifactregistry/apiv1/artifact_registry_client_example_go123_test.go index 075cb8393ac7..9b844630a155 100644 --- a/artifactregistry/apiv1/artifact_registry_client_example_go123_test.go +++ b/artifactregistry/apiv1/artifact_registry_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/artifactregistry/apiv1/artifact_registry_client_example_test.go b/artifactregistry/apiv1/artifact_registry_client_example_test.go index 7db00a3a39cd..143cf06efe7d 100644 --- a/artifactregistry/apiv1/artifact_registry_client_example_test.go +++ b/artifactregistry/apiv1/artifact_registry_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/artifactregistry/apiv1/auxiliary.go b/artifactregistry/apiv1/auxiliary.go index 11fc20ea6528..c37faeb01269 100755 --- a/artifactregistry/apiv1/auxiliary.go +++ b/artifactregistry/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/artifactregistry/apiv1/auxiliary_go123.go b/artifactregistry/apiv1/auxiliary_go123.go index 51ce26521c09..6f9ac79c6da0 100755 --- a/artifactregistry/apiv1/auxiliary_go123.go +++ b/artifactregistry/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/artifactregistry/apiv1/doc.go b/artifactregistry/apiv1/doc.go index 1325246af705..913c6a4e7a6b 100755 --- a/artifactregistry/apiv1/doc.go +++ b/artifactregistry/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/artifactregistry/apiv1/helpers.go b/artifactregistry/apiv1/helpers.go index 5c2b5bfb7b4e..7d2c6276e448 100755 --- a/artifactregistry/apiv1/helpers.go +++ b/artifactregistry/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/artifactregistry/apiv1beta2/artifact_registry_client.go b/artifactregistry/apiv1beta2/artifact_registry_client.go index 6b2a14637b69..b0b8a4ace702 100755 --- a/artifactregistry/apiv1beta2/artifact_registry_client.go +++ b/artifactregistry/apiv1beta2/artifact_registry_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/artifactregistry/apiv1beta2/artifact_registry_client_example_go123_test.go b/artifactregistry/apiv1beta2/artifact_registry_client_example_go123_test.go index 8074f6816bba..31bef52e96fe 100644 --- a/artifactregistry/apiv1beta2/artifact_registry_client_example_go123_test.go +++ b/artifactregistry/apiv1beta2/artifact_registry_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/artifactregistry/apiv1beta2/artifact_registry_client_example_test.go b/artifactregistry/apiv1beta2/artifact_registry_client_example_test.go index 2b4722b7bcea..52334e71ee64 100644 --- a/artifactregistry/apiv1beta2/artifact_registry_client_example_test.go +++ b/artifactregistry/apiv1beta2/artifact_registry_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/artifactregistry/apiv1beta2/auxiliary.go b/artifactregistry/apiv1beta2/auxiliary.go index 790690fb43b0..399f956b3af8 100755 --- a/artifactregistry/apiv1beta2/auxiliary.go +++ b/artifactregistry/apiv1beta2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/artifactregistry/apiv1beta2/auxiliary_go123.go b/artifactregistry/apiv1beta2/auxiliary_go123.go index 697595e62f8f..fe985c04bd9a 100755 --- a/artifactregistry/apiv1beta2/auxiliary_go123.go +++ b/artifactregistry/apiv1beta2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/artifactregistry/apiv1beta2/doc.go b/artifactregistry/apiv1beta2/doc.go index 5cc0cf91a96e..d2e571a58e64 100755 --- a/artifactregistry/apiv1beta2/doc.go +++ b/artifactregistry/apiv1beta2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/artifactregistry/apiv1beta2/helpers.go b/artifactregistry/apiv1beta2/helpers.go index 5c2b5bfb7b4e..7d2c6276e448 100755 --- a/artifactregistry/apiv1beta2/helpers.go +++ b/artifactregistry/apiv1beta2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/asset/apiv1/asset_client.go b/asset/apiv1/asset_client.go index 5d5b63ed78ef..9158b2902a73 100755 --- a/asset/apiv1/asset_client.go +++ b/asset/apiv1/asset_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/asset/apiv1/asset_client_example_go123_test.go b/asset/apiv1/asset_client_example_go123_test.go index c2c389a377c3..1fe4f6973793 100644 --- a/asset/apiv1/asset_client_example_go123_test.go +++ b/asset/apiv1/asset_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/asset/apiv1/asset_client_example_test.go b/asset/apiv1/asset_client_example_test.go index eeb871fbb36d..9a31d894f228 100644 --- a/asset/apiv1/asset_client_example_test.go +++ b/asset/apiv1/asset_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/asset/apiv1/auxiliary.go b/asset/apiv1/auxiliary.go index 1825c976b8da..edcb29f32e9d 100755 --- a/asset/apiv1/auxiliary.go +++ b/asset/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/asset/apiv1/auxiliary_go123.go b/asset/apiv1/auxiliary_go123.go index daf7904c7bcd..82c7fcd1c747 100755 --- a/asset/apiv1/auxiliary_go123.go +++ b/asset/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/asset/apiv1/doc.go b/asset/apiv1/doc.go index 8f91709a7a09..008fd9326250 100755 --- a/asset/apiv1/doc.go +++ b/asset/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/asset/apiv1/helpers.go b/asset/apiv1/helpers.go index 9f9f777c82d2..0121398fb972 100755 --- a/asset/apiv1/helpers.go +++ b/asset/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/asset/apiv1p2beta1/asset_client.go b/asset/apiv1p2beta1/asset_client.go index 8a316967c0b1..5956fa69322a 100755 --- a/asset/apiv1p2beta1/asset_client.go +++ b/asset/apiv1p2beta1/asset_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/asset/apiv1p2beta1/asset_client_example_go123_test.go b/asset/apiv1p2beta1/asset_client_example_go123_test.go index 463caec06fe4..23c1565acdfe 100644 --- a/asset/apiv1p2beta1/asset_client_example_go123_test.go +++ b/asset/apiv1p2beta1/asset_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/asset/apiv1p2beta1/asset_client_example_test.go b/asset/apiv1p2beta1/asset_client_example_test.go index 7f75d820bce1..170ae41d3716 100644 --- a/asset/apiv1p2beta1/asset_client_example_test.go +++ b/asset/apiv1p2beta1/asset_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/asset/apiv1p2beta1/auxiliary.go b/asset/apiv1p2beta1/auxiliary.go index 901adb08085c..de21ec7e14a7 100755 --- a/asset/apiv1p2beta1/auxiliary.go +++ b/asset/apiv1p2beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/asset/apiv1p2beta1/auxiliary_go123.go b/asset/apiv1p2beta1/auxiliary_go123.go index 482d879fec1b..0933ae32ee89 100755 --- a/asset/apiv1p2beta1/auxiliary_go123.go +++ b/asset/apiv1p2beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/asset/apiv1p2beta1/doc.go b/asset/apiv1p2beta1/doc.go index d8da26fb1e29..1aa17dab86a5 100755 --- a/asset/apiv1p2beta1/doc.go +++ b/asset/apiv1p2beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/asset/apiv1p2beta1/helpers.go b/asset/apiv1p2beta1/helpers.go index 9f9f777c82d2..0121398fb972 100755 --- a/asset/apiv1p2beta1/helpers.go +++ b/asset/apiv1p2beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/asset/apiv1p5beta1/asset_client.go b/asset/apiv1p5beta1/asset_client.go index 2bd4d4e91655..faa8e96f125c 100755 --- a/asset/apiv1p5beta1/asset_client.go +++ b/asset/apiv1p5beta1/asset_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/asset/apiv1p5beta1/asset_client_example_go123_test.go b/asset/apiv1p5beta1/asset_client_example_go123_test.go index 0cc7fb6d0bb3..329d091ce098 100644 --- a/asset/apiv1p5beta1/asset_client_example_go123_test.go +++ b/asset/apiv1p5beta1/asset_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/asset/apiv1p5beta1/asset_client_example_test.go b/asset/apiv1p5beta1/asset_client_example_test.go index 20c334bd6530..cacef4ae01dd 100644 --- a/asset/apiv1p5beta1/asset_client_example_test.go +++ b/asset/apiv1p5beta1/asset_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/asset/apiv1p5beta1/auxiliary.go b/asset/apiv1p5beta1/auxiliary.go index abceaf775b76..988920446a93 100755 --- a/asset/apiv1p5beta1/auxiliary.go +++ b/asset/apiv1p5beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/asset/apiv1p5beta1/auxiliary_go123.go b/asset/apiv1p5beta1/auxiliary_go123.go index 9c820b5fcb4a..d6a8d807bef5 100755 --- a/asset/apiv1p5beta1/auxiliary_go123.go +++ b/asset/apiv1p5beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/asset/apiv1p5beta1/doc.go b/asset/apiv1p5beta1/doc.go index ec3b00cea34e..d5730d62a89c 100755 --- a/asset/apiv1p5beta1/doc.go +++ b/asset/apiv1p5beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/asset/apiv1p5beta1/helpers.go b/asset/apiv1p5beta1/helpers.go index 9f9f777c82d2..0121398fb972 100755 --- a/asset/apiv1p5beta1/helpers.go +++ b/asset/apiv1p5beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/assuredworkloads/apiv1/assured_workloads_client.go b/assuredworkloads/apiv1/assured_workloads_client.go index 4234ff0eff13..ef32758240e0 100755 --- a/assuredworkloads/apiv1/assured_workloads_client.go +++ b/assuredworkloads/apiv1/assured_workloads_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/assuredworkloads/apiv1/assured_workloads_client_example_go123_test.go b/assuredworkloads/apiv1/assured_workloads_client_example_go123_test.go index c351a0dc0df3..71b276468cda 100644 --- a/assuredworkloads/apiv1/assured_workloads_client_example_go123_test.go +++ b/assuredworkloads/apiv1/assured_workloads_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/assuredworkloads/apiv1/assured_workloads_client_example_test.go b/assuredworkloads/apiv1/assured_workloads_client_example_test.go index 41c8d2665fc0..89ab839f8cdb 100644 --- a/assuredworkloads/apiv1/assured_workloads_client_example_test.go +++ b/assuredworkloads/apiv1/assured_workloads_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/assuredworkloads/apiv1/auxiliary.go b/assuredworkloads/apiv1/auxiliary.go index 7652bc6c0f4f..d0cc80b1398a 100755 --- a/assuredworkloads/apiv1/auxiliary.go +++ b/assuredworkloads/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/assuredworkloads/apiv1/auxiliary_go123.go b/assuredworkloads/apiv1/auxiliary_go123.go index 71ec070e096f..f63f92221dad 100755 --- a/assuredworkloads/apiv1/auxiliary_go123.go +++ b/assuredworkloads/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/assuredworkloads/apiv1/doc.go b/assuredworkloads/apiv1/doc.go index 82a2a964b0a8..79ffd3fe6393 100755 --- a/assuredworkloads/apiv1/doc.go +++ b/assuredworkloads/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/assuredworkloads/apiv1/helpers.go b/assuredworkloads/apiv1/helpers.go index ff6270ea9989..9ca536a57a5b 100755 --- a/assuredworkloads/apiv1/helpers.go +++ b/assuredworkloads/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/assuredworkloads/apiv1beta1/assured_workloads_client.go b/assuredworkloads/apiv1beta1/assured_workloads_client.go index 32a19df790ba..b746f5da8411 100755 --- a/assuredworkloads/apiv1beta1/assured_workloads_client.go +++ b/assuredworkloads/apiv1beta1/assured_workloads_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/assuredworkloads/apiv1beta1/assured_workloads_client_example_go123_test.go b/assuredworkloads/apiv1beta1/assured_workloads_client_example_go123_test.go index 4b2a6c974305..96cf5b752eba 100644 --- a/assuredworkloads/apiv1beta1/assured_workloads_client_example_go123_test.go +++ b/assuredworkloads/apiv1beta1/assured_workloads_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/assuredworkloads/apiv1beta1/assured_workloads_client_example_test.go b/assuredworkloads/apiv1beta1/assured_workloads_client_example_test.go index 60bb00abdae9..990a1307ee81 100644 --- a/assuredworkloads/apiv1beta1/assured_workloads_client_example_test.go +++ b/assuredworkloads/apiv1beta1/assured_workloads_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/assuredworkloads/apiv1beta1/auxiliary.go b/assuredworkloads/apiv1beta1/auxiliary.go index b00440015509..82cd1627a608 100755 --- a/assuredworkloads/apiv1beta1/auxiliary.go +++ b/assuredworkloads/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/assuredworkloads/apiv1beta1/auxiliary_go123.go b/assuredworkloads/apiv1beta1/auxiliary_go123.go index 7cd17596482b..793f482507bd 100755 --- a/assuredworkloads/apiv1beta1/auxiliary_go123.go +++ b/assuredworkloads/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/assuredworkloads/apiv1beta1/doc.go b/assuredworkloads/apiv1beta1/doc.go index 4a3bac49c05d..19a4bb5a3102 100755 --- a/assuredworkloads/apiv1beta1/doc.go +++ b/assuredworkloads/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/assuredworkloads/apiv1beta1/helpers.go b/assuredworkloads/apiv1beta1/helpers.go index ff6270ea9989..9ca536a57a5b 100755 --- a/assuredworkloads/apiv1beta1/helpers.go +++ b/assuredworkloads/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/automl/apiv1/auto_ml_client.go b/automl/apiv1/auto_ml_client.go index 21b8b1214799..45513aa63764 100755 --- a/automl/apiv1/auto_ml_client.go +++ b/automl/apiv1/auto_ml_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/automl/apiv1/auto_ml_client_example_go123_test.go b/automl/apiv1/auto_ml_client_example_go123_test.go index 111ba1c4b6e0..9796886ec3c2 100644 --- a/automl/apiv1/auto_ml_client_example_go123_test.go +++ b/automl/apiv1/auto_ml_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/automl/apiv1/auto_ml_client_example_test.go b/automl/apiv1/auto_ml_client_example_test.go index 602d77644b1d..ed09c4841edf 100644 --- a/automl/apiv1/auto_ml_client_example_test.go +++ b/automl/apiv1/auto_ml_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/automl/apiv1/auxiliary.go b/automl/apiv1/auxiliary.go index 5477308d1903..e7d68ec04a84 100755 --- a/automl/apiv1/auxiliary.go +++ b/automl/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/automl/apiv1/auxiliary_go123.go b/automl/apiv1/auxiliary_go123.go index e3e4163812e2..973888228b41 100755 --- a/automl/apiv1/auxiliary_go123.go +++ b/automl/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/automl/apiv1/doc.go b/automl/apiv1/doc.go index c630180e8ccc..a8fb55b89615 100755 --- a/automl/apiv1/doc.go +++ b/automl/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/automl/apiv1/helpers.go b/automl/apiv1/helpers.go index 9cf9b51f6502..6a5fcb051f8c 100755 --- a/automl/apiv1/helpers.go +++ b/automl/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/automl/apiv1/prediction_client.go b/automl/apiv1/prediction_client.go index 48651736afc7..816ca3c69b08 100755 --- a/automl/apiv1/prediction_client.go +++ b/automl/apiv1/prediction_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/automl/apiv1/prediction_client_example_go123_test.go b/automl/apiv1/prediction_client_example_go123_test.go index b462fb22f5f9..e97aff5e4119 100644 --- a/automl/apiv1/prediction_client_example_go123_test.go +++ b/automl/apiv1/prediction_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/automl/apiv1/prediction_client_example_test.go b/automl/apiv1/prediction_client_example_test.go index 56cb31b48dba..835fa8a357cf 100644 --- a/automl/apiv1/prediction_client_example_test.go +++ b/automl/apiv1/prediction_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/automl/apiv1beta1/auto_ml_client.go b/automl/apiv1beta1/auto_ml_client.go index 3da753b36dc7..96e8fd781619 100755 --- a/automl/apiv1beta1/auto_ml_client.go +++ b/automl/apiv1beta1/auto_ml_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/automl/apiv1beta1/auto_ml_client_example_go123_test.go b/automl/apiv1beta1/auto_ml_client_example_go123_test.go index c3b595f4e94c..7894f6897219 100644 --- a/automl/apiv1beta1/auto_ml_client_example_go123_test.go +++ b/automl/apiv1beta1/auto_ml_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/automl/apiv1beta1/auto_ml_client_example_test.go b/automl/apiv1beta1/auto_ml_client_example_test.go index 31bf7eddc1a8..d88db21ba064 100644 --- a/automl/apiv1beta1/auto_ml_client_example_test.go +++ b/automl/apiv1beta1/auto_ml_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/automl/apiv1beta1/auxiliary.go b/automl/apiv1beta1/auxiliary.go index 2c7650fa8239..cc23e6343213 100755 --- a/automl/apiv1beta1/auxiliary.go +++ b/automl/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/automl/apiv1beta1/auxiliary_go123.go b/automl/apiv1beta1/auxiliary_go123.go index 28b567afbd2e..cdd1af3a33db 100755 --- a/automl/apiv1beta1/auxiliary_go123.go +++ b/automl/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/automl/apiv1beta1/doc.go b/automl/apiv1beta1/doc.go index 49de7dfc8c61..f83b498373fb 100755 --- a/automl/apiv1beta1/doc.go +++ b/automl/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/automl/apiv1beta1/helpers.go b/automl/apiv1beta1/helpers.go index 9cf9b51f6502..6a5fcb051f8c 100755 --- a/automl/apiv1beta1/helpers.go +++ b/automl/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/automl/apiv1beta1/prediction_client.go b/automl/apiv1beta1/prediction_client.go index a9b17d7a33b0..665cca758b48 100755 --- a/automl/apiv1beta1/prediction_client.go +++ b/automl/apiv1beta1/prediction_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/automl/apiv1beta1/prediction_client_example_go123_test.go b/automl/apiv1beta1/prediction_client_example_go123_test.go index b462fb22f5f9..e97aff5e4119 100644 --- a/automl/apiv1beta1/prediction_client_example_go123_test.go +++ b/automl/apiv1beta1/prediction_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/automl/apiv1beta1/prediction_client_example_test.go b/automl/apiv1beta1/prediction_client_example_test.go index 13b0c8b146b0..b095046643bb 100644 --- a/automl/apiv1beta1/prediction_client_example_test.go +++ b/automl/apiv1beta1/prediction_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/backupdr/apiv1/auxiliary.go b/backupdr/apiv1/auxiliary.go index c3f1db796a3c..215d3832414b 100755 --- a/backupdr/apiv1/auxiliary.go +++ b/backupdr/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/backupdr/apiv1/auxiliary_go123.go b/backupdr/apiv1/auxiliary_go123.go index 31d473d7ba6e..9cd16c8a2723 100755 --- a/backupdr/apiv1/auxiliary_go123.go +++ b/backupdr/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/backupdr/apiv1/backupdr_client.go b/backupdr/apiv1/backupdr_client.go index dad9a5bb98c8..3726c38f5626 100755 --- a/backupdr/apiv1/backupdr_client.go +++ b/backupdr/apiv1/backupdr_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/backupdr/apiv1/backupdr_client_example_go123_test.go b/backupdr/apiv1/backupdr_client_example_go123_test.go index 45048969f77e..ea6a38ea6716 100644 --- a/backupdr/apiv1/backupdr_client_example_go123_test.go +++ b/backupdr/apiv1/backupdr_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/backupdr/apiv1/backupdr_client_example_test.go b/backupdr/apiv1/backupdr_client_example_test.go index b300d7f90ee9..2c9e376183a4 100644 --- a/backupdr/apiv1/backupdr_client_example_test.go +++ b/backupdr/apiv1/backupdr_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/backupdr/apiv1/doc.go b/backupdr/apiv1/doc.go index 8c50ab2da8ca..4eb38cf906f3 100755 --- a/backupdr/apiv1/doc.go +++ b/backupdr/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/backupdr/apiv1/helpers.go b/backupdr/apiv1/helpers.go index e213197a6635..5690a402edc3 100755 --- a/backupdr/apiv1/helpers.go +++ b/backupdr/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/baremetalsolution/apiv2/auxiliary.go b/baremetalsolution/apiv2/auxiliary.go index c00cf0d01239..4c6bf1b2ccaa 100755 --- a/baremetalsolution/apiv2/auxiliary.go +++ b/baremetalsolution/apiv2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/baremetalsolution/apiv2/auxiliary_go123.go b/baremetalsolution/apiv2/auxiliary_go123.go index e287dc211d7f..c114ad11f08a 100755 --- a/baremetalsolution/apiv2/auxiliary_go123.go +++ b/baremetalsolution/apiv2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/baremetalsolution/apiv2/bare_metal_solution_client.go b/baremetalsolution/apiv2/bare_metal_solution_client.go index 7b981e1654b1..3521150ce3cb 100755 --- a/baremetalsolution/apiv2/bare_metal_solution_client.go +++ b/baremetalsolution/apiv2/bare_metal_solution_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/baremetalsolution/apiv2/bare_metal_solution_client_example_go123_test.go b/baremetalsolution/apiv2/bare_metal_solution_client_example_go123_test.go index 56c72f65ea8b..049c5b7a7d10 100644 --- a/baremetalsolution/apiv2/bare_metal_solution_client_example_go123_test.go +++ b/baremetalsolution/apiv2/bare_metal_solution_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/baremetalsolution/apiv2/bare_metal_solution_client_example_test.go b/baremetalsolution/apiv2/bare_metal_solution_client_example_test.go index 71b50484477f..2dac555e9e1a 100644 --- a/baremetalsolution/apiv2/bare_metal_solution_client_example_test.go +++ b/baremetalsolution/apiv2/bare_metal_solution_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/baremetalsolution/apiv2/doc.go b/baremetalsolution/apiv2/doc.go index 893cb6ac9f27..2d1c8bd70398 100755 --- a/baremetalsolution/apiv2/doc.go +++ b/baremetalsolution/apiv2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/baremetalsolution/apiv2/helpers.go b/baremetalsolution/apiv2/helpers.go index d07ce9f4ff38..8e7776a83fbe 100755 --- a/baremetalsolution/apiv2/helpers.go +++ b/baremetalsolution/apiv2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/batch/apiv1/auxiliary.go b/batch/apiv1/auxiliary.go index 1ab07e16e904..5fd24eb097cf 100755 --- a/batch/apiv1/auxiliary.go +++ b/batch/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/batch/apiv1/auxiliary_go123.go b/batch/apiv1/auxiliary_go123.go index bde766e00272..786bed21cf46 100755 --- a/batch/apiv1/auxiliary_go123.go +++ b/batch/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/batch/apiv1/batch_client.go b/batch/apiv1/batch_client.go index 67bc12e14fe9..a1860ec1abab 100755 --- a/batch/apiv1/batch_client.go +++ b/batch/apiv1/batch_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/batch/apiv1/batch_client_example_go123_test.go b/batch/apiv1/batch_client_example_go123_test.go index f2abfa7049a6..1bfac5b05889 100644 --- a/batch/apiv1/batch_client_example_go123_test.go +++ b/batch/apiv1/batch_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/batch/apiv1/batch_client_example_test.go b/batch/apiv1/batch_client_example_test.go index 6d3073163595..e369ac8c6edc 100644 --- a/batch/apiv1/batch_client_example_test.go +++ b/batch/apiv1/batch_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/batch/apiv1/doc.go b/batch/apiv1/doc.go index 36899b9d4145..cc9bf0db567a 100755 --- a/batch/apiv1/doc.go +++ b/batch/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/batch/apiv1/helpers.go b/batch/apiv1/helpers.go index 820bc234c32e..70d95a968975 100755 --- a/batch/apiv1/helpers.go +++ b/batch/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/appconnections/apiv1/app_connections_client.go b/beyondcorp/appconnections/apiv1/app_connections_client.go index 40daa9fa5521..de99d1514081 100755 --- a/beyondcorp/appconnections/apiv1/app_connections_client.go +++ b/beyondcorp/appconnections/apiv1/app_connections_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/appconnections/apiv1/app_connections_client_example_go123_test.go b/beyondcorp/appconnections/apiv1/app_connections_client_example_go123_test.go index c992ad483914..37b39c397edf 100644 --- a/beyondcorp/appconnections/apiv1/app_connections_client_example_go123_test.go +++ b/beyondcorp/appconnections/apiv1/app_connections_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/appconnections/apiv1/app_connections_client_example_test.go b/beyondcorp/appconnections/apiv1/app_connections_client_example_test.go index 0ec1713010a8..11c4bfec2743 100644 --- a/beyondcorp/appconnections/apiv1/app_connections_client_example_test.go +++ b/beyondcorp/appconnections/apiv1/app_connections_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/appconnections/apiv1/auxiliary.go b/beyondcorp/appconnections/apiv1/auxiliary.go index 27f088d7e35b..97f5c1353866 100755 --- a/beyondcorp/appconnections/apiv1/auxiliary.go +++ b/beyondcorp/appconnections/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/appconnections/apiv1/auxiliary_go123.go b/beyondcorp/appconnections/apiv1/auxiliary_go123.go index 4c547b026a8e..0acf61044109 100755 --- a/beyondcorp/appconnections/apiv1/auxiliary_go123.go +++ b/beyondcorp/appconnections/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/appconnections/apiv1/doc.go b/beyondcorp/appconnections/apiv1/doc.go index 36babbd99439..4c5679eb6eec 100755 --- a/beyondcorp/appconnections/apiv1/doc.go +++ b/beyondcorp/appconnections/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/appconnections/apiv1/helpers.go b/beyondcorp/appconnections/apiv1/helpers.go index 12419d00ffae..d5e54b84d2d5 100755 --- a/beyondcorp/appconnections/apiv1/helpers.go +++ b/beyondcorp/appconnections/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/appconnectors/apiv1/app_connectors_client.go b/beyondcorp/appconnectors/apiv1/app_connectors_client.go index 4582f82b1098..80b30bbba1a6 100755 --- a/beyondcorp/appconnectors/apiv1/app_connectors_client.go +++ b/beyondcorp/appconnectors/apiv1/app_connectors_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/appconnectors/apiv1/app_connectors_client_example_go123_test.go b/beyondcorp/appconnectors/apiv1/app_connectors_client_example_go123_test.go index 5b4ee2d6949c..da39c66500de 100644 --- a/beyondcorp/appconnectors/apiv1/app_connectors_client_example_go123_test.go +++ b/beyondcorp/appconnectors/apiv1/app_connectors_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/appconnectors/apiv1/app_connectors_client_example_test.go b/beyondcorp/appconnectors/apiv1/app_connectors_client_example_test.go index d7f66196ea5f..c6f7b317779c 100644 --- a/beyondcorp/appconnectors/apiv1/app_connectors_client_example_test.go +++ b/beyondcorp/appconnectors/apiv1/app_connectors_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/appconnectors/apiv1/auxiliary.go b/beyondcorp/appconnectors/apiv1/auxiliary.go index 89266ede3ebf..c61741106f77 100755 --- a/beyondcorp/appconnectors/apiv1/auxiliary.go +++ b/beyondcorp/appconnectors/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/appconnectors/apiv1/auxiliary_go123.go b/beyondcorp/appconnectors/apiv1/auxiliary_go123.go index 4bab5aa00987..b2a7ba55e976 100755 --- a/beyondcorp/appconnectors/apiv1/auxiliary_go123.go +++ b/beyondcorp/appconnectors/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/appconnectors/apiv1/doc.go b/beyondcorp/appconnectors/apiv1/doc.go index 3521acd1d9b2..fa49e6408621 100755 --- a/beyondcorp/appconnectors/apiv1/doc.go +++ b/beyondcorp/appconnectors/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/appconnectors/apiv1/helpers.go b/beyondcorp/appconnectors/apiv1/helpers.go index 2081f555b1cf..6aa4d85e1278 100755 --- a/beyondcorp/appconnectors/apiv1/helpers.go +++ b/beyondcorp/appconnectors/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/appgateways/apiv1/app_gateways_client.go b/beyondcorp/appgateways/apiv1/app_gateways_client.go index 51929d678e69..fcf344638b31 100755 --- a/beyondcorp/appgateways/apiv1/app_gateways_client.go +++ b/beyondcorp/appgateways/apiv1/app_gateways_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/appgateways/apiv1/app_gateways_client_example_go123_test.go b/beyondcorp/appgateways/apiv1/app_gateways_client_example_go123_test.go index 8aad944e31f5..6508dd473bba 100644 --- a/beyondcorp/appgateways/apiv1/app_gateways_client_example_go123_test.go +++ b/beyondcorp/appgateways/apiv1/app_gateways_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/appgateways/apiv1/app_gateways_client_example_test.go b/beyondcorp/appgateways/apiv1/app_gateways_client_example_test.go index 4c3aa57dc228..48ef1315907d 100644 --- a/beyondcorp/appgateways/apiv1/app_gateways_client_example_test.go +++ b/beyondcorp/appgateways/apiv1/app_gateways_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/appgateways/apiv1/auxiliary.go b/beyondcorp/appgateways/apiv1/auxiliary.go index 59455d861dcf..e5a173436e3b 100755 --- a/beyondcorp/appgateways/apiv1/auxiliary.go +++ b/beyondcorp/appgateways/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/appgateways/apiv1/auxiliary_go123.go b/beyondcorp/appgateways/apiv1/auxiliary_go123.go index 6115db2a1c89..02fc0a90a2cb 100755 --- a/beyondcorp/appgateways/apiv1/auxiliary_go123.go +++ b/beyondcorp/appgateways/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/appgateways/apiv1/doc.go b/beyondcorp/appgateways/apiv1/doc.go index 3a36807cbf84..7df5570821f6 100755 --- a/beyondcorp/appgateways/apiv1/doc.go +++ b/beyondcorp/appgateways/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/appgateways/apiv1/helpers.go b/beyondcorp/appgateways/apiv1/helpers.go index 187a1391bb23..dadb158457fb 100755 --- a/beyondcorp/appgateways/apiv1/helpers.go +++ b/beyondcorp/appgateways/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/clientconnectorservices/apiv1/auxiliary.go b/beyondcorp/clientconnectorservices/apiv1/auxiliary.go index 335a44d681a7..00c323e0a326 100755 --- a/beyondcorp/clientconnectorservices/apiv1/auxiliary.go +++ b/beyondcorp/clientconnectorservices/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/clientconnectorservices/apiv1/auxiliary_go123.go b/beyondcorp/clientconnectorservices/apiv1/auxiliary_go123.go index d0fb8129f6ac..bc60a3487e97 100755 --- a/beyondcorp/clientconnectorservices/apiv1/auxiliary_go123.go +++ b/beyondcorp/clientconnectorservices/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/clientconnectorservices/apiv1/client_connector_services_client.go b/beyondcorp/clientconnectorservices/apiv1/client_connector_services_client.go index cf3881223f4f..f96398665be0 100755 --- a/beyondcorp/clientconnectorservices/apiv1/client_connector_services_client.go +++ b/beyondcorp/clientconnectorservices/apiv1/client_connector_services_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/clientconnectorservices/apiv1/client_connector_services_client_example_go123_test.go b/beyondcorp/clientconnectorservices/apiv1/client_connector_services_client_example_go123_test.go index 5aca283eac0f..4d1acb4a3043 100644 --- a/beyondcorp/clientconnectorservices/apiv1/client_connector_services_client_example_go123_test.go +++ b/beyondcorp/clientconnectorservices/apiv1/client_connector_services_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/clientconnectorservices/apiv1/client_connector_services_client_example_test.go b/beyondcorp/clientconnectorservices/apiv1/client_connector_services_client_example_test.go index 8167105be644..e1f5e8c788a0 100644 --- a/beyondcorp/clientconnectorservices/apiv1/client_connector_services_client_example_test.go +++ b/beyondcorp/clientconnectorservices/apiv1/client_connector_services_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/clientconnectorservices/apiv1/doc.go b/beyondcorp/clientconnectorservices/apiv1/doc.go index 53e7629cfbd5..49c3b20e3932 100755 --- a/beyondcorp/clientconnectorservices/apiv1/doc.go +++ b/beyondcorp/clientconnectorservices/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/clientconnectorservices/apiv1/helpers.go b/beyondcorp/clientconnectorservices/apiv1/helpers.go index 3dfb4eeb0133..f9c5f2c2be8a 100755 --- a/beyondcorp/clientconnectorservices/apiv1/helpers.go +++ b/beyondcorp/clientconnectorservices/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/clientgateways/apiv1/auxiliary.go b/beyondcorp/clientgateways/apiv1/auxiliary.go index a00878c5ca89..e4240c8a24da 100755 --- a/beyondcorp/clientgateways/apiv1/auxiliary.go +++ b/beyondcorp/clientgateways/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/clientgateways/apiv1/auxiliary_go123.go b/beyondcorp/clientgateways/apiv1/auxiliary_go123.go index 91e88fee42d7..82f2da9ea2ab 100755 --- a/beyondcorp/clientgateways/apiv1/auxiliary_go123.go +++ b/beyondcorp/clientgateways/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/clientgateways/apiv1/client_gateways_client.go b/beyondcorp/clientgateways/apiv1/client_gateways_client.go index ef9e873e51ff..7985b3c600e3 100755 --- a/beyondcorp/clientgateways/apiv1/client_gateways_client.go +++ b/beyondcorp/clientgateways/apiv1/client_gateways_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/clientgateways/apiv1/client_gateways_client_example_go123_test.go b/beyondcorp/clientgateways/apiv1/client_gateways_client_example_go123_test.go index 8b605ee73958..c1228eea13a5 100644 --- a/beyondcorp/clientgateways/apiv1/client_gateways_client_example_go123_test.go +++ b/beyondcorp/clientgateways/apiv1/client_gateways_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/clientgateways/apiv1/client_gateways_client_example_test.go b/beyondcorp/clientgateways/apiv1/client_gateways_client_example_test.go index 58eeab5c7567..45aa10384afd 100644 --- a/beyondcorp/clientgateways/apiv1/client_gateways_client_example_test.go +++ b/beyondcorp/clientgateways/apiv1/client_gateways_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/clientgateways/apiv1/doc.go b/beyondcorp/clientgateways/apiv1/doc.go index 37e132b2320e..e0d478e4385c 100755 --- a/beyondcorp/clientgateways/apiv1/doc.go +++ b/beyondcorp/clientgateways/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/beyondcorp/clientgateways/apiv1/helpers.go b/beyondcorp/clientgateways/apiv1/helpers.go index 362dcb546983..a3ac196f972a 100755 --- a/beyondcorp/clientgateways/apiv1/helpers.go +++ b/beyondcorp/clientgateways/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/analyticshub/apiv1/analytics_hub_client.go b/bigquery/analyticshub/apiv1/analytics_hub_client.go index 75505bbddc43..3f5ee0728109 100755 --- a/bigquery/analyticshub/apiv1/analytics_hub_client.go +++ b/bigquery/analyticshub/apiv1/analytics_hub_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/analyticshub/apiv1/analytics_hub_client_example_go123_test.go b/bigquery/analyticshub/apiv1/analytics_hub_client_example_go123_test.go index d361827a772a..ee36ebf41a0a 100644 --- a/bigquery/analyticshub/apiv1/analytics_hub_client_example_go123_test.go +++ b/bigquery/analyticshub/apiv1/analytics_hub_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/analyticshub/apiv1/analytics_hub_client_example_test.go b/bigquery/analyticshub/apiv1/analytics_hub_client_example_test.go index d5dde85f457a..72625b2f0c1c 100644 --- a/bigquery/analyticshub/apiv1/analytics_hub_client_example_test.go +++ b/bigquery/analyticshub/apiv1/analytics_hub_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/analyticshub/apiv1/auxiliary.go b/bigquery/analyticshub/apiv1/auxiliary.go index c13f926cda54..fcb29d77bc11 100755 --- a/bigquery/analyticshub/apiv1/auxiliary.go +++ b/bigquery/analyticshub/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/analyticshub/apiv1/auxiliary_go123.go b/bigquery/analyticshub/apiv1/auxiliary_go123.go index 039dcb5e5f01..2d0cc9574882 100755 --- a/bigquery/analyticshub/apiv1/auxiliary_go123.go +++ b/bigquery/analyticshub/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/analyticshub/apiv1/doc.go b/bigquery/analyticshub/apiv1/doc.go index e075bf290b5f..3f5b6607f4cb 100755 --- a/bigquery/analyticshub/apiv1/doc.go +++ b/bigquery/analyticshub/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/analyticshub/apiv1/helpers.go b/bigquery/analyticshub/apiv1/helpers.go index fa298cf51115..808ef2cfd7f2 100755 --- a/bigquery/analyticshub/apiv1/helpers.go +++ b/bigquery/analyticshub/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/biglake/apiv1/auxiliary.go b/bigquery/biglake/apiv1/auxiliary.go index 8f1a2f0a6d5e..a0c10d84da26 100755 --- a/bigquery/biglake/apiv1/auxiliary.go +++ b/bigquery/biglake/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/biglake/apiv1/auxiliary_go123.go b/bigquery/biglake/apiv1/auxiliary_go123.go index 52525b15eb3c..5823d0c83a7e 100755 --- a/bigquery/biglake/apiv1/auxiliary_go123.go +++ b/bigquery/biglake/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/biglake/apiv1/doc.go b/bigquery/biglake/apiv1/doc.go index 2d178ef602a9..228f82b795ca 100755 --- a/bigquery/biglake/apiv1/doc.go +++ b/bigquery/biglake/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/biglake/apiv1/helpers.go b/bigquery/biglake/apiv1/helpers.go index 38aea732d1c9..5da62f263e29 100755 --- a/bigquery/biglake/apiv1/helpers.go +++ b/bigquery/biglake/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/biglake/apiv1/metastore_client.go b/bigquery/biglake/apiv1/metastore_client.go index 0f3cb249f522..bc8143e9a81f 100755 --- a/bigquery/biglake/apiv1/metastore_client.go +++ b/bigquery/biglake/apiv1/metastore_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/biglake/apiv1/metastore_client_example_go123_test.go b/bigquery/biglake/apiv1/metastore_client_example_go123_test.go index 41f7c9c363af..c10226bc9a88 100644 --- a/bigquery/biglake/apiv1/metastore_client_example_go123_test.go +++ b/bigquery/biglake/apiv1/metastore_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/biglake/apiv1/metastore_client_example_test.go b/bigquery/biglake/apiv1/metastore_client_example_test.go index b6cda78804c7..b3804cc4aed7 100644 --- a/bigquery/biglake/apiv1/metastore_client_example_test.go +++ b/bigquery/biglake/apiv1/metastore_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/biglake/apiv1alpha1/auxiliary.go b/bigquery/biglake/apiv1alpha1/auxiliary.go index 0bae62c9fdb0..ed4eeefd26b7 100755 --- a/bigquery/biglake/apiv1alpha1/auxiliary.go +++ b/bigquery/biglake/apiv1alpha1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/biglake/apiv1alpha1/auxiliary_go123.go b/bigquery/biglake/apiv1alpha1/auxiliary_go123.go index 20a72c94b0ea..3d91814cfd5e 100755 --- a/bigquery/biglake/apiv1alpha1/auxiliary_go123.go +++ b/bigquery/biglake/apiv1alpha1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/biglake/apiv1alpha1/doc.go b/bigquery/biglake/apiv1alpha1/doc.go index 148a1c95b8c6..6956604ab0cb 100755 --- a/bigquery/biglake/apiv1alpha1/doc.go +++ b/bigquery/biglake/apiv1alpha1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/biglake/apiv1alpha1/helpers.go b/bigquery/biglake/apiv1alpha1/helpers.go index 38aea732d1c9..5da62f263e29 100755 --- a/bigquery/biglake/apiv1alpha1/helpers.go +++ b/bigquery/biglake/apiv1alpha1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/biglake/apiv1alpha1/metastore_client.go b/bigquery/biglake/apiv1alpha1/metastore_client.go index 2b5bc1698949..ef44c962efcb 100755 --- a/bigquery/biglake/apiv1alpha1/metastore_client.go +++ b/bigquery/biglake/apiv1alpha1/metastore_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/biglake/apiv1alpha1/metastore_client_example_go123_test.go b/bigquery/biglake/apiv1alpha1/metastore_client_example_go123_test.go index 41f39293a492..36d9c48f8492 100644 --- a/bigquery/biglake/apiv1alpha1/metastore_client_example_go123_test.go +++ b/bigquery/biglake/apiv1alpha1/metastore_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/biglake/apiv1alpha1/metastore_client_example_test.go b/bigquery/biglake/apiv1alpha1/metastore_client_example_test.go index b3f50e763f4d..799734f7b072 100644 --- a/bigquery/biglake/apiv1alpha1/metastore_client_example_test.go +++ b/bigquery/biglake/apiv1alpha1/metastore_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/connection/apiv1/auxiliary.go b/bigquery/connection/apiv1/auxiliary.go index ccb0e4de2e0e..0745e2379059 100755 --- a/bigquery/connection/apiv1/auxiliary.go +++ b/bigquery/connection/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/connection/apiv1/auxiliary_go123.go b/bigquery/connection/apiv1/auxiliary_go123.go index 3237d788e3b5..78ed2dd86b4c 100755 --- a/bigquery/connection/apiv1/auxiliary_go123.go +++ b/bigquery/connection/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/connection/apiv1/connection_client.go b/bigquery/connection/apiv1/connection_client.go index 7da069e17ce8..ddee2aaf3b58 100755 --- a/bigquery/connection/apiv1/connection_client.go +++ b/bigquery/connection/apiv1/connection_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/connection/apiv1/connection_client_example_go123_test.go b/bigquery/connection/apiv1/connection_client_example_go123_test.go index e230a0668cac..6620bd16efc4 100644 --- a/bigquery/connection/apiv1/connection_client_example_go123_test.go +++ b/bigquery/connection/apiv1/connection_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/connection/apiv1/connection_client_example_test.go b/bigquery/connection/apiv1/connection_client_example_test.go index 1a8e67f619af..594b8bcdf007 100644 --- a/bigquery/connection/apiv1/connection_client_example_test.go +++ b/bigquery/connection/apiv1/connection_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/connection/apiv1/doc.go b/bigquery/connection/apiv1/doc.go index 159ff5eaa69d..8a4738e2a239 100755 --- a/bigquery/connection/apiv1/doc.go +++ b/bigquery/connection/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/connection/apiv1/helpers.go b/bigquery/connection/apiv1/helpers.go index b1d38b75e997..deb1371bd1a3 100755 --- a/bigquery/connection/apiv1/helpers.go +++ b/bigquery/connection/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/connection/apiv1beta1/auxiliary.go b/bigquery/connection/apiv1beta1/auxiliary.go index 7a3a690ca6a7..7d77befe3f6f 100755 --- a/bigquery/connection/apiv1beta1/auxiliary.go +++ b/bigquery/connection/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/connection/apiv1beta1/auxiliary_go123.go b/bigquery/connection/apiv1beta1/auxiliary_go123.go index 6d38a03e06d4..6f6ea59d2017 100755 --- a/bigquery/connection/apiv1beta1/auxiliary_go123.go +++ b/bigquery/connection/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/connection/apiv1beta1/connection_client.go b/bigquery/connection/apiv1beta1/connection_client.go index b700a2b8a8ea..9be9ae334ef6 100755 --- a/bigquery/connection/apiv1beta1/connection_client.go +++ b/bigquery/connection/apiv1beta1/connection_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/connection/apiv1beta1/connection_client_example_go123_test.go b/bigquery/connection/apiv1beta1/connection_client_example_go123_test.go index 4fe7dbc0baf5..7abecabc1d4d 100644 --- a/bigquery/connection/apiv1beta1/connection_client_example_go123_test.go +++ b/bigquery/connection/apiv1beta1/connection_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/connection/apiv1beta1/connection_client_example_test.go b/bigquery/connection/apiv1beta1/connection_client_example_test.go index 39e4384401e0..22491cd6e963 100644 --- a/bigquery/connection/apiv1beta1/connection_client_example_test.go +++ b/bigquery/connection/apiv1beta1/connection_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/connection/apiv1beta1/doc.go b/bigquery/connection/apiv1beta1/doc.go index 76717e9c879b..1c1ac01136c7 100755 --- a/bigquery/connection/apiv1beta1/doc.go +++ b/bigquery/connection/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/connection/apiv1beta1/helpers.go b/bigquery/connection/apiv1beta1/helpers.go index b1d38b75e997..deb1371bd1a3 100755 --- a/bigquery/connection/apiv1beta1/helpers.go +++ b/bigquery/connection/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/dataexchange/apiv1beta1/analytics_hub_client.go b/bigquery/dataexchange/apiv1beta1/analytics_hub_client.go index 47490715d57c..d860f1952157 100755 --- a/bigquery/dataexchange/apiv1beta1/analytics_hub_client.go +++ b/bigquery/dataexchange/apiv1beta1/analytics_hub_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/dataexchange/apiv1beta1/analytics_hub_client_example_go123_test.go b/bigquery/dataexchange/apiv1beta1/analytics_hub_client_example_go123_test.go index a276f71157ba..71fd6661e202 100644 --- a/bigquery/dataexchange/apiv1beta1/analytics_hub_client_example_go123_test.go +++ b/bigquery/dataexchange/apiv1beta1/analytics_hub_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/dataexchange/apiv1beta1/analytics_hub_client_example_test.go b/bigquery/dataexchange/apiv1beta1/analytics_hub_client_example_test.go index 13a2bbfe3e90..ef4ed943393e 100644 --- a/bigquery/dataexchange/apiv1beta1/analytics_hub_client_example_test.go +++ b/bigquery/dataexchange/apiv1beta1/analytics_hub_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/dataexchange/apiv1beta1/auxiliary.go b/bigquery/dataexchange/apiv1beta1/auxiliary.go index f82ef212daa7..73cb8575cc5e 100755 --- a/bigquery/dataexchange/apiv1beta1/auxiliary.go +++ b/bigquery/dataexchange/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/dataexchange/apiv1beta1/auxiliary_go123.go b/bigquery/dataexchange/apiv1beta1/auxiliary_go123.go index 41ef05514c44..04315a5c3011 100755 --- a/bigquery/dataexchange/apiv1beta1/auxiliary_go123.go +++ b/bigquery/dataexchange/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/dataexchange/apiv1beta1/doc.go b/bigquery/dataexchange/apiv1beta1/doc.go index 4bd0365cad56..9170b70f232b 100755 --- a/bigquery/dataexchange/apiv1beta1/doc.go +++ b/bigquery/dataexchange/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/dataexchange/apiv1beta1/helpers.go b/bigquery/dataexchange/apiv1beta1/helpers.go index d920840cb572..109ee4685740 100755 --- a/bigquery/dataexchange/apiv1beta1/helpers.go +++ b/bigquery/dataexchange/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/datapolicies/apiv1/auxiliary.go b/bigquery/datapolicies/apiv1/auxiliary.go index 5274b4bda8f3..975914bf7797 100755 --- a/bigquery/datapolicies/apiv1/auxiliary.go +++ b/bigquery/datapolicies/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/datapolicies/apiv1/auxiliary_go123.go b/bigquery/datapolicies/apiv1/auxiliary_go123.go index 8f3a4ec9e62b..3d159c44daa8 100755 --- a/bigquery/datapolicies/apiv1/auxiliary_go123.go +++ b/bigquery/datapolicies/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/datapolicies/apiv1/data_policy_client.go b/bigquery/datapolicies/apiv1/data_policy_client.go index f01cfb271c1d..4a27c43f40bb 100755 --- a/bigquery/datapolicies/apiv1/data_policy_client.go +++ b/bigquery/datapolicies/apiv1/data_policy_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/datapolicies/apiv1/data_policy_client_example_go123_test.go b/bigquery/datapolicies/apiv1/data_policy_client_example_go123_test.go index 60affc8883c7..5ab0a84a7398 100644 --- a/bigquery/datapolicies/apiv1/data_policy_client_example_go123_test.go +++ b/bigquery/datapolicies/apiv1/data_policy_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/datapolicies/apiv1/data_policy_client_example_test.go b/bigquery/datapolicies/apiv1/data_policy_client_example_test.go index c10dbd997a70..a5ba3c052dd3 100644 --- a/bigquery/datapolicies/apiv1/data_policy_client_example_test.go +++ b/bigquery/datapolicies/apiv1/data_policy_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/datapolicies/apiv1/doc.go b/bigquery/datapolicies/apiv1/doc.go index 0a12fd6aa645..3c6967f3b445 100755 --- a/bigquery/datapolicies/apiv1/doc.go +++ b/bigquery/datapolicies/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/datapolicies/apiv1/helpers.go b/bigquery/datapolicies/apiv1/helpers.go index d181ebb73c2b..d1e6f89df6c9 100755 --- a/bigquery/datapolicies/apiv1/helpers.go +++ b/bigquery/datapolicies/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/datapolicies/apiv1beta1/auxiliary.go b/bigquery/datapolicies/apiv1beta1/auxiliary.go index 2e913c00979f..fde53d1f89a6 100755 --- a/bigquery/datapolicies/apiv1beta1/auxiliary.go +++ b/bigquery/datapolicies/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/datapolicies/apiv1beta1/auxiliary_go123.go b/bigquery/datapolicies/apiv1beta1/auxiliary_go123.go index 634dc348875d..71a70845a3a6 100755 --- a/bigquery/datapolicies/apiv1beta1/auxiliary_go123.go +++ b/bigquery/datapolicies/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/datapolicies/apiv1beta1/data_policy_client.go b/bigquery/datapolicies/apiv1beta1/data_policy_client.go index ee52fdf3e808..5fefcfbe498e 100755 --- a/bigquery/datapolicies/apiv1beta1/data_policy_client.go +++ b/bigquery/datapolicies/apiv1beta1/data_policy_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/datapolicies/apiv1beta1/data_policy_client_example_go123_test.go b/bigquery/datapolicies/apiv1beta1/data_policy_client_example_go123_test.go index f95296281ac6..bff3e693b6a6 100644 --- a/bigquery/datapolicies/apiv1beta1/data_policy_client_example_go123_test.go +++ b/bigquery/datapolicies/apiv1beta1/data_policy_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/datapolicies/apiv1beta1/data_policy_client_example_test.go b/bigquery/datapolicies/apiv1beta1/data_policy_client_example_test.go index 6317dbb86c7d..0f004fbd448c 100644 --- a/bigquery/datapolicies/apiv1beta1/data_policy_client_example_test.go +++ b/bigquery/datapolicies/apiv1beta1/data_policy_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/datapolicies/apiv1beta1/doc.go b/bigquery/datapolicies/apiv1beta1/doc.go index 37248ef3e890..39e66bbc495e 100755 --- a/bigquery/datapolicies/apiv1beta1/doc.go +++ b/bigquery/datapolicies/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/datapolicies/apiv1beta1/helpers.go b/bigquery/datapolicies/apiv1beta1/helpers.go index d181ebb73c2b..d1e6f89df6c9 100755 --- a/bigquery/datapolicies/apiv1beta1/helpers.go +++ b/bigquery/datapolicies/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/datatransfer/apiv1/auxiliary.go b/bigquery/datatransfer/apiv1/auxiliary.go index 6f804c9f0eb9..9f126b7d6f6c 100755 --- a/bigquery/datatransfer/apiv1/auxiliary.go +++ b/bigquery/datatransfer/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/datatransfer/apiv1/auxiliary_go123.go b/bigquery/datatransfer/apiv1/auxiliary_go123.go index 8436dfb4ea6a..3b0b228a96ce 100755 --- a/bigquery/datatransfer/apiv1/auxiliary_go123.go +++ b/bigquery/datatransfer/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/datatransfer/apiv1/data_transfer_client.go b/bigquery/datatransfer/apiv1/data_transfer_client.go index b1290eb7b620..5b157f6e6cbd 100755 --- a/bigquery/datatransfer/apiv1/data_transfer_client.go +++ b/bigquery/datatransfer/apiv1/data_transfer_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/datatransfer/apiv1/data_transfer_client_example_go123_test.go b/bigquery/datatransfer/apiv1/data_transfer_client_example_go123_test.go index 41a681206800..ee972ff1f26a 100644 --- a/bigquery/datatransfer/apiv1/data_transfer_client_example_go123_test.go +++ b/bigquery/datatransfer/apiv1/data_transfer_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/datatransfer/apiv1/data_transfer_client_example_test.go b/bigquery/datatransfer/apiv1/data_transfer_client_example_test.go index 3aac5acfcfca..4de522c415c8 100644 --- a/bigquery/datatransfer/apiv1/data_transfer_client_example_test.go +++ b/bigquery/datatransfer/apiv1/data_transfer_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/datatransfer/apiv1/doc.go b/bigquery/datatransfer/apiv1/doc.go index ce0d2a30a89e..b086ac08bae6 100755 --- a/bigquery/datatransfer/apiv1/doc.go +++ b/bigquery/datatransfer/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/datatransfer/apiv1/helpers.go b/bigquery/datatransfer/apiv1/helpers.go index adf15229c849..3ae9e144dcda 100755 --- a/bigquery/datatransfer/apiv1/helpers.go +++ b/bigquery/datatransfer/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/migration/apiv2/auxiliary.go b/bigquery/migration/apiv2/auxiliary.go index 8a850822d497..a732e38ca430 100755 --- a/bigquery/migration/apiv2/auxiliary.go +++ b/bigquery/migration/apiv2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/migration/apiv2/auxiliary_go123.go b/bigquery/migration/apiv2/auxiliary_go123.go index 72dc9a8f639c..92869e960891 100755 --- a/bigquery/migration/apiv2/auxiliary_go123.go +++ b/bigquery/migration/apiv2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/migration/apiv2/doc.go b/bigquery/migration/apiv2/doc.go index 56aa53af3d7d..0307552649e3 100755 --- a/bigquery/migration/apiv2/doc.go +++ b/bigquery/migration/apiv2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/migration/apiv2/helpers.go b/bigquery/migration/apiv2/helpers.go index 787c991df8a3..7dff400ec73f 100755 --- a/bigquery/migration/apiv2/helpers.go +++ b/bigquery/migration/apiv2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/migration/apiv2/migration_client.go b/bigquery/migration/apiv2/migration_client.go index a4b505c296ec..41e33980e86a 100755 --- a/bigquery/migration/apiv2/migration_client.go +++ b/bigquery/migration/apiv2/migration_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/migration/apiv2/migration_client_example_go123_test.go b/bigquery/migration/apiv2/migration_client_example_go123_test.go index b04df1685745..825896ac9c82 100644 --- a/bigquery/migration/apiv2/migration_client_example_go123_test.go +++ b/bigquery/migration/apiv2/migration_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/migration/apiv2/migration_client_example_test.go b/bigquery/migration/apiv2/migration_client_example_test.go index 1bc0fb8e406c..490c7c38fc28 100644 --- a/bigquery/migration/apiv2/migration_client_example_test.go +++ b/bigquery/migration/apiv2/migration_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/migration/apiv2alpha/auxiliary.go b/bigquery/migration/apiv2alpha/auxiliary.go index ef2396fc43da..b371f4304b12 100755 --- a/bigquery/migration/apiv2alpha/auxiliary.go +++ b/bigquery/migration/apiv2alpha/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/migration/apiv2alpha/auxiliary_go123.go b/bigquery/migration/apiv2alpha/auxiliary_go123.go index adfc46a723c9..afd36cb6e05e 100755 --- a/bigquery/migration/apiv2alpha/auxiliary_go123.go +++ b/bigquery/migration/apiv2alpha/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/migration/apiv2alpha/doc.go b/bigquery/migration/apiv2alpha/doc.go index 7f99446ffaac..9d24f72c10b8 100755 --- a/bigquery/migration/apiv2alpha/doc.go +++ b/bigquery/migration/apiv2alpha/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/migration/apiv2alpha/helpers.go b/bigquery/migration/apiv2alpha/helpers.go index 88eb4d93c10c..131b001cf6c3 100755 --- a/bigquery/migration/apiv2alpha/helpers.go +++ b/bigquery/migration/apiv2alpha/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/migration/apiv2alpha/migration_client.go b/bigquery/migration/apiv2alpha/migration_client.go index 868e1dd860c6..147f36da429f 100755 --- a/bigquery/migration/apiv2alpha/migration_client.go +++ b/bigquery/migration/apiv2alpha/migration_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/migration/apiv2alpha/migration_client_example_go123_test.go b/bigquery/migration/apiv2alpha/migration_client_example_go123_test.go index 06da34bfb8f8..39f127f7a5ff 100644 --- a/bigquery/migration/apiv2alpha/migration_client_example_go123_test.go +++ b/bigquery/migration/apiv2alpha/migration_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/migration/apiv2alpha/migration_client_example_test.go b/bigquery/migration/apiv2alpha/migration_client_example_test.go index ad1a3b970af6..aed19622f1b7 100644 --- a/bigquery/migration/apiv2alpha/migration_client_example_test.go +++ b/bigquery/migration/apiv2alpha/migration_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/migration/apiv2alpha/sql_translation_client.go b/bigquery/migration/apiv2alpha/sql_translation_client.go index 70da010bafe7..852add2b9b01 100755 --- a/bigquery/migration/apiv2alpha/sql_translation_client.go +++ b/bigquery/migration/apiv2alpha/sql_translation_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/migration/apiv2alpha/sql_translation_client_example_go123_test.go b/bigquery/migration/apiv2alpha/sql_translation_client_example_go123_test.go index dfbef20a398e..37d76e63c6b4 100644 --- a/bigquery/migration/apiv2alpha/sql_translation_client_example_go123_test.go +++ b/bigquery/migration/apiv2alpha/sql_translation_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/migration/apiv2alpha/sql_translation_client_example_test.go b/bigquery/migration/apiv2alpha/sql_translation_client_example_test.go index 17eea2a20e22..130eadcf7a05 100644 --- a/bigquery/migration/apiv2alpha/sql_translation_client_example_test.go +++ b/bigquery/migration/apiv2alpha/sql_translation_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/reservation/apiv1/auxiliary.go b/bigquery/reservation/apiv1/auxiliary.go index c5048cd1fad9..5a6e783c74fb 100755 --- a/bigquery/reservation/apiv1/auxiliary.go +++ b/bigquery/reservation/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/reservation/apiv1/auxiliary_go123.go b/bigquery/reservation/apiv1/auxiliary_go123.go index 1cba7459b763..bf132489b8c5 100755 --- a/bigquery/reservation/apiv1/auxiliary_go123.go +++ b/bigquery/reservation/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/reservation/apiv1/doc.go b/bigquery/reservation/apiv1/doc.go index f0538a71d470..c12a8c1c6501 100755 --- a/bigquery/reservation/apiv1/doc.go +++ b/bigquery/reservation/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/reservation/apiv1/helpers.go b/bigquery/reservation/apiv1/helpers.go index 73d1c230cf7e..3f282354eccd 100755 --- a/bigquery/reservation/apiv1/helpers.go +++ b/bigquery/reservation/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/reservation/apiv1/reservation_client.go b/bigquery/reservation/apiv1/reservation_client.go index 5b4e71c7fe36..867da21ace00 100755 --- a/bigquery/reservation/apiv1/reservation_client.go +++ b/bigquery/reservation/apiv1/reservation_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/reservation/apiv1/reservation_client_example_go123_test.go b/bigquery/reservation/apiv1/reservation_client_example_go123_test.go index f5c4f0c8ffa3..607f5ac29583 100644 --- a/bigquery/reservation/apiv1/reservation_client_example_go123_test.go +++ b/bigquery/reservation/apiv1/reservation_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/reservation/apiv1/reservation_client_example_test.go b/bigquery/reservation/apiv1/reservation_client_example_test.go index 175375cfc48d..8364b358a050 100644 --- a/bigquery/reservation/apiv1/reservation_client_example_test.go +++ b/bigquery/reservation/apiv1/reservation_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1/auxiliary.go b/bigquery/storage/apiv1/auxiliary.go index 8f7891d25e1b..58c4db472594 100755 --- a/bigquery/storage/apiv1/auxiliary.go +++ b/bigquery/storage/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1/auxiliary_go123.go b/bigquery/storage/apiv1/auxiliary_go123.go index 7c7ca20370e3..014680d6504e 100755 --- a/bigquery/storage/apiv1/auxiliary_go123.go +++ b/bigquery/storage/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1/big_query_read_client.go b/bigquery/storage/apiv1/big_query_read_client.go index e46676a4b52f..5db463a1e9d8 100755 --- a/bigquery/storage/apiv1/big_query_read_client.go +++ b/bigquery/storage/apiv1/big_query_read_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1/big_query_read_client_example_go123_test.go b/bigquery/storage/apiv1/big_query_read_client_example_go123_test.go index c496a9cc0d15..c9b919987935 100644 --- a/bigquery/storage/apiv1/big_query_read_client_example_go123_test.go +++ b/bigquery/storage/apiv1/big_query_read_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1/big_query_read_client_example_test.go b/bigquery/storage/apiv1/big_query_read_client_example_test.go index cdfc7a7d842b..5aa14b07f35c 100644 --- a/bigquery/storage/apiv1/big_query_read_client_example_test.go +++ b/bigquery/storage/apiv1/big_query_read_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1/big_query_write_client.go b/bigquery/storage/apiv1/big_query_write_client.go index f5e1db3bb64a..d14a281b65d1 100755 --- a/bigquery/storage/apiv1/big_query_write_client.go +++ b/bigquery/storage/apiv1/big_query_write_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1/big_query_write_client_example_go123_test.go b/bigquery/storage/apiv1/big_query_write_client_example_go123_test.go index c496a9cc0d15..c9b919987935 100644 --- a/bigquery/storage/apiv1/big_query_write_client_example_go123_test.go +++ b/bigquery/storage/apiv1/big_query_write_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1/big_query_write_client_example_test.go b/bigquery/storage/apiv1/big_query_write_client_example_test.go index c6e3b869d4db..ad3dbb488f46 100644 --- a/bigquery/storage/apiv1/big_query_write_client_example_test.go +++ b/bigquery/storage/apiv1/big_query_write_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1/doc.go b/bigquery/storage/apiv1/doc.go index 8c55fa1299bd..025ec93f01f3 100755 --- a/bigquery/storage/apiv1/doc.go +++ b/bigquery/storage/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1/helpers.go b/bigquery/storage/apiv1/helpers.go index 6966ca08d948..b9a068f5d589 100755 --- a/bigquery/storage/apiv1/helpers.go +++ b/bigquery/storage/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1alpha/auxiliary.go b/bigquery/storage/apiv1alpha/auxiliary.go index 8f7891d25e1b..58c4db472594 100755 --- a/bigquery/storage/apiv1alpha/auxiliary.go +++ b/bigquery/storage/apiv1alpha/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1alpha/auxiliary_go123.go b/bigquery/storage/apiv1alpha/auxiliary_go123.go index 7c7ca20370e3..014680d6504e 100755 --- a/bigquery/storage/apiv1alpha/auxiliary_go123.go +++ b/bigquery/storage/apiv1alpha/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1alpha/doc.go b/bigquery/storage/apiv1alpha/doc.go index 02a910ab8516..9a690317265c 100755 --- a/bigquery/storage/apiv1alpha/doc.go +++ b/bigquery/storage/apiv1alpha/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1alpha/helpers.go b/bigquery/storage/apiv1alpha/helpers.go index 3cbeba8cc05d..0038a01b77e2 100755 --- a/bigquery/storage/apiv1alpha/helpers.go +++ b/bigquery/storage/apiv1alpha/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1alpha/metastore_partition_client.go b/bigquery/storage/apiv1alpha/metastore_partition_client.go index fa16f69ac205..dbf41d1dd4b8 100755 --- a/bigquery/storage/apiv1alpha/metastore_partition_client.go +++ b/bigquery/storage/apiv1alpha/metastore_partition_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1alpha/metastore_partition_client_example_go123_test.go b/bigquery/storage/apiv1alpha/metastore_partition_client_example_go123_test.go index c496a9cc0d15..c9b919987935 100644 --- a/bigquery/storage/apiv1alpha/metastore_partition_client_example_go123_test.go +++ b/bigquery/storage/apiv1alpha/metastore_partition_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1alpha/metastore_partition_client_example_test.go b/bigquery/storage/apiv1alpha/metastore_partition_client_example_test.go index 3acdd07ca5fc..ca54518f2ba6 100644 --- a/bigquery/storage/apiv1alpha/metastore_partition_client_example_test.go +++ b/bigquery/storage/apiv1alpha/metastore_partition_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1beta1/auxiliary.go b/bigquery/storage/apiv1beta1/auxiliary.go index 8f7891d25e1b..58c4db472594 100755 --- a/bigquery/storage/apiv1beta1/auxiliary.go +++ b/bigquery/storage/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1beta1/auxiliary_go123.go b/bigquery/storage/apiv1beta1/auxiliary_go123.go index 7c7ca20370e3..014680d6504e 100755 --- a/bigquery/storage/apiv1beta1/auxiliary_go123.go +++ b/bigquery/storage/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1beta1/big_query_storage_client.go b/bigquery/storage/apiv1beta1/big_query_storage_client.go index 7c9aa3e7702c..d48087227639 100755 --- a/bigquery/storage/apiv1beta1/big_query_storage_client.go +++ b/bigquery/storage/apiv1beta1/big_query_storage_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1beta1/big_query_storage_client_example_go123_test.go b/bigquery/storage/apiv1beta1/big_query_storage_client_example_go123_test.go index c496a9cc0d15..c9b919987935 100644 --- a/bigquery/storage/apiv1beta1/big_query_storage_client_example_go123_test.go +++ b/bigquery/storage/apiv1beta1/big_query_storage_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1beta1/big_query_storage_client_example_test.go b/bigquery/storage/apiv1beta1/big_query_storage_client_example_test.go index 96e2a0cfbfd6..03e13dd0fbe2 100644 --- a/bigquery/storage/apiv1beta1/big_query_storage_client_example_test.go +++ b/bigquery/storage/apiv1beta1/big_query_storage_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1beta1/doc.go b/bigquery/storage/apiv1beta1/doc.go index 5f951e03079d..2e5550af12ae 100755 --- a/bigquery/storage/apiv1beta1/doc.go +++ b/bigquery/storage/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1beta1/helpers.go b/bigquery/storage/apiv1beta1/helpers.go index 58cb21952be3..fe4480d1e112 100755 --- a/bigquery/storage/apiv1beta1/helpers.go +++ b/bigquery/storage/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1beta2/auxiliary.go b/bigquery/storage/apiv1beta2/auxiliary.go index 8f7891d25e1b..58c4db472594 100755 --- a/bigquery/storage/apiv1beta2/auxiliary.go +++ b/bigquery/storage/apiv1beta2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1beta2/auxiliary_go123.go b/bigquery/storage/apiv1beta2/auxiliary_go123.go index 7c7ca20370e3..014680d6504e 100755 --- a/bigquery/storage/apiv1beta2/auxiliary_go123.go +++ b/bigquery/storage/apiv1beta2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1beta2/big_query_read_client.go b/bigquery/storage/apiv1beta2/big_query_read_client.go index aa30f4aa9e2c..16b7ce02cb53 100755 --- a/bigquery/storage/apiv1beta2/big_query_read_client.go +++ b/bigquery/storage/apiv1beta2/big_query_read_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1beta2/big_query_read_client_example_go123_test.go b/bigquery/storage/apiv1beta2/big_query_read_client_example_go123_test.go index c496a9cc0d15..c9b919987935 100644 --- a/bigquery/storage/apiv1beta2/big_query_read_client_example_go123_test.go +++ b/bigquery/storage/apiv1beta2/big_query_read_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1beta2/big_query_read_client_example_test.go b/bigquery/storage/apiv1beta2/big_query_read_client_example_test.go index ee2c36339acc..61ba720b3b42 100644 --- a/bigquery/storage/apiv1beta2/big_query_read_client_example_test.go +++ b/bigquery/storage/apiv1beta2/big_query_read_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1beta2/big_query_write_client.go b/bigquery/storage/apiv1beta2/big_query_write_client.go index cb145ce97271..1dd448e5a45d 100755 --- a/bigquery/storage/apiv1beta2/big_query_write_client.go +++ b/bigquery/storage/apiv1beta2/big_query_write_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1beta2/big_query_write_client_example_go123_test.go b/bigquery/storage/apiv1beta2/big_query_write_client_example_go123_test.go index c496a9cc0d15..c9b919987935 100644 --- a/bigquery/storage/apiv1beta2/big_query_write_client_example_go123_test.go +++ b/bigquery/storage/apiv1beta2/big_query_write_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1beta2/big_query_write_client_example_test.go b/bigquery/storage/apiv1beta2/big_query_write_client_example_test.go index 3f2c7c3bab39..f4ac631cc36d 100644 --- a/bigquery/storage/apiv1beta2/big_query_write_client_example_test.go +++ b/bigquery/storage/apiv1beta2/big_query_write_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1beta2/doc.go b/bigquery/storage/apiv1beta2/doc.go index 024dc4ef04fa..680ba9b4de6c 100755 --- a/bigquery/storage/apiv1beta2/doc.go +++ b/bigquery/storage/apiv1beta2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/bigquery/storage/apiv1beta2/helpers.go b/bigquery/storage/apiv1beta2/helpers.go index 9117797ec19c..dad757a1aaf7 100755 --- a/bigquery/storage/apiv1beta2/helpers.go +++ b/bigquery/storage/apiv1beta2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/billing/apiv1/auxiliary.go b/billing/apiv1/auxiliary.go index 829a5d3fe543..a8542998828e 100755 --- a/billing/apiv1/auxiliary.go +++ b/billing/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/billing/apiv1/auxiliary_go123.go b/billing/apiv1/auxiliary_go123.go index 00e641884427..1106ab5afa51 100755 --- a/billing/apiv1/auxiliary_go123.go +++ b/billing/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/billing/apiv1/cloud_billing_client.go b/billing/apiv1/cloud_billing_client.go index 471cb5719c93..925636d71099 100755 --- a/billing/apiv1/cloud_billing_client.go +++ b/billing/apiv1/cloud_billing_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/billing/apiv1/cloud_billing_client_example_go123_test.go b/billing/apiv1/cloud_billing_client_example_go123_test.go index 72a0b6d76c58..de091ff235fc 100644 --- a/billing/apiv1/cloud_billing_client_example_go123_test.go +++ b/billing/apiv1/cloud_billing_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/billing/apiv1/cloud_billing_client_example_test.go b/billing/apiv1/cloud_billing_client_example_test.go index 17f2301eca05..b0ee09ebae28 100644 --- a/billing/apiv1/cloud_billing_client_example_test.go +++ b/billing/apiv1/cloud_billing_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/billing/apiv1/cloud_catalog_client.go b/billing/apiv1/cloud_catalog_client.go index bb03ca8a4122..87f99e7b8442 100755 --- a/billing/apiv1/cloud_catalog_client.go +++ b/billing/apiv1/cloud_catalog_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/billing/apiv1/cloud_catalog_client_example_go123_test.go b/billing/apiv1/cloud_catalog_client_example_go123_test.go index a749f86cd412..af008f7c08a1 100644 --- a/billing/apiv1/cloud_catalog_client_example_go123_test.go +++ b/billing/apiv1/cloud_catalog_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/billing/apiv1/cloud_catalog_client_example_test.go b/billing/apiv1/cloud_catalog_client_example_test.go index 18d3eb78ba55..65785cb4b46a 100644 --- a/billing/apiv1/cloud_catalog_client_example_test.go +++ b/billing/apiv1/cloud_catalog_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/billing/apiv1/doc.go b/billing/apiv1/doc.go index 9718685a1bc7..2ce55bc76871 100755 --- a/billing/apiv1/doc.go +++ b/billing/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/billing/apiv1/helpers.go b/billing/apiv1/helpers.go index 319fd3efdfaf..fa4abae14519 100755 --- a/billing/apiv1/helpers.go +++ b/billing/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/billing/budgets/apiv1/auxiliary.go b/billing/budgets/apiv1/auxiliary.go index affa58cafaf3..bf945270eefa 100755 --- a/billing/budgets/apiv1/auxiliary.go +++ b/billing/budgets/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/billing/budgets/apiv1/auxiliary_go123.go b/billing/budgets/apiv1/auxiliary_go123.go index 8fccb4b5872e..92302ed20c9e 100755 --- a/billing/budgets/apiv1/auxiliary_go123.go +++ b/billing/budgets/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/billing/budgets/apiv1/budget_client.go b/billing/budgets/apiv1/budget_client.go index b50654b8be17..fcc9388c454a 100755 --- a/billing/budgets/apiv1/budget_client.go +++ b/billing/budgets/apiv1/budget_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/billing/budgets/apiv1/budget_client_example_go123_test.go b/billing/budgets/apiv1/budget_client_example_go123_test.go index 46e10a9d1923..756fa13e80a5 100644 --- a/billing/budgets/apiv1/budget_client_example_go123_test.go +++ b/billing/budgets/apiv1/budget_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/billing/budgets/apiv1/budget_client_example_test.go b/billing/budgets/apiv1/budget_client_example_test.go index c544a9d04282..4b59614e85de 100644 --- a/billing/budgets/apiv1/budget_client_example_test.go +++ b/billing/budgets/apiv1/budget_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/billing/budgets/apiv1/doc.go b/billing/budgets/apiv1/doc.go index 1104b9bf398a..8ec3e93e39b2 100755 --- a/billing/budgets/apiv1/doc.go +++ b/billing/budgets/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/billing/budgets/apiv1/helpers.go b/billing/budgets/apiv1/helpers.go index 3c9e9de49bc3..d20a4e76ad64 100755 --- a/billing/budgets/apiv1/helpers.go +++ b/billing/budgets/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/billing/budgets/apiv1beta1/auxiliary.go b/billing/budgets/apiv1beta1/auxiliary.go index c4bb01111146..b81e03a6a2ad 100755 --- a/billing/budgets/apiv1beta1/auxiliary.go +++ b/billing/budgets/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/billing/budgets/apiv1beta1/auxiliary_go123.go b/billing/budgets/apiv1beta1/auxiliary_go123.go index 787d1666bf1e..48b1f5258a2e 100755 --- a/billing/budgets/apiv1beta1/auxiliary_go123.go +++ b/billing/budgets/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/billing/budgets/apiv1beta1/budget_client.go b/billing/budgets/apiv1beta1/budget_client.go index 61ba8981b5c6..83654f5d0f37 100755 --- a/billing/budgets/apiv1beta1/budget_client.go +++ b/billing/budgets/apiv1beta1/budget_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/billing/budgets/apiv1beta1/budget_client_example_go123_test.go b/billing/budgets/apiv1beta1/budget_client_example_go123_test.go index a3fdeaab5454..8bf9d3780a1b 100644 --- a/billing/budgets/apiv1beta1/budget_client_example_go123_test.go +++ b/billing/budgets/apiv1beta1/budget_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/billing/budgets/apiv1beta1/budget_client_example_test.go b/billing/budgets/apiv1beta1/budget_client_example_test.go index 145a75a5f643..bf041277d62e 100644 --- a/billing/budgets/apiv1beta1/budget_client_example_test.go +++ b/billing/budgets/apiv1beta1/budget_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/billing/budgets/apiv1beta1/doc.go b/billing/budgets/apiv1beta1/doc.go index 3ad7cf4dc37a..2d564be80a70 100755 --- a/billing/budgets/apiv1beta1/doc.go +++ b/billing/budgets/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/billing/budgets/apiv1beta1/helpers.go b/billing/budgets/apiv1beta1/helpers.go index 3c9e9de49bc3..d20a4e76ad64 100755 --- a/billing/budgets/apiv1beta1/helpers.go +++ b/billing/budgets/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/binaryauthorization/apiv1/auxiliary.go b/binaryauthorization/apiv1/auxiliary.go index 34494eb1c5fb..7eec115495c3 100755 --- a/binaryauthorization/apiv1/auxiliary.go +++ b/binaryauthorization/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/binaryauthorization/apiv1/auxiliary_go123.go b/binaryauthorization/apiv1/auxiliary_go123.go index 414a9d53d5d2..701b8c50a728 100755 --- a/binaryauthorization/apiv1/auxiliary_go123.go +++ b/binaryauthorization/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/binaryauthorization/apiv1/binauthz_management_client.go b/binaryauthorization/apiv1/binauthz_management_client.go index 33c6b35b83cd..85266871735c 100755 --- a/binaryauthorization/apiv1/binauthz_management_client.go +++ b/binaryauthorization/apiv1/binauthz_management_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/binaryauthorization/apiv1/binauthz_management_client_example_go123_test.go b/binaryauthorization/apiv1/binauthz_management_client_example_go123_test.go index 251353863623..c4d9238c6ee9 100644 --- a/binaryauthorization/apiv1/binauthz_management_client_example_go123_test.go +++ b/binaryauthorization/apiv1/binauthz_management_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/binaryauthorization/apiv1/binauthz_management_client_example_test.go b/binaryauthorization/apiv1/binauthz_management_client_example_test.go index 312129c0aed4..16c47145ffff 100644 --- a/binaryauthorization/apiv1/binauthz_management_client_example_test.go +++ b/binaryauthorization/apiv1/binauthz_management_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/binaryauthorization/apiv1/doc.go b/binaryauthorization/apiv1/doc.go index 22a52f115a4d..d2185fecb425 100755 --- a/binaryauthorization/apiv1/doc.go +++ b/binaryauthorization/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/binaryauthorization/apiv1/helpers.go b/binaryauthorization/apiv1/helpers.go index 7026874ad16f..69f0460cf629 100755 --- a/binaryauthorization/apiv1/helpers.go +++ b/binaryauthorization/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/binaryauthorization/apiv1/system_policy_client.go b/binaryauthorization/apiv1/system_policy_client.go index 2e4d6e1e8eb7..c3fff725c030 100755 --- a/binaryauthorization/apiv1/system_policy_client.go +++ b/binaryauthorization/apiv1/system_policy_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/binaryauthorization/apiv1/system_policy_client_example_go123_test.go b/binaryauthorization/apiv1/system_policy_client_example_go123_test.go index e5a73c6a29cd..5bad736b75f8 100644 --- a/binaryauthorization/apiv1/system_policy_client_example_go123_test.go +++ b/binaryauthorization/apiv1/system_policy_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/binaryauthorization/apiv1/system_policy_client_example_test.go b/binaryauthorization/apiv1/system_policy_client_example_test.go index fdf9e44f4af9..9bd41f8c1495 100644 --- a/binaryauthorization/apiv1/system_policy_client_example_test.go +++ b/binaryauthorization/apiv1/system_policy_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/binaryauthorization/apiv1/validation_helper_client.go b/binaryauthorization/apiv1/validation_helper_client.go index b498978fb281..19dcb3d10a0f 100755 --- a/binaryauthorization/apiv1/validation_helper_client.go +++ b/binaryauthorization/apiv1/validation_helper_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/binaryauthorization/apiv1/validation_helper_client_example_go123_test.go b/binaryauthorization/apiv1/validation_helper_client_example_go123_test.go index e5a73c6a29cd..5bad736b75f8 100644 --- a/binaryauthorization/apiv1/validation_helper_client_example_go123_test.go +++ b/binaryauthorization/apiv1/validation_helper_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/binaryauthorization/apiv1/validation_helper_client_example_test.go b/binaryauthorization/apiv1/validation_helper_client_example_test.go index f8925b8909ab..bc3b5aa9535d 100644 --- a/binaryauthorization/apiv1/validation_helper_client_example_test.go +++ b/binaryauthorization/apiv1/validation_helper_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/binaryauthorization/apiv1beta1/auxiliary.go b/binaryauthorization/apiv1beta1/auxiliary.go index 159aae5b847c..51457f5bf28e 100755 --- a/binaryauthorization/apiv1beta1/auxiliary.go +++ b/binaryauthorization/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/binaryauthorization/apiv1beta1/auxiliary_go123.go b/binaryauthorization/apiv1beta1/auxiliary_go123.go index 5aa4c24186b2..6e8ebc9f852a 100755 --- a/binaryauthorization/apiv1beta1/auxiliary_go123.go +++ b/binaryauthorization/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/binaryauthorization/apiv1beta1/binauthz_management_service_v1_beta1_client.go b/binaryauthorization/apiv1beta1/binauthz_management_service_v1_beta1_client.go index bba225e3234f..63fd9cef46ab 100755 --- a/binaryauthorization/apiv1beta1/binauthz_management_service_v1_beta1_client.go +++ b/binaryauthorization/apiv1beta1/binauthz_management_service_v1_beta1_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/binaryauthorization/apiv1beta1/binauthz_management_service_v1_beta1_client_example_go123_test.go b/binaryauthorization/apiv1beta1/binauthz_management_service_v1_beta1_client_example_go123_test.go index 45026032c536..8d9cb643a6d6 100644 --- a/binaryauthorization/apiv1beta1/binauthz_management_service_v1_beta1_client_example_go123_test.go +++ b/binaryauthorization/apiv1beta1/binauthz_management_service_v1_beta1_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/binaryauthorization/apiv1beta1/binauthz_management_service_v1_beta1_client_example_test.go b/binaryauthorization/apiv1beta1/binauthz_management_service_v1_beta1_client_example_test.go index 4cb1ac95b2ee..60443732ba56 100644 --- a/binaryauthorization/apiv1beta1/binauthz_management_service_v1_beta1_client_example_test.go +++ b/binaryauthorization/apiv1beta1/binauthz_management_service_v1_beta1_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/binaryauthorization/apiv1beta1/doc.go b/binaryauthorization/apiv1beta1/doc.go index 8a9eb169f3b4..3d848bca7407 100755 --- a/binaryauthorization/apiv1beta1/doc.go +++ b/binaryauthorization/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/binaryauthorization/apiv1beta1/helpers.go b/binaryauthorization/apiv1beta1/helpers.go index 7026874ad16f..69f0460cf629 100755 --- a/binaryauthorization/apiv1beta1/helpers.go +++ b/binaryauthorization/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/binaryauthorization/apiv1beta1/system_policy_v1_beta1_client.go b/binaryauthorization/apiv1beta1/system_policy_v1_beta1_client.go index 2e3b90671546..46e9f3df57be 100755 --- a/binaryauthorization/apiv1beta1/system_policy_v1_beta1_client.go +++ b/binaryauthorization/apiv1beta1/system_policy_v1_beta1_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/binaryauthorization/apiv1beta1/system_policy_v1_beta1_client_example_go123_test.go b/binaryauthorization/apiv1beta1/system_policy_v1_beta1_client_example_go123_test.go index e5a73c6a29cd..5bad736b75f8 100644 --- a/binaryauthorization/apiv1beta1/system_policy_v1_beta1_client_example_go123_test.go +++ b/binaryauthorization/apiv1beta1/system_policy_v1_beta1_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/binaryauthorization/apiv1beta1/system_policy_v1_beta1_client_example_test.go b/binaryauthorization/apiv1beta1/system_policy_v1_beta1_client_example_test.go index e6142fd26c6c..ff0f1c25e76b 100644 --- a/binaryauthorization/apiv1beta1/system_policy_v1_beta1_client_example_test.go +++ b/binaryauthorization/apiv1beta1/system_policy_v1_beta1_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/certificatemanager/apiv1/auxiliary.go b/certificatemanager/apiv1/auxiliary.go index 4c0f50bf7437..91dea85d2a82 100755 --- a/certificatemanager/apiv1/auxiliary.go +++ b/certificatemanager/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/certificatemanager/apiv1/auxiliary_go123.go b/certificatemanager/apiv1/auxiliary_go123.go index 3a554603ac15..952b9050f1d2 100755 --- a/certificatemanager/apiv1/auxiliary_go123.go +++ b/certificatemanager/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/certificatemanager/apiv1/certificate_manager_client.go b/certificatemanager/apiv1/certificate_manager_client.go index e1057780e7e2..716d3865dfc2 100755 --- a/certificatemanager/apiv1/certificate_manager_client.go +++ b/certificatemanager/apiv1/certificate_manager_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/certificatemanager/apiv1/certificate_manager_client_example_go123_test.go b/certificatemanager/apiv1/certificate_manager_client_example_go123_test.go index 97bc783d0936..1b06b05d8826 100644 --- a/certificatemanager/apiv1/certificate_manager_client_example_go123_test.go +++ b/certificatemanager/apiv1/certificate_manager_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/certificatemanager/apiv1/certificate_manager_client_example_test.go b/certificatemanager/apiv1/certificate_manager_client_example_test.go index 74aa35ba1039..340277da97e3 100644 --- a/certificatemanager/apiv1/certificate_manager_client_example_test.go +++ b/certificatemanager/apiv1/certificate_manager_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/certificatemanager/apiv1/doc.go b/certificatemanager/apiv1/doc.go index 99fab4218c28..83bc5443fc18 100755 --- a/certificatemanager/apiv1/doc.go +++ b/certificatemanager/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/certificatemanager/apiv1/helpers.go b/certificatemanager/apiv1/helpers.go index 729b51b4cc75..959ae97ea9c8 100755 --- a/certificatemanager/apiv1/helpers.go +++ b/certificatemanager/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/channel/apiv1/auxiliary.go b/channel/apiv1/auxiliary.go index 065c6fd335f6..52b7039078c6 100755 --- a/channel/apiv1/auxiliary.go +++ b/channel/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/channel/apiv1/auxiliary_go123.go b/channel/apiv1/auxiliary_go123.go index 4c2dd1e2cd72..d2e533cea892 100755 --- a/channel/apiv1/auxiliary_go123.go +++ b/channel/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/channel/apiv1/cloud_channel_client.go b/channel/apiv1/cloud_channel_client.go index ccdcdce7c772..5f8d54d886e6 100755 --- a/channel/apiv1/cloud_channel_client.go +++ b/channel/apiv1/cloud_channel_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/channel/apiv1/cloud_channel_client_example_go123_test.go b/channel/apiv1/cloud_channel_client_example_go123_test.go index 0893a28dd2d4..653db2c5f7c9 100644 --- a/channel/apiv1/cloud_channel_client_example_go123_test.go +++ b/channel/apiv1/cloud_channel_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/channel/apiv1/cloud_channel_client_example_test.go b/channel/apiv1/cloud_channel_client_example_test.go index c4ce47237e3a..e43da056fae4 100644 --- a/channel/apiv1/cloud_channel_client_example_test.go +++ b/channel/apiv1/cloud_channel_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/channel/apiv1/cloud_channel_reports_client.go b/channel/apiv1/cloud_channel_reports_client.go index df1b4528c4e4..e7d2a19202ad 100755 --- a/channel/apiv1/cloud_channel_reports_client.go +++ b/channel/apiv1/cloud_channel_reports_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/channel/apiv1/cloud_channel_reports_client_example_go123_test.go b/channel/apiv1/cloud_channel_reports_client_example_go123_test.go index 44ef76ea1320..0c17fe9b5b00 100644 --- a/channel/apiv1/cloud_channel_reports_client_example_go123_test.go +++ b/channel/apiv1/cloud_channel_reports_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/channel/apiv1/cloud_channel_reports_client_example_test.go b/channel/apiv1/cloud_channel_reports_client_example_test.go index d2e4fb7bbfe3..72303a22609a 100644 --- a/channel/apiv1/cloud_channel_reports_client_example_test.go +++ b/channel/apiv1/cloud_channel_reports_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/channel/apiv1/doc.go b/channel/apiv1/doc.go index f2e444c1afeb..826e13d7ed2e 100755 --- a/channel/apiv1/doc.go +++ b/channel/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/channel/apiv1/helpers.go b/channel/apiv1/helpers.go index e9bcade9badd..7a825f25bfb9 100755 --- a/channel/apiv1/helpers.go +++ b/channel/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/chat/apiv1/auxiliary.go b/chat/apiv1/auxiliary.go index e478814ce26c..0a9e223782ed 100755 --- a/chat/apiv1/auxiliary.go +++ b/chat/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/chat/apiv1/auxiliary_go123.go b/chat/apiv1/auxiliary_go123.go index 973838be2f84..627c6f5a8e64 100755 --- a/chat/apiv1/auxiliary_go123.go +++ b/chat/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/chat/apiv1/chat_client.go b/chat/apiv1/chat_client.go index 13beae3da974..90758e19ecc7 100755 --- a/chat/apiv1/chat_client.go +++ b/chat/apiv1/chat_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/chat/apiv1/chat_client_example_go123_test.go b/chat/apiv1/chat_client_example_go123_test.go index 756f27a34314..3e0f021c16b4 100644 --- a/chat/apiv1/chat_client_example_go123_test.go +++ b/chat/apiv1/chat_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/chat/apiv1/chat_client_example_test.go b/chat/apiv1/chat_client_example_test.go index 2f1803d86b11..9a60b8e460b8 100644 --- a/chat/apiv1/chat_client_example_test.go +++ b/chat/apiv1/chat_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/chat/apiv1/doc.go b/chat/apiv1/doc.go index 9f53756be90f..1bf222e5c19f 100755 --- a/chat/apiv1/doc.go +++ b/chat/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/chat/apiv1/helpers.go b/chat/apiv1/helpers.go index b9bdb699e519..8ae5052d3426 100755 --- a/chat/apiv1/helpers.go +++ b/chat/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudbuild/apiv1/v2/auxiliary.go b/cloudbuild/apiv1/v2/auxiliary.go index c65684361f20..ba81b28079e5 100755 --- a/cloudbuild/apiv1/v2/auxiliary.go +++ b/cloudbuild/apiv1/v2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudbuild/apiv1/v2/auxiliary_go123.go b/cloudbuild/apiv1/v2/auxiliary_go123.go index 23883794361d..28535685d69a 100755 --- a/cloudbuild/apiv1/v2/auxiliary_go123.go +++ b/cloudbuild/apiv1/v2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudbuild/apiv1/v2/cloud_build_client.go b/cloudbuild/apiv1/v2/cloud_build_client.go index 75e5109c84ce..e5b2ff1fbc2d 100755 --- a/cloudbuild/apiv1/v2/cloud_build_client.go +++ b/cloudbuild/apiv1/v2/cloud_build_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudbuild/apiv1/v2/cloud_build_client_example_go123_test.go b/cloudbuild/apiv1/v2/cloud_build_client_example_go123_test.go index f07bd7fd1038..92c6e3ffeea6 100644 --- a/cloudbuild/apiv1/v2/cloud_build_client_example_go123_test.go +++ b/cloudbuild/apiv1/v2/cloud_build_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudbuild/apiv1/v2/cloud_build_client_example_test.go b/cloudbuild/apiv1/v2/cloud_build_client_example_test.go index e3260feec16e..f9407d4c37d4 100644 --- a/cloudbuild/apiv1/v2/cloud_build_client_example_test.go +++ b/cloudbuild/apiv1/v2/cloud_build_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudbuild/apiv1/v2/doc.go b/cloudbuild/apiv1/v2/doc.go index c6c62d70451d..67d9461bdb96 100755 --- a/cloudbuild/apiv1/v2/doc.go +++ b/cloudbuild/apiv1/v2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudbuild/apiv1/v2/helpers.go b/cloudbuild/apiv1/v2/helpers.go index f4827f6e7a18..dbac8241dd4f 100755 --- a/cloudbuild/apiv1/v2/helpers.go +++ b/cloudbuild/apiv1/v2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudbuild/apiv2/auxiliary.go b/cloudbuild/apiv2/auxiliary.go index 32f1ff5b7bd8..c1efa0445aee 100755 --- a/cloudbuild/apiv2/auxiliary.go +++ b/cloudbuild/apiv2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudbuild/apiv2/auxiliary_go123.go b/cloudbuild/apiv2/auxiliary_go123.go index e724af83294c..74e7d9d0fe1c 100755 --- a/cloudbuild/apiv2/auxiliary_go123.go +++ b/cloudbuild/apiv2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudbuild/apiv2/doc.go b/cloudbuild/apiv2/doc.go index 88f501e5eefc..c3224b703e4e 100755 --- a/cloudbuild/apiv2/doc.go +++ b/cloudbuild/apiv2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudbuild/apiv2/helpers.go b/cloudbuild/apiv2/helpers.go index f4827f6e7a18..dbac8241dd4f 100755 --- a/cloudbuild/apiv2/helpers.go +++ b/cloudbuild/apiv2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudbuild/apiv2/repository_manager_client.go b/cloudbuild/apiv2/repository_manager_client.go index 9df3443b6e31..751f31ec837e 100755 --- a/cloudbuild/apiv2/repository_manager_client.go +++ b/cloudbuild/apiv2/repository_manager_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudbuild/apiv2/repository_manager_client_example_go123_test.go b/cloudbuild/apiv2/repository_manager_client_example_go123_test.go index f88f74588aef..8633d85c6d20 100644 --- a/cloudbuild/apiv2/repository_manager_client_example_go123_test.go +++ b/cloudbuild/apiv2/repository_manager_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudbuild/apiv2/repository_manager_client_example_test.go b/cloudbuild/apiv2/repository_manager_client_example_test.go index 9349926a16be..00945525efa0 100644 --- a/cloudbuild/apiv2/repository_manager_client_example_test.go +++ b/cloudbuild/apiv2/repository_manager_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudcontrolspartner/apiv1/auxiliary.go b/cloudcontrolspartner/apiv1/auxiliary.go index 37c8b80aff3d..dd36c506b5f9 100755 --- a/cloudcontrolspartner/apiv1/auxiliary.go +++ b/cloudcontrolspartner/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudcontrolspartner/apiv1/auxiliary_go123.go b/cloudcontrolspartner/apiv1/auxiliary_go123.go index 9b558525c233..39b557494f09 100755 --- a/cloudcontrolspartner/apiv1/auxiliary_go123.go +++ b/cloudcontrolspartner/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudcontrolspartner/apiv1/cloud_controls_partner_core_client.go b/cloudcontrolspartner/apiv1/cloud_controls_partner_core_client.go index f22afba317c9..da8bd6cf100a 100755 --- a/cloudcontrolspartner/apiv1/cloud_controls_partner_core_client.go +++ b/cloudcontrolspartner/apiv1/cloud_controls_partner_core_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudcontrolspartner/apiv1/cloud_controls_partner_core_client_example_go123_test.go b/cloudcontrolspartner/apiv1/cloud_controls_partner_core_client_example_go123_test.go index 05a3b5bcf8be..6ce64d1f2e33 100644 --- a/cloudcontrolspartner/apiv1/cloud_controls_partner_core_client_example_go123_test.go +++ b/cloudcontrolspartner/apiv1/cloud_controls_partner_core_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudcontrolspartner/apiv1/cloud_controls_partner_core_client_example_test.go b/cloudcontrolspartner/apiv1/cloud_controls_partner_core_client_example_test.go index 261bbde672cb..5c34739bf7a1 100644 --- a/cloudcontrolspartner/apiv1/cloud_controls_partner_core_client_example_test.go +++ b/cloudcontrolspartner/apiv1/cloud_controls_partner_core_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudcontrolspartner/apiv1/cloud_controls_partner_monitoring_client.go b/cloudcontrolspartner/apiv1/cloud_controls_partner_monitoring_client.go index 3ce2a888378b..27f54186f376 100755 --- a/cloudcontrolspartner/apiv1/cloud_controls_partner_monitoring_client.go +++ b/cloudcontrolspartner/apiv1/cloud_controls_partner_monitoring_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudcontrolspartner/apiv1/cloud_controls_partner_monitoring_client_example_go123_test.go b/cloudcontrolspartner/apiv1/cloud_controls_partner_monitoring_client_example_go123_test.go index 0fcfb60efcf8..b7fbcc741325 100644 --- a/cloudcontrolspartner/apiv1/cloud_controls_partner_monitoring_client_example_go123_test.go +++ b/cloudcontrolspartner/apiv1/cloud_controls_partner_monitoring_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudcontrolspartner/apiv1/cloud_controls_partner_monitoring_client_example_test.go b/cloudcontrolspartner/apiv1/cloud_controls_partner_monitoring_client_example_test.go index 91f2b4836138..4dcbdd363e1f 100644 --- a/cloudcontrolspartner/apiv1/cloud_controls_partner_monitoring_client_example_test.go +++ b/cloudcontrolspartner/apiv1/cloud_controls_partner_monitoring_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudcontrolspartner/apiv1/doc.go b/cloudcontrolspartner/apiv1/doc.go index 4986d8b60454..9c7760800e6b 100755 --- a/cloudcontrolspartner/apiv1/doc.go +++ b/cloudcontrolspartner/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudcontrolspartner/apiv1/helpers.go b/cloudcontrolspartner/apiv1/helpers.go index cda7d2706895..7be68eca0324 100755 --- a/cloudcontrolspartner/apiv1/helpers.go +++ b/cloudcontrolspartner/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudcontrolspartner/apiv1beta/auxiliary.go b/cloudcontrolspartner/apiv1beta/auxiliary.go index 5af0c8a1a9f8..5877d3315192 100755 --- a/cloudcontrolspartner/apiv1beta/auxiliary.go +++ b/cloudcontrolspartner/apiv1beta/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudcontrolspartner/apiv1beta/auxiliary_go123.go b/cloudcontrolspartner/apiv1beta/auxiliary_go123.go index 1cb0096e4293..0bfc3fe327d0 100755 --- a/cloudcontrolspartner/apiv1beta/auxiliary_go123.go +++ b/cloudcontrolspartner/apiv1beta/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudcontrolspartner/apiv1beta/cloud_controls_partner_core_client.go b/cloudcontrolspartner/apiv1beta/cloud_controls_partner_core_client.go index 479169e752a4..259102c291bc 100755 --- a/cloudcontrolspartner/apiv1beta/cloud_controls_partner_core_client.go +++ b/cloudcontrolspartner/apiv1beta/cloud_controls_partner_core_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudcontrolspartner/apiv1beta/cloud_controls_partner_core_client_example_go123_test.go b/cloudcontrolspartner/apiv1beta/cloud_controls_partner_core_client_example_go123_test.go index 5ef5316837cb..a57484d58876 100644 --- a/cloudcontrolspartner/apiv1beta/cloud_controls_partner_core_client_example_go123_test.go +++ b/cloudcontrolspartner/apiv1beta/cloud_controls_partner_core_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudcontrolspartner/apiv1beta/cloud_controls_partner_core_client_example_test.go b/cloudcontrolspartner/apiv1beta/cloud_controls_partner_core_client_example_test.go index 2adce5e96347..ec957f4f1278 100644 --- a/cloudcontrolspartner/apiv1beta/cloud_controls_partner_core_client_example_test.go +++ b/cloudcontrolspartner/apiv1beta/cloud_controls_partner_core_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudcontrolspartner/apiv1beta/cloud_controls_partner_monitoring_client.go b/cloudcontrolspartner/apiv1beta/cloud_controls_partner_monitoring_client.go index 1bb705e7fb29..1c66302776e8 100755 --- a/cloudcontrolspartner/apiv1beta/cloud_controls_partner_monitoring_client.go +++ b/cloudcontrolspartner/apiv1beta/cloud_controls_partner_monitoring_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudcontrolspartner/apiv1beta/cloud_controls_partner_monitoring_client_example_go123_test.go b/cloudcontrolspartner/apiv1beta/cloud_controls_partner_monitoring_client_example_go123_test.go index c750e5d124c0..49acacd89414 100644 --- a/cloudcontrolspartner/apiv1beta/cloud_controls_partner_monitoring_client_example_go123_test.go +++ b/cloudcontrolspartner/apiv1beta/cloud_controls_partner_monitoring_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudcontrolspartner/apiv1beta/cloud_controls_partner_monitoring_client_example_test.go b/cloudcontrolspartner/apiv1beta/cloud_controls_partner_monitoring_client_example_test.go index e9fca2456c5c..5503b049631d 100644 --- a/cloudcontrolspartner/apiv1beta/cloud_controls_partner_monitoring_client_example_test.go +++ b/cloudcontrolspartner/apiv1beta/cloud_controls_partner_monitoring_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudcontrolspartner/apiv1beta/doc.go b/cloudcontrolspartner/apiv1beta/doc.go index 10a31c96ed02..b4b879f89a0d 100755 --- a/cloudcontrolspartner/apiv1beta/doc.go +++ b/cloudcontrolspartner/apiv1beta/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudcontrolspartner/apiv1beta/helpers.go b/cloudcontrolspartner/apiv1beta/helpers.go index cda7d2706895..7be68eca0324 100755 --- a/cloudcontrolspartner/apiv1beta/helpers.go +++ b/cloudcontrolspartner/apiv1beta/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/clouddms/apiv1/auxiliary.go b/clouddms/apiv1/auxiliary.go index 4490a2d6862e..ceb51d959f04 100755 --- a/clouddms/apiv1/auxiliary.go +++ b/clouddms/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/clouddms/apiv1/auxiliary_go123.go b/clouddms/apiv1/auxiliary_go123.go index c57e8c4da7d2..7ec5e2081d8f 100755 --- a/clouddms/apiv1/auxiliary_go123.go +++ b/clouddms/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/clouddms/apiv1/data_migration_client.go b/clouddms/apiv1/data_migration_client.go index 6813e35f3edb..3f5eae47d139 100755 --- a/clouddms/apiv1/data_migration_client.go +++ b/clouddms/apiv1/data_migration_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/clouddms/apiv1/data_migration_client_example_go123_test.go b/clouddms/apiv1/data_migration_client_example_go123_test.go index 6cda9fba3f26..bd6913a8388a 100644 --- a/clouddms/apiv1/data_migration_client_example_go123_test.go +++ b/clouddms/apiv1/data_migration_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/clouddms/apiv1/data_migration_client_example_test.go b/clouddms/apiv1/data_migration_client_example_test.go index 42bee9ecca44..9ce59513f531 100644 --- a/clouddms/apiv1/data_migration_client_example_test.go +++ b/clouddms/apiv1/data_migration_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/clouddms/apiv1/doc.go b/clouddms/apiv1/doc.go index 7aa64f2d6fdb..f1973a103393 100755 --- a/clouddms/apiv1/doc.go +++ b/clouddms/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/clouddms/apiv1/helpers.go b/clouddms/apiv1/helpers.go index effc06f46704..8e274bb228ea 100755 --- a/clouddms/apiv1/helpers.go +++ b/clouddms/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudprofiler/apiv2/auxiliary.go b/cloudprofiler/apiv2/auxiliary.go index a517a3dcdbfa..64f8904b9743 100755 --- a/cloudprofiler/apiv2/auxiliary.go +++ b/cloudprofiler/apiv2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudprofiler/apiv2/auxiliary_go123.go b/cloudprofiler/apiv2/auxiliary_go123.go index ecd92a99dc5b..dab0f574b1fd 100755 --- a/cloudprofiler/apiv2/auxiliary_go123.go +++ b/cloudprofiler/apiv2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudprofiler/apiv2/doc.go b/cloudprofiler/apiv2/doc.go index 1811659edd3f..e33cf5217f4f 100755 --- a/cloudprofiler/apiv2/doc.go +++ b/cloudprofiler/apiv2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudprofiler/apiv2/export_client.go b/cloudprofiler/apiv2/export_client.go index a8e82915533e..e152443ac499 100755 --- a/cloudprofiler/apiv2/export_client.go +++ b/cloudprofiler/apiv2/export_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudprofiler/apiv2/export_client_example_go123_test.go b/cloudprofiler/apiv2/export_client_example_go123_test.go index a01840b747d5..df4043a06450 100644 --- a/cloudprofiler/apiv2/export_client_example_go123_test.go +++ b/cloudprofiler/apiv2/export_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudprofiler/apiv2/export_client_example_test.go b/cloudprofiler/apiv2/export_client_example_test.go index 51a95624fafe..d96337078d9c 100644 --- a/cloudprofiler/apiv2/export_client_example_test.go +++ b/cloudprofiler/apiv2/export_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudprofiler/apiv2/helpers.go b/cloudprofiler/apiv2/helpers.go index e8cc62778c25..61b42faaecc1 100755 --- a/cloudprofiler/apiv2/helpers.go +++ b/cloudprofiler/apiv2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudprofiler/apiv2/profiler_client.go b/cloudprofiler/apiv2/profiler_client.go index c7d17be35ecb..8dbcd8088d69 100755 --- a/cloudprofiler/apiv2/profiler_client.go +++ b/cloudprofiler/apiv2/profiler_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudprofiler/apiv2/profiler_client_example_go123_test.go b/cloudprofiler/apiv2/profiler_client_example_go123_test.go index f68a30a893fd..06f87543a02a 100644 --- a/cloudprofiler/apiv2/profiler_client_example_go123_test.go +++ b/cloudprofiler/apiv2/profiler_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudprofiler/apiv2/profiler_client_example_test.go b/cloudprofiler/apiv2/profiler_client_example_test.go index b77dff4cc139..d6b25ed236a5 100644 --- a/cloudprofiler/apiv2/profiler_client_example_test.go +++ b/cloudprofiler/apiv2/profiler_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudquotas/apiv1/auxiliary.go b/cloudquotas/apiv1/auxiliary.go index b7f653dd25a2..7a037f2f99a3 100755 --- a/cloudquotas/apiv1/auxiliary.go +++ b/cloudquotas/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudquotas/apiv1/auxiliary_go123.go b/cloudquotas/apiv1/auxiliary_go123.go index 250b2aab89da..553b813c0f92 100755 --- a/cloudquotas/apiv1/auxiliary_go123.go +++ b/cloudquotas/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudquotas/apiv1/cloud_quotas_client.go b/cloudquotas/apiv1/cloud_quotas_client.go index 9dc4a6f82cde..7482222fa01f 100755 --- a/cloudquotas/apiv1/cloud_quotas_client.go +++ b/cloudquotas/apiv1/cloud_quotas_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudquotas/apiv1/cloud_quotas_client_example_go123_test.go b/cloudquotas/apiv1/cloud_quotas_client_example_go123_test.go index 0f6858544693..2c29aa6e496d 100644 --- a/cloudquotas/apiv1/cloud_quotas_client_example_go123_test.go +++ b/cloudquotas/apiv1/cloud_quotas_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudquotas/apiv1/cloud_quotas_client_example_test.go b/cloudquotas/apiv1/cloud_quotas_client_example_test.go index 49d76fb09bcf..01760ad871cf 100644 --- a/cloudquotas/apiv1/cloud_quotas_client_example_test.go +++ b/cloudquotas/apiv1/cloud_quotas_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudquotas/apiv1/doc.go b/cloudquotas/apiv1/doc.go index 479aaf6c152f..bdad97f7a190 100755 --- a/cloudquotas/apiv1/doc.go +++ b/cloudquotas/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudquotas/apiv1/helpers.go b/cloudquotas/apiv1/helpers.go index a0a313a58f0c..4a4e7b16ec15 100755 --- a/cloudquotas/apiv1/helpers.go +++ b/cloudquotas/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudtasks/apiv2/auxiliary.go b/cloudtasks/apiv2/auxiliary.go index 97c9f60303a0..307bbd4a3cf6 100755 --- a/cloudtasks/apiv2/auxiliary.go +++ b/cloudtasks/apiv2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudtasks/apiv2/auxiliary_go123.go b/cloudtasks/apiv2/auxiliary_go123.go index 83434faa9b0a..9d484e4c0aee 100755 --- a/cloudtasks/apiv2/auxiliary_go123.go +++ b/cloudtasks/apiv2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudtasks/apiv2/cloud_tasks_client.go b/cloudtasks/apiv2/cloud_tasks_client.go index 3bec7ffd3f5c..5ef94681c31f 100755 --- a/cloudtasks/apiv2/cloud_tasks_client.go +++ b/cloudtasks/apiv2/cloud_tasks_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudtasks/apiv2/cloud_tasks_client_example_go123_test.go b/cloudtasks/apiv2/cloud_tasks_client_example_go123_test.go index 330a6ddc15b3..91cbdad3f031 100644 --- a/cloudtasks/apiv2/cloud_tasks_client_example_go123_test.go +++ b/cloudtasks/apiv2/cloud_tasks_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudtasks/apiv2/cloud_tasks_client_example_test.go b/cloudtasks/apiv2/cloud_tasks_client_example_test.go index 2255536710d0..8bdf213a7336 100644 --- a/cloudtasks/apiv2/cloud_tasks_client_example_test.go +++ b/cloudtasks/apiv2/cloud_tasks_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudtasks/apiv2/doc.go b/cloudtasks/apiv2/doc.go index 4125db919618..931e89f12178 100755 --- a/cloudtasks/apiv2/doc.go +++ b/cloudtasks/apiv2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudtasks/apiv2/helpers.go b/cloudtasks/apiv2/helpers.go index f51bb20d6fd1..9a0ddc9e2f46 100755 --- a/cloudtasks/apiv2/helpers.go +++ b/cloudtasks/apiv2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudtasks/apiv2beta2/auxiliary.go b/cloudtasks/apiv2beta2/auxiliary.go index 686002a51c62..9883c7aabcfe 100755 --- a/cloudtasks/apiv2beta2/auxiliary.go +++ b/cloudtasks/apiv2beta2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudtasks/apiv2beta2/auxiliary_go123.go b/cloudtasks/apiv2beta2/auxiliary_go123.go index 0705fb5361d9..65c7752b36d2 100755 --- a/cloudtasks/apiv2beta2/auxiliary_go123.go +++ b/cloudtasks/apiv2beta2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudtasks/apiv2beta2/cloud_tasks_client.go b/cloudtasks/apiv2beta2/cloud_tasks_client.go index 9c330c107614..e6c3526200d5 100755 --- a/cloudtasks/apiv2beta2/cloud_tasks_client.go +++ b/cloudtasks/apiv2beta2/cloud_tasks_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudtasks/apiv2beta2/cloud_tasks_client_example_go123_test.go b/cloudtasks/apiv2beta2/cloud_tasks_client_example_go123_test.go index 9deaffe41400..47375473b046 100644 --- a/cloudtasks/apiv2beta2/cloud_tasks_client_example_go123_test.go +++ b/cloudtasks/apiv2beta2/cloud_tasks_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudtasks/apiv2beta2/cloud_tasks_client_example_test.go b/cloudtasks/apiv2beta2/cloud_tasks_client_example_test.go index 5e660258de86..68f62c95fab2 100644 --- a/cloudtasks/apiv2beta2/cloud_tasks_client_example_test.go +++ b/cloudtasks/apiv2beta2/cloud_tasks_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudtasks/apiv2beta2/doc.go b/cloudtasks/apiv2beta2/doc.go index 57c8eee53eba..37f3a1ac40c2 100755 --- a/cloudtasks/apiv2beta2/doc.go +++ b/cloudtasks/apiv2beta2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudtasks/apiv2beta2/helpers.go b/cloudtasks/apiv2beta2/helpers.go index f51bb20d6fd1..9a0ddc9e2f46 100755 --- a/cloudtasks/apiv2beta2/helpers.go +++ b/cloudtasks/apiv2beta2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudtasks/apiv2beta3/auxiliary.go b/cloudtasks/apiv2beta3/auxiliary.go index 5e867cebd720..2a2d5f0829e6 100755 --- a/cloudtasks/apiv2beta3/auxiliary.go +++ b/cloudtasks/apiv2beta3/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudtasks/apiv2beta3/auxiliary_go123.go b/cloudtasks/apiv2beta3/auxiliary_go123.go index 565b52afa041..a0e7d8e1f7b4 100755 --- a/cloudtasks/apiv2beta3/auxiliary_go123.go +++ b/cloudtasks/apiv2beta3/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudtasks/apiv2beta3/cloud_tasks_client.go b/cloudtasks/apiv2beta3/cloud_tasks_client.go index a68d5ccd95ea..6fbce8337e75 100755 --- a/cloudtasks/apiv2beta3/cloud_tasks_client.go +++ b/cloudtasks/apiv2beta3/cloud_tasks_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudtasks/apiv2beta3/cloud_tasks_client_example_go123_test.go b/cloudtasks/apiv2beta3/cloud_tasks_client_example_go123_test.go index 8f1c967cd2b7..1a9b4da6c5fc 100644 --- a/cloudtasks/apiv2beta3/cloud_tasks_client_example_go123_test.go +++ b/cloudtasks/apiv2beta3/cloud_tasks_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudtasks/apiv2beta3/cloud_tasks_client_example_test.go b/cloudtasks/apiv2beta3/cloud_tasks_client_example_test.go index 77f5fde204af..66a760b7cd5f 100644 --- a/cloudtasks/apiv2beta3/cloud_tasks_client_example_test.go +++ b/cloudtasks/apiv2beta3/cloud_tasks_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudtasks/apiv2beta3/doc.go b/cloudtasks/apiv2beta3/doc.go index 57449b5cbbc1..59670cfc202d 100755 --- a/cloudtasks/apiv2beta3/doc.go +++ b/cloudtasks/apiv2beta3/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/cloudtasks/apiv2beta3/helpers.go b/cloudtasks/apiv2beta3/helpers.go index f51bb20d6fd1..9a0ddc9e2f46 100755 --- a/cloudtasks/apiv2beta3/helpers.go +++ b/cloudtasks/apiv2beta3/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/commerce/consumer/procurement/apiv1/auxiliary.go b/commerce/consumer/procurement/apiv1/auxiliary.go index d924c70bedc3..91a9c95ae14c 100755 --- a/commerce/consumer/procurement/apiv1/auxiliary.go +++ b/commerce/consumer/procurement/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/commerce/consumer/procurement/apiv1/auxiliary_go123.go b/commerce/consumer/procurement/apiv1/auxiliary_go123.go index 355b09781bf0..63acd0cb823c 100755 --- a/commerce/consumer/procurement/apiv1/auxiliary_go123.go +++ b/commerce/consumer/procurement/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/commerce/consumer/procurement/apiv1/consumer_procurement_client.go b/commerce/consumer/procurement/apiv1/consumer_procurement_client.go index 5c08edd4969a..78d1e2a942c5 100755 --- a/commerce/consumer/procurement/apiv1/consumer_procurement_client.go +++ b/commerce/consumer/procurement/apiv1/consumer_procurement_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/commerce/consumer/procurement/apiv1/consumer_procurement_client_example_go123_test.go b/commerce/consumer/procurement/apiv1/consumer_procurement_client_example_go123_test.go index e3c50715319f..f5050e6674fc 100644 --- a/commerce/consumer/procurement/apiv1/consumer_procurement_client_example_go123_test.go +++ b/commerce/consumer/procurement/apiv1/consumer_procurement_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/commerce/consumer/procurement/apiv1/consumer_procurement_client_example_test.go b/commerce/consumer/procurement/apiv1/consumer_procurement_client_example_test.go index eea73919cb81..84081f2277c4 100644 --- a/commerce/consumer/procurement/apiv1/consumer_procurement_client_example_test.go +++ b/commerce/consumer/procurement/apiv1/consumer_procurement_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/commerce/consumer/procurement/apiv1/doc.go b/commerce/consumer/procurement/apiv1/doc.go index fc0bbc27e081..3c4439692c46 100755 --- a/commerce/consumer/procurement/apiv1/doc.go +++ b/commerce/consumer/procurement/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/commerce/consumer/procurement/apiv1/helpers.go b/commerce/consumer/procurement/apiv1/helpers.go index 8c0923abc23c..535b9f7840fb 100755 --- a/commerce/consumer/procurement/apiv1/helpers.go +++ b/commerce/consumer/procurement/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/commerce/consumer/procurement/apiv1/license_management_client.go b/commerce/consumer/procurement/apiv1/license_management_client.go index 16bee239e59e..ff19b1f353dd 100755 --- a/commerce/consumer/procurement/apiv1/license_management_client.go +++ b/commerce/consumer/procurement/apiv1/license_management_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/commerce/consumer/procurement/apiv1/license_management_client_example_go123_test.go b/commerce/consumer/procurement/apiv1/license_management_client_example_go123_test.go index 017b283ebae3..73bdb21f701f 100644 --- a/commerce/consumer/procurement/apiv1/license_management_client_example_go123_test.go +++ b/commerce/consumer/procurement/apiv1/license_management_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/commerce/consumer/procurement/apiv1/license_management_client_example_test.go b/commerce/consumer/procurement/apiv1/license_management_client_example_test.go index 7867fc2de9e3..4691b41d7366 100644 --- a/commerce/consumer/procurement/apiv1/license_management_client_example_test.go +++ b/commerce/consumer/procurement/apiv1/license_management_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/accelerator_types_client.go b/compute/apiv1/accelerator_types_client.go index 8c525cadad3b..540a641cc724 100755 --- a/compute/apiv1/accelerator_types_client.go +++ b/compute/apiv1/accelerator_types_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/accelerator_types_client_example_go123_test.go b/compute/apiv1/accelerator_types_client_example_go123_test.go index 29e2de9bb1fc..287144707e9d 100644 --- a/compute/apiv1/accelerator_types_client_example_go123_test.go +++ b/compute/apiv1/accelerator_types_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/accelerator_types_client_example_test.go b/compute/apiv1/accelerator_types_client_example_test.go index 009849179429..98a0dae74a0f 100644 --- a/compute/apiv1/accelerator_types_client_example_test.go +++ b/compute/apiv1/accelerator_types_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/addresses_client.go b/compute/apiv1/addresses_client.go index eb27efc79d7b..57e1d52f104c 100755 --- a/compute/apiv1/addresses_client.go +++ b/compute/apiv1/addresses_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/addresses_client_example_go123_test.go b/compute/apiv1/addresses_client_example_go123_test.go index e085b26258d3..728202a17980 100644 --- a/compute/apiv1/addresses_client_example_go123_test.go +++ b/compute/apiv1/addresses_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/addresses_client_example_test.go b/compute/apiv1/addresses_client_example_test.go index 98ed914fc24a..51ca1d8b4a9e 100644 --- a/compute/apiv1/addresses_client_example_test.go +++ b/compute/apiv1/addresses_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/autoscalers_client.go b/compute/apiv1/autoscalers_client.go index d1fdb4130823..b935b383c0e1 100755 --- a/compute/apiv1/autoscalers_client.go +++ b/compute/apiv1/autoscalers_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/autoscalers_client_example_go123_test.go b/compute/apiv1/autoscalers_client_example_go123_test.go index 320b910a37c4..8a499c52b600 100644 --- a/compute/apiv1/autoscalers_client_example_go123_test.go +++ b/compute/apiv1/autoscalers_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/autoscalers_client_example_test.go b/compute/apiv1/autoscalers_client_example_test.go index b0a94ed63502..06d868a2f7c5 100644 --- a/compute/apiv1/autoscalers_client_example_test.go +++ b/compute/apiv1/autoscalers_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/auxiliary.go b/compute/apiv1/auxiliary.go index 2fe4808243dc..2d2785b94557 100755 --- a/compute/apiv1/auxiliary.go +++ b/compute/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/auxiliary_go123.go b/compute/apiv1/auxiliary_go123.go index ca087f18ab62..42d813613497 100755 --- a/compute/apiv1/auxiliary_go123.go +++ b/compute/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/backend_buckets_client.go b/compute/apiv1/backend_buckets_client.go index 708cd74a6fdf..2b930b048816 100755 --- a/compute/apiv1/backend_buckets_client.go +++ b/compute/apiv1/backend_buckets_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/backend_buckets_client_example_go123_test.go b/compute/apiv1/backend_buckets_client_example_go123_test.go index de467c9383f1..ffd8899b669a 100644 --- a/compute/apiv1/backend_buckets_client_example_go123_test.go +++ b/compute/apiv1/backend_buckets_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/backend_buckets_client_example_test.go b/compute/apiv1/backend_buckets_client_example_test.go index 5c951ae1f64d..f599d93b1c30 100644 --- a/compute/apiv1/backend_buckets_client_example_test.go +++ b/compute/apiv1/backend_buckets_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/backend_services_client.go b/compute/apiv1/backend_services_client.go index b23db8892153..edd24952496d 100755 --- a/compute/apiv1/backend_services_client.go +++ b/compute/apiv1/backend_services_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/backend_services_client_example_go123_test.go b/compute/apiv1/backend_services_client_example_go123_test.go index 08ac7d008fc4..7e2444e44bcf 100644 --- a/compute/apiv1/backend_services_client_example_go123_test.go +++ b/compute/apiv1/backend_services_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/backend_services_client_example_test.go b/compute/apiv1/backend_services_client_example_test.go index 9647c51baaf5..5e09be0c730d 100644 --- a/compute/apiv1/backend_services_client_example_test.go +++ b/compute/apiv1/backend_services_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/disk_types_client.go b/compute/apiv1/disk_types_client.go index 687c7293ae3a..bcfcf808eb59 100755 --- a/compute/apiv1/disk_types_client.go +++ b/compute/apiv1/disk_types_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/disk_types_client_example_go123_test.go b/compute/apiv1/disk_types_client_example_go123_test.go index 2bdc096889f4..79cc36b0c908 100644 --- a/compute/apiv1/disk_types_client_example_go123_test.go +++ b/compute/apiv1/disk_types_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/disk_types_client_example_test.go b/compute/apiv1/disk_types_client_example_test.go index c7bb307f197a..c1ee9322173d 100644 --- a/compute/apiv1/disk_types_client_example_test.go +++ b/compute/apiv1/disk_types_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/disks_client.go b/compute/apiv1/disks_client.go index 8d5fd735de54..32ad63743f32 100755 --- a/compute/apiv1/disks_client.go +++ b/compute/apiv1/disks_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/disks_client_example_go123_test.go b/compute/apiv1/disks_client_example_go123_test.go index d0dfcc54cfa1..b598a7c7e86c 100644 --- a/compute/apiv1/disks_client_example_go123_test.go +++ b/compute/apiv1/disks_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/disks_client_example_test.go b/compute/apiv1/disks_client_example_test.go index 281841fe37d1..19ccab67bc7c 100644 --- a/compute/apiv1/disks_client_example_test.go +++ b/compute/apiv1/disks_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/doc.go b/compute/apiv1/doc.go index ded74419cec2..85241a1b320c 100755 --- a/compute/apiv1/doc.go +++ b/compute/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/external_vpn_gateways_client.go b/compute/apiv1/external_vpn_gateways_client.go index f0a0ac320912..8072b4405625 100755 --- a/compute/apiv1/external_vpn_gateways_client.go +++ b/compute/apiv1/external_vpn_gateways_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/external_vpn_gateways_client_example_go123_test.go b/compute/apiv1/external_vpn_gateways_client_example_go123_test.go index 4616c955c31d..9d846d05a3bc 100644 --- a/compute/apiv1/external_vpn_gateways_client_example_go123_test.go +++ b/compute/apiv1/external_vpn_gateways_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/external_vpn_gateways_client_example_test.go b/compute/apiv1/external_vpn_gateways_client_example_test.go index 38317e0e36a2..8ef74f529504 100644 --- a/compute/apiv1/external_vpn_gateways_client_example_test.go +++ b/compute/apiv1/external_vpn_gateways_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/firewall_policies_client.go b/compute/apiv1/firewall_policies_client.go index bcaa974d8a24..51b8c59863d9 100755 --- a/compute/apiv1/firewall_policies_client.go +++ b/compute/apiv1/firewall_policies_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/firewall_policies_client_example_go123_test.go b/compute/apiv1/firewall_policies_client_example_go123_test.go index 9f5a80cba655..5ec87cc4205c 100644 --- a/compute/apiv1/firewall_policies_client_example_go123_test.go +++ b/compute/apiv1/firewall_policies_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/firewall_policies_client_example_test.go b/compute/apiv1/firewall_policies_client_example_test.go index ab8f9e198f97..1b17d0fc5095 100644 --- a/compute/apiv1/firewall_policies_client_example_test.go +++ b/compute/apiv1/firewall_policies_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/firewalls_client.go b/compute/apiv1/firewalls_client.go index 21f960c9aeb6..cae02135f3e8 100755 --- a/compute/apiv1/firewalls_client.go +++ b/compute/apiv1/firewalls_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/firewalls_client_example_go123_test.go b/compute/apiv1/firewalls_client_example_go123_test.go index 21a34dca87a7..3d131e5571c9 100644 --- a/compute/apiv1/firewalls_client_example_go123_test.go +++ b/compute/apiv1/firewalls_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/firewalls_client_example_test.go b/compute/apiv1/firewalls_client_example_test.go index 967a4ea5d3d4..f2dd7e6115cc 100644 --- a/compute/apiv1/firewalls_client_example_test.go +++ b/compute/apiv1/firewalls_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/forwarding_rules_client.go b/compute/apiv1/forwarding_rules_client.go index 99dd8a52b450..7068d5e17ff9 100755 --- a/compute/apiv1/forwarding_rules_client.go +++ b/compute/apiv1/forwarding_rules_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/forwarding_rules_client_example_go123_test.go b/compute/apiv1/forwarding_rules_client_example_go123_test.go index b0297010b657..e344afa8d760 100644 --- a/compute/apiv1/forwarding_rules_client_example_go123_test.go +++ b/compute/apiv1/forwarding_rules_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/forwarding_rules_client_example_test.go b/compute/apiv1/forwarding_rules_client_example_test.go index 1a328e18b4c2..35645539ae29 100644 --- a/compute/apiv1/forwarding_rules_client_example_test.go +++ b/compute/apiv1/forwarding_rules_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/global_addresses_client.go b/compute/apiv1/global_addresses_client.go index 4ed233cde6c2..b43c39060cfc 100755 --- a/compute/apiv1/global_addresses_client.go +++ b/compute/apiv1/global_addresses_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/global_addresses_client_example_go123_test.go b/compute/apiv1/global_addresses_client_example_go123_test.go index b98f85a0f44c..805bf121bf06 100644 --- a/compute/apiv1/global_addresses_client_example_go123_test.go +++ b/compute/apiv1/global_addresses_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/global_addresses_client_example_test.go b/compute/apiv1/global_addresses_client_example_test.go index 95e6449dca41..8d7d68d7de43 100644 --- a/compute/apiv1/global_addresses_client_example_test.go +++ b/compute/apiv1/global_addresses_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/global_forwarding_rules_client.go b/compute/apiv1/global_forwarding_rules_client.go index 8d042e91a1fa..3738d3653ce0 100755 --- a/compute/apiv1/global_forwarding_rules_client.go +++ b/compute/apiv1/global_forwarding_rules_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/global_forwarding_rules_client_example_go123_test.go b/compute/apiv1/global_forwarding_rules_client_example_go123_test.go index b3613c252c44..0f3f75aab8eb 100644 --- a/compute/apiv1/global_forwarding_rules_client_example_go123_test.go +++ b/compute/apiv1/global_forwarding_rules_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/global_forwarding_rules_client_example_test.go b/compute/apiv1/global_forwarding_rules_client_example_test.go index 086bda728999..f542190c6146 100644 --- a/compute/apiv1/global_forwarding_rules_client_example_test.go +++ b/compute/apiv1/global_forwarding_rules_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/global_network_endpoint_groups_client.go b/compute/apiv1/global_network_endpoint_groups_client.go index f827e0b1d978..9b8a94eed46c 100755 --- a/compute/apiv1/global_network_endpoint_groups_client.go +++ b/compute/apiv1/global_network_endpoint_groups_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/global_network_endpoint_groups_client_example_go123_test.go b/compute/apiv1/global_network_endpoint_groups_client_example_go123_test.go index 9c1408d8c7ba..b8e46f42baee 100644 --- a/compute/apiv1/global_network_endpoint_groups_client_example_go123_test.go +++ b/compute/apiv1/global_network_endpoint_groups_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/global_network_endpoint_groups_client_example_test.go b/compute/apiv1/global_network_endpoint_groups_client_example_test.go index be0e9d7b282a..4bb16b3329c4 100644 --- a/compute/apiv1/global_network_endpoint_groups_client_example_test.go +++ b/compute/apiv1/global_network_endpoint_groups_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/global_operations_client.go b/compute/apiv1/global_operations_client.go index 983b6df78654..eba360d0912e 100755 --- a/compute/apiv1/global_operations_client.go +++ b/compute/apiv1/global_operations_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/global_operations_client_example_go123_test.go b/compute/apiv1/global_operations_client_example_go123_test.go index d32ca01360cb..702da9ad30db 100644 --- a/compute/apiv1/global_operations_client_example_go123_test.go +++ b/compute/apiv1/global_operations_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/global_operations_client_example_test.go b/compute/apiv1/global_operations_client_example_test.go index 7ccbb3762ba5..06ac6a002087 100644 --- a/compute/apiv1/global_operations_client_example_test.go +++ b/compute/apiv1/global_operations_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/global_organization_operations_client.go b/compute/apiv1/global_organization_operations_client.go index aa66de24a116..b40856bf1950 100755 --- a/compute/apiv1/global_organization_operations_client.go +++ b/compute/apiv1/global_organization_operations_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/global_organization_operations_client_example_go123_test.go b/compute/apiv1/global_organization_operations_client_example_go123_test.go index ed2591e53aa9..a05e90282dee 100644 --- a/compute/apiv1/global_organization_operations_client_example_go123_test.go +++ b/compute/apiv1/global_organization_operations_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/global_organization_operations_client_example_test.go b/compute/apiv1/global_organization_operations_client_example_test.go index 4067ce7e2b38..1114044d3ae6 100644 --- a/compute/apiv1/global_organization_operations_client_example_test.go +++ b/compute/apiv1/global_organization_operations_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/global_public_delegated_prefixes_client.go b/compute/apiv1/global_public_delegated_prefixes_client.go index 72e3f4758cdb..fc737222626e 100755 --- a/compute/apiv1/global_public_delegated_prefixes_client.go +++ b/compute/apiv1/global_public_delegated_prefixes_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/global_public_delegated_prefixes_client_example_go123_test.go b/compute/apiv1/global_public_delegated_prefixes_client_example_go123_test.go index 57ffa5e23f28..0f9eec2e85e0 100644 --- a/compute/apiv1/global_public_delegated_prefixes_client_example_go123_test.go +++ b/compute/apiv1/global_public_delegated_prefixes_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/global_public_delegated_prefixes_client_example_test.go b/compute/apiv1/global_public_delegated_prefixes_client_example_test.go index 1f7fe609ad23..0e38ed790e86 100644 --- a/compute/apiv1/global_public_delegated_prefixes_client_example_test.go +++ b/compute/apiv1/global_public_delegated_prefixes_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/health_checks_client.go b/compute/apiv1/health_checks_client.go index 973f577ab50f..a45518745c0b 100755 --- a/compute/apiv1/health_checks_client.go +++ b/compute/apiv1/health_checks_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/health_checks_client_example_go123_test.go b/compute/apiv1/health_checks_client_example_go123_test.go index c3aff2da4b60..ef795f5f46ec 100644 --- a/compute/apiv1/health_checks_client_example_go123_test.go +++ b/compute/apiv1/health_checks_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/health_checks_client_example_test.go b/compute/apiv1/health_checks_client_example_test.go index 8856cb5e4bfb..53c3e2571c63 100644 --- a/compute/apiv1/health_checks_client_example_test.go +++ b/compute/apiv1/health_checks_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/helpers.go b/compute/apiv1/helpers.go index a40fbd73831e..c76090cfce42 100755 --- a/compute/apiv1/helpers.go +++ b/compute/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/image_family_views_client.go b/compute/apiv1/image_family_views_client.go index 519f858225e8..d17dc527a48e 100755 --- a/compute/apiv1/image_family_views_client.go +++ b/compute/apiv1/image_family_views_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/image_family_views_client_example_go123_test.go b/compute/apiv1/image_family_views_client_example_go123_test.go index 6f8858b6c7a7..e75790f7ff6c 100644 --- a/compute/apiv1/image_family_views_client_example_go123_test.go +++ b/compute/apiv1/image_family_views_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/image_family_views_client_example_test.go b/compute/apiv1/image_family_views_client_example_test.go index 60d431607034..16c4f184d713 100644 --- a/compute/apiv1/image_family_views_client_example_test.go +++ b/compute/apiv1/image_family_views_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/images_client.go b/compute/apiv1/images_client.go index 8ca4b27ab150..cb4e73edec8c 100755 --- a/compute/apiv1/images_client.go +++ b/compute/apiv1/images_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/images_client_example_go123_test.go b/compute/apiv1/images_client_example_go123_test.go index 5aea0b0bec1c..1cd17076f51e 100644 --- a/compute/apiv1/images_client_example_go123_test.go +++ b/compute/apiv1/images_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/images_client_example_test.go b/compute/apiv1/images_client_example_test.go index 32f02c54d42e..d82c08d101b3 100644 --- a/compute/apiv1/images_client_example_test.go +++ b/compute/apiv1/images_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/instance_group_manager_resize_requests_client.go b/compute/apiv1/instance_group_manager_resize_requests_client.go index 56b157776e3a..e23c0807b0a2 100755 --- a/compute/apiv1/instance_group_manager_resize_requests_client.go +++ b/compute/apiv1/instance_group_manager_resize_requests_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/instance_group_manager_resize_requests_client_example_go123_test.go b/compute/apiv1/instance_group_manager_resize_requests_client_example_go123_test.go index 94291cdb7813..9004e8fa1f8f 100644 --- a/compute/apiv1/instance_group_manager_resize_requests_client_example_go123_test.go +++ b/compute/apiv1/instance_group_manager_resize_requests_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/instance_group_manager_resize_requests_client_example_test.go b/compute/apiv1/instance_group_manager_resize_requests_client_example_test.go index fcba8032e52c..ea52a7c5268d 100644 --- a/compute/apiv1/instance_group_manager_resize_requests_client_example_test.go +++ b/compute/apiv1/instance_group_manager_resize_requests_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/instance_group_managers_client.go b/compute/apiv1/instance_group_managers_client.go index 815bdd7ffb78..71dee31205a1 100755 --- a/compute/apiv1/instance_group_managers_client.go +++ b/compute/apiv1/instance_group_managers_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/instance_group_managers_client_example_go123_test.go b/compute/apiv1/instance_group_managers_client_example_go123_test.go index c14da9746839..34db28bdcef2 100644 --- a/compute/apiv1/instance_group_managers_client_example_go123_test.go +++ b/compute/apiv1/instance_group_managers_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/instance_group_managers_client_example_test.go b/compute/apiv1/instance_group_managers_client_example_test.go index b95b0d2d54f1..743f7361ab50 100644 --- a/compute/apiv1/instance_group_managers_client_example_test.go +++ b/compute/apiv1/instance_group_managers_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/instance_groups_client.go b/compute/apiv1/instance_groups_client.go index 2df0f523bc0f..813c016feedb 100755 --- a/compute/apiv1/instance_groups_client.go +++ b/compute/apiv1/instance_groups_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/instance_groups_client_example_go123_test.go b/compute/apiv1/instance_groups_client_example_go123_test.go index 1404b69c8bb7..97ec741ae89b 100644 --- a/compute/apiv1/instance_groups_client_example_go123_test.go +++ b/compute/apiv1/instance_groups_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/instance_groups_client_example_test.go b/compute/apiv1/instance_groups_client_example_test.go index 9716ff960bef..7af4c8f94612 100644 --- a/compute/apiv1/instance_groups_client_example_test.go +++ b/compute/apiv1/instance_groups_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/instance_settings_client.go b/compute/apiv1/instance_settings_client.go index 24082080abf0..d3c326090dfb 100755 --- a/compute/apiv1/instance_settings_client.go +++ b/compute/apiv1/instance_settings_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/instance_settings_client_example_go123_test.go b/compute/apiv1/instance_settings_client_example_go123_test.go index 6f8858b6c7a7..e75790f7ff6c 100644 --- a/compute/apiv1/instance_settings_client_example_go123_test.go +++ b/compute/apiv1/instance_settings_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/instance_settings_client_example_test.go b/compute/apiv1/instance_settings_client_example_test.go index 41f690855131..c39f00e3f93d 100644 --- a/compute/apiv1/instance_settings_client_example_test.go +++ b/compute/apiv1/instance_settings_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/instance_templates_client.go b/compute/apiv1/instance_templates_client.go index bc867448c4dc..0f8cd0718d1e 100755 --- a/compute/apiv1/instance_templates_client.go +++ b/compute/apiv1/instance_templates_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/instance_templates_client_example_go123_test.go b/compute/apiv1/instance_templates_client_example_go123_test.go index 52af4ff150e7..700fec1f1e94 100644 --- a/compute/apiv1/instance_templates_client_example_go123_test.go +++ b/compute/apiv1/instance_templates_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/instance_templates_client_example_test.go b/compute/apiv1/instance_templates_client_example_test.go index b422c7eca15d..ed9d86b37eca 100644 --- a/compute/apiv1/instance_templates_client_example_test.go +++ b/compute/apiv1/instance_templates_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/instances_client.go b/compute/apiv1/instances_client.go index 39571fa17fb8..87ff1c680de6 100755 --- a/compute/apiv1/instances_client.go +++ b/compute/apiv1/instances_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/instances_client_example_go123_test.go b/compute/apiv1/instances_client_example_go123_test.go index f587cf2435f7..82b43b2326ab 100644 --- a/compute/apiv1/instances_client_example_go123_test.go +++ b/compute/apiv1/instances_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/instances_client_example_test.go b/compute/apiv1/instances_client_example_test.go index 23cfd79051a6..1dbd8fd1b684 100644 --- a/compute/apiv1/instances_client_example_test.go +++ b/compute/apiv1/instances_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/instant_snapshots_client.go b/compute/apiv1/instant_snapshots_client.go index 97d683755abd..e04454567cc9 100755 --- a/compute/apiv1/instant_snapshots_client.go +++ b/compute/apiv1/instant_snapshots_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/instant_snapshots_client_example_go123_test.go b/compute/apiv1/instant_snapshots_client_example_go123_test.go index 8cbe33780a88..ed42ae8be690 100644 --- a/compute/apiv1/instant_snapshots_client_example_go123_test.go +++ b/compute/apiv1/instant_snapshots_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/instant_snapshots_client_example_test.go b/compute/apiv1/instant_snapshots_client_example_test.go index 9378d89e0d43..57edd1bb92b5 100644 --- a/compute/apiv1/instant_snapshots_client_example_test.go +++ b/compute/apiv1/instant_snapshots_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/interconnect_attachments_client.go b/compute/apiv1/interconnect_attachments_client.go index 4e93cc7c2494..402456685088 100755 --- a/compute/apiv1/interconnect_attachments_client.go +++ b/compute/apiv1/interconnect_attachments_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/interconnect_attachments_client_example_go123_test.go b/compute/apiv1/interconnect_attachments_client_example_go123_test.go index 9edb5c536a55..938f9bff21f5 100644 --- a/compute/apiv1/interconnect_attachments_client_example_go123_test.go +++ b/compute/apiv1/interconnect_attachments_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/interconnect_attachments_client_example_test.go b/compute/apiv1/interconnect_attachments_client_example_test.go index 2a22c66efbab..9da9e49cd741 100644 --- a/compute/apiv1/interconnect_attachments_client_example_test.go +++ b/compute/apiv1/interconnect_attachments_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/interconnect_locations_client.go b/compute/apiv1/interconnect_locations_client.go index 729bec46fae7..69a4ec625f61 100755 --- a/compute/apiv1/interconnect_locations_client.go +++ b/compute/apiv1/interconnect_locations_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/interconnect_locations_client_example_go123_test.go b/compute/apiv1/interconnect_locations_client_example_go123_test.go index d2d1900ba006..f7dc05e2c5b6 100644 --- a/compute/apiv1/interconnect_locations_client_example_go123_test.go +++ b/compute/apiv1/interconnect_locations_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/interconnect_locations_client_example_test.go b/compute/apiv1/interconnect_locations_client_example_test.go index 21670a12272b..c1aaab7dba24 100644 --- a/compute/apiv1/interconnect_locations_client_example_test.go +++ b/compute/apiv1/interconnect_locations_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/interconnect_remote_locations_client.go b/compute/apiv1/interconnect_remote_locations_client.go index 3b1feb485533..3645bc445887 100755 --- a/compute/apiv1/interconnect_remote_locations_client.go +++ b/compute/apiv1/interconnect_remote_locations_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/interconnect_remote_locations_client_example_go123_test.go b/compute/apiv1/interconnect_remote_locations_client_example_go123_test.go index 44591370233b..05e9ce5cea94 100644 --- a/compute/apiv1/interconnect_remote_locations_client_example_go123_test.go +++ b/compute/apiv1/interconnect_remote_locations_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/interconnect_remote_locations_client_example_test.go b/compute/apiv1/interconnect_remote_locations_client_example_test.go index ca516dc65971..8edb0ceb753b 100644 --- a/compute/apiv1/interconnect_remote_locations_client_example_test.go +++ b/compute/apiv1/interconnect_remote_locations_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/interconnects_client.go b/compute/apiv1/interconnects_client.go index 0789efc9a266..02ee59336894 100755 --- a/compute/apiv1/interconnects_client.go +++ b/compute/apiv1/interconnects_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/interconnects_client_example_go123_test.go b/compute/apiv1/interconnects_client_example_go123_test.go index dfdbb7e800f5..d698d3fc6064 100644 --- a/compute/apiv1/interconnects_client_example_go123_test.go +++ b/compute/apiv1/interconnects_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/interconnects_client_example_test.go b/compute/apiv1/interconnects_client_example_test.go index da61d8a4829f..d04d2f6a1b46 100644 --- a/compute/apiv1/interconnects_client_example_test.go +++ b/compute/apiv1/interconnects_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/license_codes_client.go b/compute/apiv1/license_codes_client.go index c686e470005c..6dd3d828d38b 100755 --- a/compute/apiv1/license_codes_client.go +++ b/compute/apiv1/license_codes_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/license_codes_client_example_go123_test.go b/compute/apiv1/license_codes_client_example_go123_test.go index 6f8858b6c7a7..e75790f7ff6c 100644 --- a/compute/apiv1/license_codes_client_example_go123_test.go +++ b/compute/apiv1/license_codes_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/license_codes_client_example_test.go b/compute/apiv1/license_codes_client_example_test.go index 48b003c59543..42a0b6ed1b95 100644 --- a/compute/apiv1/license_codes_client_example_test.go +++ b/compute/apiv1/license_codes_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/licenses_client.go b/compute/apiv1/licenses_client.go index c5a41b21c7b1..ce5e93858b08 100755 --- a/compute/apiv1/licenses_client.go +++ b/compute/apiv1/licenses_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/licenses_client_example_go123_test.go b/compute/apiv1/licenses_client_example_go123_test.go index 80429f517f25..95ff531830c9 100644 --- a/compute/apiv1/licenses_client_example_go123_test.go +++ b/compute/apiv1/licenses_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/licenses_client_example_test.go b/compute/apiv1/licenses_client_example_test.go index 5b50e10b243f..da047b67b69b 100644 --- a/compute/apiv1/licenses_client_example_test.go +++ b/compute/apiv1/licenses_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/machine_images_client.go b/compute/apiv1/machine_images_client.go index efcfb18ea57f..8494080bb88a 100755 --- a/compute/apiv1/machine_images_client.go +++ b/compute/apiv1/machine_images_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/machine_images_client_example_go123_test.go b/compute/apiv1/machine_images_client_example_go123_test.go index 0bcc09d09edd..3f7c5dd69d7d 100644 --- a/compute/apiv1/machine_images_client_example_go123_test.go +++ b/compute/apiv1/machine_images_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/machine_images_client_example_test.go b/compute/apiv1/machine_images_client_example_test.go index c87a0934a0bc..bc2113aae112 100644 --- a/compute/apiv1/machine_images_client_example_test.go +++ b/compute/apiv1/machine_images_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/machine_types_client.go b/compute/apiv1/machine_types_client.go index 66f53576612b..16df3a2de5ba 100755 --- a/compute/apiv1/machine_types_client.go +++ b/compute/apiv1/machine_types_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/machine_types_client_example_go123_test.go b/compute/apiv1/machine_types_client_example_go123_test.go index b99fa49b2131..cbd58ef80617 100644 --- a/compute/apiv1/machine_types_client_example_go123_test.go +++ b/compute/apiv1/machine_types_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/machine_types_client_example_test.go b/compute/apiv1/machine_types_client_example_test.go index 9c7fc3b29de5..94c9893e4ec4 100644 --- a/compute/apiv1/machine_types_client_example_test.go +++ b/compute/apiv1/machine_types_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/network_attachments_client.go b/compute/apiv1/network_attachments_client.go index aa86c6475a8f..2c3384b9c346 100755 --- a/compute/apiv1/network_attachments_client.go +++ b/compute/apiv1/network_attachments_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/network_attachments_client_example_go123_test.go b/compute/apiv1/network_attachments_client_example_go123_test.go index 2b01dcb460d4..3555802b4f0c 100644 --- a/compute/apiv1/network_attachments_client_example_go123_test.go +++ b/compute/apiv1/network_attachments_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/network_attachments_client_example_test.go b/compute/apiv1/network_attachments_client_example_test.go index d7b102056863..8058fc44126f 100644 --- a/compute/apiv1/network_attachments_client_example_test.go +++ b/compute/apiv1/network_attachments_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/network_edge_security_services_client.go b/compute/apiv1/network_edge_security_services_client.go index 753f72ec524c..b10a24e33e7c 100755 --- a/compute/apiv1/network_edge_security_services_client.go +++ b/compute/apiv1/network_edge_security_services_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/network_edge_security_services_client_example_go123_test.go b/compute/apiv1/network_edge_security_services_client_example_go123_test.go index e26d7eada32e..19eb4a3a6ed4 100644 --- a/compute/apiv1/network_edge_security_services_client_example_go123_test.go +++ b/compute/apiv1/network_edge_security_services_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/network_edge_security_services_client_example_test.go b/compute/apiv1/network_edge_security_services_client_example_test.go index 1910afacbc0c..fb8ddbbf64fc 100644 --- a/compute/apiv1/network_edge_security_services_client_example_test.go +++ b/compute/apiv1/network_edge_security_services_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/network_endpoint_groups_client.go b/compute/apiv1/network_endpoint_groups_client.go index 7516c319b296..4890acfc650c 100755 --- a/compute/apiv1/network_endpoint_groups_client.go +++ b/compute/apiv1/network_endpoint_groups_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/network_endpoint_groups_client_example_go123_test.go b/compute/apiv1/network_endpoint_groups_client_example_go123_test.go index 3c5990f5d3a2..60330c57bc6e 100644 --- a/compute/apiv1/network_endpoint_groups_client_example_go123_test.go +++ b/compute/apiv1/network_endpoint_groups_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/network_endpoint_groups_client_example_test.go b/compute/apiv1/network_endpoint_groups_client_example_test.go index bef6102a6b8e..f36bc15d6a83 100644 --- a/compute/apiv1/network_endpoint_groups_client_example_test.go +++ b/compute/apiv1/network_endpoint_groups_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/network_firewall_policies_client.go b/compute/apiv1/network_firewall_policies_client.go index 2a1792bd8fd4..16b619e7b5e4 100755 --- a/compute/apiv1/network_firewall_policies_client.go +++ b/compute/apiv1/network_firewall_policies_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/network_firewall_policies_client_example_go123_test.go b/compute/apiv1/network_firewall_policies_client_example_go123_test.go index a2c5353d7dd6..92955ed1b482 100644 --- a/compute/apiv1/network_firewall_policies_client_example_go123_test.go +++ b/compute/apiv1/network_firewall_policies_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/network_firewall_policies_client_example_test.go b/compute/apiv1/network_firewall_policies_client_example_test.go index ed85d0848288..4634d54f4f52 100644 --- a/compute/apiv1/network_firewall_policies_client_example_test.go +++ b/compute/apiv1/network_firewall_policies_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/network_profiles_client.go b/compute/apiv1/network_profiles_client.go index aea4edfc1ccd..415b6bf6ace5 100755 --- a/compute/apiv1/network_profiles_client.go +++ b/compute/apiv1/network_profiles_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/network_profiles_client_example_go123_test.go b/compute/apiv1/network_profiles_client_example_go123_test.go index 1838f14a6c4f..8907af1029fe 100644 --- a/compute/apiv1/network_profiles_client_example_go123_test.go +++ b/compute/apiv1/network_profiles_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/network_profiles_client_example_test.go b/compute/apiv1/network_profiles_client_example_test.go index 2d623156d392..60df8b79c4fb 100644 --- a/compute/apiv1/network_profiles_client_example_test.go +++ b/compute/apiv1/network_profiles_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/networks_client.go b/compute/apiv1/networks_client.go index bfabe87d4395..a1bcb32c0f1a 100755 --- a/compute/apiv1/networks_client.go +++ b/compute/apiv1/networks_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/networks_client_example_go123_test.go b/compute/apiv1/networks_client_example_go123_test.go index 78991fcc53b1..ca45580d52f5 100644 --- a/compute/apiv1/networks_client_example_go123_test.go +++ b/compute/apiv1/networks_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/networks_client_example_test.go b/compute/apiv1/networks_client_example_test.go index ab0c1d7f4738..d6f75959f150 100644 --- a/compute/apiv1/networks_client_example_test.go +++ b/compute/apiv1/networks_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/node_groups_client.go b/compute/apiv1/node_groups_client.go index 7eeb7f2fc700..d1960c4646f5 100755 --- a/compute/apiv1/node_groups_client.go +++ b/compute/apiv1/node_groups_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/node_groups_client_example_go123_test.go b/compute/apiv1/node_groups_client_example_go123_test.go index a43fcc4e0627..074539fa4be9 100644 --- a/compute/apiv1/node_groups_client_example_go123_test.go +++ b/compute/apiv1/node_groups_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/node_groups_client_example_test.go b/compute/apiv1/node_groups_client_example_test.go index 3051bc8b497a..74e733ca80c9 100644 --- a/compute/apiv1/node_groups_client_example_test.go +++ b/compute/apiv1/node_groups_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/node_templates_client.go b/compute/apiv1/node_templates_client.go index c540556493ec..9877fc88aa5a 100755 --- a/compute/apiv1/node_templates_client.go +++ b/compute/apiv1/node_templates_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/node_templates_client_example_go123_test.go b/compute/apiv1/node_templates_client_example_go123_test.go index faa29339ca60..963e6717a863 100644 --- a/compute/apiv1/node_templates_client_example_go123_test.go +++ b/compute/apiv1/node_templates_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/node_templates_client_example_test.go b/compute/apiv1/node_templates_client_example_test.go index 851735c482e9..ed797d54d9bf 100644 --- a/compute/apiv1/node_templates_client_example_test.go +++ b/compute/apiv1/node_templates_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/node_types_client.go b/compute/apiv1/node_types_client.go index 8041e0a7fb30..8e7e3430c45a 100755 --- a/compute/apiv1/node_types_client.go +++ b/compute/apiv1/node_types_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/node_types_client_example_go123_test.go b/compute/apiv1/node_types_client_example_go123_test.go index 365420293fb0..eee6a1ab49ef 100644 --- a/compute/apiv1/node_types_client_example_go123_test.go +++ b/compute/apiv1/node_types_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/node_types_client_example_test.go b/compute/apiv1/node_types_client_example_test.go index a345b4372a10..dad7f33064c9 100644 --- a/compute/apiv1/node_types_client_example_test.go +++ b/compute/apiv1/node_types_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/operations.go b/compute/apiv1/operations.go index bfee8ff96524..4ffb09570d13 100755 --- a/compute/apiv1/operations.go +++ b/compute/apiv1/operations.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/packet_mirrorings_client.go b/compute/apiv1/packet_mirrorings_client.go index cb2e144f736c..ef86efda4a67 100755 --- a/compute/apiv1/packet_mirrorings_client.go +++ b/compute/apiv1/packet_mirrorings_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/packet_mirrorings_client_example_go123_test.go b/compute/apiv1/packet_mirrorings_client_example_go123_test.go index 1fc85c14b1ce..f0743ad98feb 100644 --- a/compute/apiv1/packet_mirrorings_client_example_go123_test.go +++ b/compute/apiv1/packet_mirrorings_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/packet_mirrorings_client_example_test.go b/compute/apiv1/packet_mirrorings_client_example_test.go index 3691fc345130..42de4892b634 100644 --- a/compute/apiv1/packet_mirrorings_client_example_test.go +++ b/compute/apiv1/packet_mirrorings_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/projects_client.go b/compute/apiv1/projects_client.go index abf9ebacbce3..c02632d96d91 100755 --- a/compute/apiv1/projects_client.go +++ b/compute/apiv1/projects_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/projects_client_example_go123_test.go b/compute/apiv1/projects_client_example_go123_test.go index 578b79f1fb6a..ec8c00616823 100644 --- a/compute/apiv1/projects_client_example_go123_test.go +++ b/compute/apiv1/projects_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/projects_client_example_test.go b/compute/apiv1/projects_client_example_test.go index 2b2d7afa11c5..ddb09bfb2093 100644 --- a/compute/apiv1/projects_client_example_test.go +++ b/compute/apiv1/projects_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/public_advertised_prefixes_client.go b/compute/apiv1/public_advertised_prefixes_client.go index 3fc3a0d5da04..73dd9a38e56c 100755 --- a/compute/apiv1/public_advertised_prefixes_client.go +++ b/compute/apiv1/public_advertised_prefixes_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/public_advertised_prefixes_client_example_go123_test.go b/compute/apiv1/public_advertised_prefixes_client_example_go123_test.go index 9e8427051b27..ea03eec6803b 100644 --- a/compute/apiv1/public_advertised_prefixes_client_example_go123_test.go +++ b/compute/apiv1/public_advertised_prefixes_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/public_advertised_prefixes_client_example_test.go b/compute/apiv1/public_advertised_prefixes_client_example_test.go index 38d449d4c09d..e8f8c5c20dfb 100644 --- a/compute/apiv1/public_advertised_prefixes_client_example_test.go +++ b/compute/apiv1/public_advertised_prefixes_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/public_delegated_prefixes_client.go b/compute/apiv1/public_delegated_prefixes_client.go index 5d017912713a..a236036ab457 100755 --- a/compute/apiv1/public_delegated_prefixes_client.go +++ b/compute/apiv1/public_delegated_prefixes_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/public_delegated_prefixes_client_example_go123_test.go b/compute/apiv1/public_delegated_prefixes_client_example_go123_test.go index dbd4de9b1225..501af6074031 100644 --- a/compute/apiv1/public_delegated_prefixes_client_example_go123_test.go +++ b/compute/apiv1/public_delegated_prefixes_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/public_delegated_prefixes_client_example_test.go b/compute/apiv1/public_delegated_prefixes_client_example_test.go index 1ad1e8c91132..9af0638701a2 100644 --- a/compute/apiv1/public_delegated_prefixes_client_example_test.go +++ b/compute/apiv1/public_delegated_prefixes_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_autoscalers_client.go b/compute/apiv1/region_autoscalers_client.go index d04a7d3171cd..64f0f90b82bd 100755 --- a/compute/apiv1/region_autoscalers_client.go +++ b/compute/apiv1/region_autoscalers_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_autoscalers_client_example_go123_test.go b/compute/apiv1/region_autoscalers_client_example_go123_test.go index e3aa1bbed754..d76dc5df19c5 100644 --- a/compute/apiv1/region_autoscalers_client_example_go123_test.go +++ b/compute/apiv1/region_autoscalers_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_autoscalers_client_example_test.go b/compute/apiv1/region_autoscalers_client_example_test.go index 37f3c2e2afc1..dc1c54031e80 100644 --- a/compute/apiv1/region_autoscalers_client_example_test.go +++ b/compute/apiv1/region_autoscalers_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_backend_services_client.go b/compute/apiv1/region_backend_services_client.go index 1d0632050bde..e777e9e69651 100755 --- a/compute/apiv1/region_backend_services_client.go +++ b/compute/apiv1/region_backend_services_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_backend_services_client_example_go123_test.go b/compute/apiv1/region_backend_services_client_example_go123_test.go index fd149a321d31..e88e253d0fff 100644 --- a/compute/apiv1/region_backend_services_client_example_go123_test.go +++ b/compute/apiv1/region_backend_services_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_backend_services_client_example_test.go b/compute/apiv1/region_backend_services_client_example_test.go index e3cbda18aef2..1e6a252140e2 100644 --- a/compute/apiv1/region_backend_services_client_example_test.go +++ b/compute/apiv1/region_backend_services_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_commitments_client.go b/compute/apiv1/region_commitments_client.go index 5aa96ce5cd34..3e5c8a79c122 100755 --- a/compute/apiv1/region_commitments_client.go +++ b/compute/apiv1/region_commitments_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_commitments_client_example_go123_test.go b/compute/apiv1/region_commitments_client_example_go123_test.go index bbf118822b83..16094a168f79 100644 --- a/compute/apiv1/region_commitments_client_example_go123_test.go +++ b/compute/apiv1/region_commitments_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_commitments_client_example_test.go b/compute/apiv1/region_commitments_client_example_test.go index 6e37b536f6e5..eb0aaa8925eb 100644 --- a/compute/apiv1/region_commitments_client_example_test.go +++ b/compute/apiv1/region_commitments_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_disk_types_client.go b/compute/apiv1/region_disk_types_client.go index b715dd92cb26..2223c13f7b22 100755 --- a/compute/apiv1/region_disk_types_client.go +++ b/compute/apiv1/region_disk_types_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_disk_types_client_example_go123_test.go b/compute/apiv1/region_disk_types_client_example_go123_test.go index c19afca48515..07226a3b142d 100644 --- a/compute/apiv1/region_disk_types_client_example_go123_test.go +++ b/compute/apiv1/region_disk_types_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_disk_types_client_example_test.go b/compute/apiv1/region_disk_types_client_example_test.go index e94db4f949bf..b4782e2c4f87 100644 --- a/compute/apiv1/region_disk_types_client_example_test.go +++ b/compute/apiv1/region_disk_types_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_disks_client.go b/compute/apiv1/region_disks_client.go index c0accc2b6c92..08158c1492ee 100755 --- a/compute/apiv1/region_disks_client.go +++ b/compute/apiv1/region_disks_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_disks_client_example_go123_test.go b/compute/apiv1/region_disks_client_example_go123_test.go index b6526ed1e3a4..0d0d476cde50 100644 --- a/compute/apiv1/region_disks_client_example_go123_test.go +++ b/compute/apiv1/region_disks_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_disks_client_example_test.go b/compute/apiv1/region_disks_client_example_test.go index 9242b966c83c..7e12362b2de5 100644 --- a/compute/apiv1/region_disks_client_example_test.go +++ b/compute/apiv1/region_disks_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_health_check_services_client.go b/compute/apiv1/region_health_check_services_client.go index 4c817913034c..c5b2dc72f302 100755 --- a/compute/apiv1/region_health_check_services_client.go +++ b/compute/apiv1/region_health_check_services_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_health_check_services_client_example_go123_test.go b/compute/apiv1/region_health_check_services_client_example_go123_test.go index c381ea9c59ce..fc2f1371d96e 100644 --- a/compute/apiv1/region_health_check_services_client_example_go123_test.go +++ b/compute/apiv1/region_health_check_services_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_health_check_services_client_example_test.go b/compute/apiv1/region_health_check_services_client_example_test.go index 737c7884c170..6c625e9fb975 100644 --- a/compute/apiv1/region_health_check_services_client_example_test.go +++ b/compute/apiv1/region_health_check_services_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_health_checks_client.go b/compute/apiv1/region_health_checks_client.go index e68becd29244..cf5594343daf 100755 --- a/compute/apiv1/region_health_checks_client.go +++ b/compute/apiv1/region_health_checks_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_health_checks_client_example_go123_test.go b/compute/apiv1/region_health_checks_client_example_go123_test.go index c91b846c4bc5..7bed8057e008 100644 --- a/compute/apiv1/region_health_checks_client_example_go123_test.go +++ b/compute/apiv1/region_health_checks_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_health_checks_client_example_test.go b/compute/apiv1/region_health_checks_client_example_test.go index d7f964278940..34b3c3104860 100644 --- a/compute/apiv1/region_health_checks_client_example_test.go +++ b/compute/apiv1/region_health_checks_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_instance_group_managers_client.go b/compute/apiv1/region_instance_group_managers_client.go index 36949e05ea2f..b5bb63626986 100755 --- a/compute/apiv1/region_instance_group_managers_client.go +++ b/compute/apiv1/region_instance_group_managers_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_instance_group_managers_client_example_go123_test.go b/compute/apiv1/region_instance_group_managers_client_example_go123_test.go index 35e6902fc93b..5021ac4aeb99 100644 --- a/compute/apiv1/region_instance_group_managers_client_example_go123_test.go +++ b/compute/apiv1/region_instance_group_managers_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_instance_group_managers_client_example_test.go b/compute/apiv1/region_instance_group_managers_client_example_test.go index 70ecfa3e064a..39fbb7d44f11 100644 --- a/compute/apiv1/region_instance_group_managers_client_example_test.go +++ b/compute/apiv1/region_instance_group_managers_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_instance_groups_client.go b/compute/apiv1/region_instance_groups_client.go index 0f5bf57f62b2..a033b3c95292 100755 --- a/compute/apiv1/region_instance_groups_client.go +++ b/compute/apiv1/region_instance_groups_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_instance_groups_client_example_go123_test.go b/compute/apiv1/region_instance_groups_client_example_go123_test.go index 1078d52df100..1b81a05c2fd2 100644 --- a/compute/apiv1/region_instance_groups_client_example_go123_test.go +++ b/compute/apiv1/region_instance_groups_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_instance_groups_client_example_test.go b/compute/apiv1/region_instance_groups_client_example_test.go index 6bdd043146db..74167e50eb84 100644 --- a/compute/apiv1/region_instance_groups_client_example_test.go +++ b/compute/apiv1/region_instance_groups_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_instance_templates_client.go b/compute/apiv1/region_instance_templates_client.go index 9e1792029684..fe4096788780 100755 --- a/compute/apiv1/region_instance_templates_client.go +++ b/compute/apiv1/region_instance_templates_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_instance_templates_client_example_go123_test.go b/compute/apiv1/region_instance_templates_client_example_go123_test.go index bcc0b54dc370..11028efb1d7e 100644 --- a/compute/apiv1/region_instance_templates_client_example_go123_test.go +++ b/compute/apiv1/region_instance_templates_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_instance_templates_client_example_test.go b/compute/apiv1/region_instance_templates_client_example_test.go index 14f4977501b4..2af91563ae5a 100644 --- a/compute/apiv1/region_instance_templates_client_example_test.go +++ b/compute/apiv1/region_instance_templates_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_instances_client.go b/compute/apiv1/region_instances_client.go index 5729c502f2e6..683bd598bfd5 100755 --- a/compute/apiv1/region_instances_client.go +++ b/compute/apiv1/region_instances_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_instances_client_example_go123_test.go b/compute/apiv1/region_instances_client_example_go123_test.go index 6f8858b6c7a7..e75790f7ff6c 100644 --- a/compute/apiv1/region_instances_client_example_go123_test.go +++ b/compute/apiv1/region_instances_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_instances_client_example_test.go b/compute/apiv1/region_instances_client_example_test.go index 68759762342a..adedc88cfc75 100644 --- a/compute/apiv1/region_instances_client_example_test.go +++ b/compute/apiv1/region_instances_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_instant_snapshots_client.go b/compute/apiv1/region_instant_snapshots_client.go index 10a81629ae6b..b50fe4393418 100755 --- a/compute/apiv1/region_instant_snapshots_client.go +++ b/compute/apiv1/region_instant_snapshots_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_instant_snapshots_client_example_go123_test.go b/compute/apiv1/region_instant_snapshots_client_example_go123_test.go index f55ce4fde7ee..38ff56df79b1 100644 --- a/compute/apiv1/region_instant_snapshots_client_example_go123_test.go +++ b/compute/apiv1/region_instant_snapshots_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_instant_snapshots_client_example_test.go b/compute/apiv1/region_instant_snapshots_client_example_test.go index a8cc6ee64550..1c1353dad6e1 100644 --- a/compute/apiv1/region_instant_snapshots_client_example_test.go +++ b/compute/apiv1/region_instant_snapshots_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_network_endpoint_groups_client.go b/compute/apiv1/region_network_endpoint_groups_client.go index 484fbf14dc91..b4d4a4c81c5c 100755 --- a/compute/apiv1/region_network_endpoint_groups_client.go +++ b/compute/apiv1/region_network_endpoint_groups_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_network_endpoint_groups_client_example_go123_test.go b/compute/apiv1/region_network_endpoint_groups_client_example_go123_test.go index aab7f6cc25cb..d00ef9042ed7 100644 --- a/compute/apiv1/region_network_endpoint_groups_client_example_go123_test.go +++ b/compute/apiv1/region_network_endpoint_groups_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_network_endpoint_groups_client_example_test.go b/compute/apiv1/region_network_endpoint_groups_client_example_test.go index b2403f7f2ffe..4b41f2ef24d9 100644 --- a/compute/apiv1/region_network_endpoint_groups_client_example_test.go +++ b/compute/apiv1/region_network_endpoint_groups_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_network_firewall_policies_client.go b/compute/apiv1/region_network_firewall_policies_client.go index fbe37c7f7cf9..23fa48bbecf0 100755 --- a/compute/apiv1/region_network_firewall_policies_client.go +++ b/compute/apiv1/region_network_firewall_policies_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_network_firewall_policies_client_example_go123_test.go b/compute/apiv1/region_network_firewall_policies_client_example_go123_test.go index 44392161d697..417c2b7ba5a7 100644 --- a/compute/apiv1/region_network_firewall_policies_client_example_go123_test.go +++ b/compute/apiv1/region_network_firewall_policies_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_network_firewall_policies_client_example_test.go b/compute/apiv1/region_network_firewall_policies_client_example_test.go index 2a01ad128a19..add9f0c33ed1 100644 --- a/compute/apiv1/region_network_firewall_policies_client_example_test.go +++ b/compute/apiv1/region_network_firewall_policies_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_notification_endpoints_client.go b/compute/apiv1/region_notification_endpoints_client.go index bc578f0c2dd3..1758da5e089a 100755 --- a/compute/apiv1/region_notification_endpoints_client.go +++ b/compute/apiv1/region_notification_endpoints_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_notification_endpoints_client_example_go123_test.go b/compute/apiv1/region_notification_endpoints_client_example_go123_test.go index c0f67a436a81..3891acd394d6 100644 --- a/compute/apiv1/region_notification_endpoints_client_example_go123_test.go +++ b/compute/apiv1/region_notification_endpoints_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_notification_endpoints_client_example_test.go b/compute/apiv1/region_notification_endpoints_client_example_test.go index 1bf625ea014e..cb27df6e1427 100644 --- a/compute/apiv1/region_notification_endpoints_client_example_test.go +++ b/compute/apiv1/region_notification_endpoints_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_operations_client.go b/compute/apiv1/region_operations_client.go index c8b29b3ff1e5..c55b89d3313e 100755 --- a/compute/apiv1/region_operations_client.go +++ b/compute/apiv1/region_operations_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_operations_client_example_go123_test.go b/compute/apiv1/region_operations_client_example_go123_test.go index d1a54cf82ab8..4c1bebb47431 100644 --- a/compute/apiv1/region_operations_client_example_go123_test.go +++ b/compute/apiv1/region_operations_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_operations_client_example_test.go b/compute/apiv1/region_operations_client_example_test.go index 050c0fb8ff57..759947d58f3a 100644 --- a/compute/apiv1/region_operations_client_example_test.go +++ b/compute/apiv1/region_operations_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_security_policies_client.go b/compute/apiv1/region_security_policies_client.go index 9e4bd9f5bfd9..5ded74c2b84a 100755 --- a/compute/apiv1/region_security_policies_client.go +++ b/compute/apiv1/region_security_policies_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_security_policies_client_example_go123_test.go b/compute/apiv1/region_security_policies_client_example_go123_test.go index f2c5eb6cdc57..49ff30dffdcd 100644 --- a/compute/apiv1/region_security_policies_client_example_go123_test.go +++ b/compute/apiv1/region_security_policies_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_security_policies_client_example_test.go b/compute/apiv1/region_security_policies_client_example_test.go index 81d4df9ef1f5..c1687a798bc3 100644 --- a/compute/apiv1/region_security_policies_client_example_test.go +++ b/compute/apiv1/region_security_policies_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_ssl_certificates_client.go b/compute/apiv1/region_ssl_certificates_client.go index 22fd51bfa03c..194351fdb90d 100755 --- a/compute/apiv1/region_ssl_certificates_client.go +++ b/compute/apiv1/region_ssl_certificates_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_ssl_certificates_client_example_go123_test.go b/compute/apiv1/region_ssl_certificates_client_example_go123_test.go index 119fcd093945..1d4f8f567cfc 100644 --- a/compute/apiv1/region_ssl_certificates_client_example_go123_test.go +++ b/compute/apiv1/region_ssl_certificates_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_ssl_certificates_client_example_test.go b/compute/apiv1/region_ssl_certificates_client_example_test.go index 85d2cd6c9397..b383fd2dc151 100644 --- a/compute/apiv1/region_ssl_certificates_client_example_test.go +++ b/compute/apiv1/region_ssl_certificates_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_ssl_policies_client.go b/compute/apiv1/region_ssl_policies_client.go index dd0fb17c2a12..2dd3df8ae8e9 100755 --- a/compute/apiv1/region_ssl_policies_client.go +++ b/compute/apiv1/region_ssl_policies_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_ssl_policies_client_example_go123_test.go b/compute/apiv1/region_ssl_policies_client_example_go123_test.go index b7be24496813..6e531920f04c 100644 --- a/compute/apiv1/region_ssl_policies_client_example_go123_test.go +++ b/compute/apiv1/region_ssl_policies_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_ssl_policies_client_example_test.go b/compute/apiv1/region_ssl_policies_client_example_test.go index 334d93bcccf4..0d6fbd71c3bb 100644 --- a/compute/apiv1/region_ssl_policies_client_example_test.go +++ b/compute/apiv1/region_ssl_policies_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_target_http_proxies_client.go b/compute/apiv1/region_target_http_proxies_client.go index 04ed0e174ee3..d878517e8716 100755 --- a/compute/apiv1/region_target_http_proxies_client.go +++ b/compute/apiv1/region_target_http_proxies_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_target_http_proxies_client_example_go123_test.go b/compute/apiv1/region_target_http_proxies_client_example_go123_test.go index 20ce18fc8570..37e043b964ab 100644 --- a/compute/apiv1/region_target_http_proxies_client_example_go123_test.go +++ b/compute/apiv1/region_target_http_proxies_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_target_http_proxies_client_example_test.go b/compute/apiv1/region_target_http_proxies_client_example_test.go index 4815fc2667ac..b4dab4ee8b69 100644 --- a/compute/apiv1/region_target_http_proxies_client_example_test.go +++ b/compute/apiv1/region_target_http_proxies_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_target_https_proxies_client.go b/compute/apiv1/region_target_https_proxies_client.go index d3b03c744c8b..644fd124610d 100755 --- a/compute/apiv1/region_target_https_proxies_client.go +++ b/compute/apiv1/region_target_https_proxies_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_target_https_proxies_client_example_go123_test.go b/compute/apiv1/region_target_https_proxies_client_example_go123_test.go index 470c0cc90dca..675f8fe54b36 100644 --- a/compute/apiv1/region_target_https_proxies_client_example_go123_test.go +++ b/compute/apiv1/region_target_https_proxies_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_target_https_proxies_client_example_test.go b/compute/apiv1/region_target_https_proxies_client_example_test.go index 0fc2341d92c0..ac43348bd355 100644 --- a/compute/apiv1/region_target_https_proxies_client_example_test.go +++ b/compute/apiv1/region_target_https_proxies_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_target_tcp_proxies_client.go b/compute/apiv1/region_target_tcp_proxies_client.go index 196d62dd20df..69300aa8543f 100755 --- a/compute/apiv1/region_target_tcp_proxies_client.go +++ b/compute/apiv1/region_target_tcp_proxies_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_target_tcp_proxies_client_example_go123_test.go b/compute/apiv1/region_target_tcp_proxies_client_example_go123_test.go index 4c01105ae8d0..ae0607801d75 100644 --- a/compute/apiv1/region_target_tcp_proxies_client_example_go123_test.go +++ b/compute/apiv1/region_target_tcp_proxies_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_target_tcp_proxies_client_example_test.go b/compute/apiv1/region_target_tcp_proxies_client_example_test.go index efb5cc7a9258..91469cd56b2a 100644 --- a/compute/apiv1/region_target_tcp_proxies_client_example_test.go +++ b/compute/apiv1/region_target_tcp_proxies_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_url_maps_client.go b/compute/apiv1/region_url_maps_client.go index fc2f5094c778..f0816cfe2304 100755 --- a/compute/apiv1/region_url_maps_client.go +++ b/compute/apiv1/region_url_maps_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_url_maps_client_example_go123_test.go b/compute/apiv1/region_url_maps_client_example_go123_test.go index 636f6f32b302..34b81260b10e 100644 --- a/compute/apiv1/region_url_maps_client_example_go123_test.go +++ b/compute/apiv1/region_url_maps_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_url_maps_client_example_test.go b/compute/apiv1/region_url_maps_client_example_test.go index 41df8f69253d..3992e5d68f95 100644 --- a/compute/apiv1/region_url_maps_client_example_test.go +++ b/compute/apiv1/region_url_maps_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_zones_client.go b/compute/apiv1/region_zones_client.go index 90da85a21e44..2085e81ff146 100755 --- a/compute/apiv1/region_zones_client.go +++ b/compute/apiv1/region_zones_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_zones_client_example_go123_test.go b/compute/apiv1/region_zones_client_example_go123_test.go index f3df29d6bd6f..db8eef266691 100644 --- a/compute/apiv1/region_zones_client_example_go123_test.go +++ b/compute/apiv1/region_zones_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/region_zones_client_example_test.go b/compute/apiv1/region_zones_client_example_test.go index 85d5c2a0cb4a..ceff78d21958 100644 --- a/compute/apiv1/region_zones_client_example_test.go +++ b/compute/apiv1/region_zones_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/regions_client.go b/compute/apiv1/regions_client.go index 357f2a54aef0..48be2619e567 100755 --- a/compute/apiv1/regions_client.go +++ b/compute/apiv1/regions_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/regions_client_example_go123_test.go b/compute/apiv1/regions_client_example_go123_test.go index 7289bab6a6c8..06c745d9d4df 100644 --- a/compute/apiv1/regions_client_example_go123_test.go +++ b/compute/apiv1/regions_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/regions_client_example_test.go b/compute/apiv1/regions_client_example_test.go index 0e8e0282fe61..4999fe432d38 100644 --- a/compute/apiv1/regions_client_example_test.go +++ b/compute/apiv1/regions_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/reservations_client.go b/compute/apiv1/reservations_client.go index 5ffd814f5c45..a77084c8a346 100755 --- a/compute/apiv1/reservations_client.go +++ b/compute/apiv1/reservations_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/reservations_client_example_go123_test.go b/compute/apiv1/reservations_client_example_go123_test.go index 0aad59071260..047352b1840f 100644 --- a/compute/apiv1/reservations_client_example_go123_test.go +++ b/compute/apiv1/reservations_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/reservations_client_example_test.go b/compute/apiv1/reservations_client_example_test.go index 871b5601d02c..badd01ccede9 100644 --- a/compute/apiv1/reservations_client_example_test.go +++ b/compute/apiv1/reservations_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/resource_policies_client.go b/compute/apiv1/resource_policies_client.go index ec433615918e..108ba6ab1fce 100755 --- a/compute/apiv1/resource_policies_client.go +++ b/compute/apiv1/resource_policies_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/resource_policies_client_example_go123_test.go b/compute/apiv1/resource_policies_client_example_go123_test.go index bc849db1838a..b57d8619f6f8 100644 --- a/compute/apiv1/resource_policies_client_example_go123_test.go +++ b/compute/apiv1/resource_policies_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/resource_policies_client_example_test.go b/compute/apiv1/resource_policies_client_example_test.go index 42d8ee63ac97..df9b5bae706c 100644 --- a/compute/apiv1/resource_policies_client_example_test.go +++ b/compute/apiv1/resource_policies_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/routers_client.go b/compute/apiv1/routers_client.go index 5b1cd750c56d..a78e68a9103a 100755 --- a/compute/apiv1/routers_client.go +++ b/compute/apiv1/routers_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/routers_client_example_go123_test.go b/compute/apiv1/routers_client_example_go123_test.go index fd8169cc73b6..dfbf3f0c20e2 100644 --- a/compute/apiv1/routers_client_example_go123_test.go +++ b/compute/apiv1/routers_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/routers_client_example_test.go b/compute/apiv1/routers_client_example_test.go index c629b769c324..b33f968eb518 100644 --- a/compute/apiv1/routers_client_example_test.go +++ b/compute/apiv1/routers_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/routes_client.go b/compute/apiv1/routes_client.go index 4605b8de593a..20d0f9639377 100755 --- a/compute/apiv1/routes_client.go +++ b/compute/apiv1/routes_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/routes_client_example_go123_test.go b/compute/apiv1/routes_client_example_go123_test.go index 34ba5087414b..4a8a20f7d8d0 100644 --- a/compute/apiv1/routes_client_example_go123_test.go +++ b/compute/apiv1/routes_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/routes_client_example_test.go b/compute/apiv1/routes_client_example_test.go index c048299b46e9..42415378401d 100644 --- a/compute/apiv1/routes_client_example_test.go +++ b/compute/apiv1/routes_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/security_policies_client.go b/compute/apiv1/security_policies_client.go index 1f2ef494ada4..171058855939 100755 --- a/compute/apiv1/security_policies_client.go +++ b/compute/apiv1/security_policies_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/security_policies_client_example_go123_test.go b/compute/apiv1/security_policies_client_example_go123_test.go index 76076b33cd73..d7a06c243986 100644 --- a/compute/apiv1/security_policies_client_example_go123_test.go +++ b/compute/apiv1/security_policies_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/security_policies_client_example_test.go b/compute/apiv1/security_policies_client_example_test.go index e2716a80c408..d5c815c8a042 100644 --- a/compute/apiv1/security_policies_client_example_test.go +++ b/compute/apiv1/security_policies_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/service_attachments_client.go b/compute/apiv1/service_attachments_client.go index 9191bd04578c..db68d2eecb19 100755 --- a/compute/apiv1/service_attachments_client.go +++ b/compute/apiv1/service_attachments_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/service_attachments_client_example_go123_test.go b/compute/apiv1/service_attachments_client_example_go123_test.go index e0976079c53b..14413c40ded1 100644 --- a/compute/apiv1/service_attachments_client_example_go123_test.go +++ b/compute/apiv1/service_attachments_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/service_attachments_client_example_test.go b/compute/apiv1/service_attachments_client_example_test.go index 9255ac5fdc08..93b6a1e6da50 100644 --- a/compute/apiv1/service_attachments_client_example_test.go +++ b/compute/apiv1/service_attachments_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/snapshot_settings_client.go b/compute/apiv1/snapshot_settings_client.go index 581646c8e26d..90475b9c2f25 100755 --- a/compute/apiv1/snapshot_settings_client.go +++ b/compute/apiv1/snapshot_settings_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/snapshot_settings_client_example_go123_test.go b/compute/apiv1/snapshot_settings_client_example_go123_test.go index 6f8858b6c7a7..e75790f7ff6c 100644 --- a/compute/apiv1/snapshot_settings_client_example_go123_test.go +++ b/compute/apiv1/snapshot_settings_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/snapshot_settings_client_example_test.go b/compute/apiv1/snapshot_settings_client_example_test.go index 608ee542840e..ca0f6e194863 100644 --- a/compute/apiv1/snapshot_settings_client_example_test.go +++ b/compute/apiv1/snapshot_settings_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/snapshots_client.go b/compute/apiv1/snapshots_client.go index 06eccadc92ab..3259547b9808 100755 --- a/compute/apiv1/snapshots_client.go +++ b/compute/apiv1/snapshots_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/snapshots_client_example_go123_test.go b/compute/apiv1/snapshots_client_example_go123_test.go index 501d2f6d2cbf..e4abaad98582 100644 --- a/compute/apiv1/snapshots_client_example_go123_test.go +++ b/compute/apiv1/snapshots_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/snapshots_client_example_test.go b/compute/apiv1/snapshots_client_example_test.go index 4ced1e24638d..b0c7a96d1142 100644 --- a/compute/apiv1/snapshots_client_example_test.go +++ b/compute/apiv1/snapshots_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/ssl_certificates_client.go b/compute/apiv1/ssl_certificates_client.go index 0761c4689907..013f76ab0738 100755 --- a/compute/apiv1/ssl_certificates_client.go +++ b/compute/apiv1/ssl_certificates_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/ssl_certificates_client_example_go123_test.go b/compute/apiv1/ssl_certificates_client_example_go123_test.go index fc853a76436a..272824869cad 100644 --- a/compute/apiv1/ssl_certificates_client_example_go123_test.go +++ b/compute/apiv1/ssl_certificates_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/ssl_certificates_client_example_test.go b/compute/apiv1/ssl_certificates_client_example_test.go index b2099060be12..a957c7199932 100644 --- a/compute/apiv1/ssl_certificates_client_example_test.go +++ b/compute/apiv1/ssl_certificates_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/ssl_policies_client.go b/compute/apiv1/ssl_policies_client.go index 08e4fcfb2046..23bfd2080e90 100755 --- a/compute/apiv1/ssl_policies_client.go +++ b/compute/apiv1/ssl_policies_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/ssl_policies_client_example_go123_test.go b/compute/apiv1/ssl_policies_client_example_go123_test.go index bcfc54ba6825..353d926d3b13 100644 --- a/compute/apiv1/ssl_policies_client_example_go123_test.go +++ b/compute/apiv1/ssl_policies_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/ssl_policies_client_example_test.go b/compute/apiv1/ssl_policies_client_example_test.go index dfa7300ee96b..685296aa72e5 100644 --- a/compute/apiv1/ssl_policies_client_example_test.go +++ b/compute/apiv1/ssl_policies_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/storage_pool_types_client.go b/compute/apiv1/storage_pool_types_client.go index 9fc043448eae..8e09dd23451e 100755 --- a/compute/apiv1/storage_pool_types_client.go +++ b/compute/apiv1/storage_pool_types_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/storage_pool_types_client_example_go123_test.go b/compute/apiv1/storage_pool_types_client_example_go123_test.go index 226dfca5b3e9..e7a3a24798d8 100644 --- a/compute/apiv1/storage_pool_types_client_example_go123_test.go +++ b/compute/apiv1/storage_pool_types_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/storage_pool_types_client_example_test.go b/compute/apiv1/storage_pool_types_client_example_test.go index 8b00047d5af7..8b68b2bd45ce 100644 --- a/compute/apiv1/storage_pool_types_client_example_test.go +++ b/compute/apiv1/storage_pool_types_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/storage_pools_client.go b/compute/apiv1/storage_pools_client.go index 54db0ca1fd4c..000006941049 100755 --- a/compute/apiv1/storage_pools_client.go +++ b/compute/apiv1/storage_pools_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/storage_pools_client_example_go123_test.go b/compute/apiv1/storage_pools_client_example_go123_test.go index 0f1389c266ea..cc3ef055162d 100644 --- a/compute/apiv1/storage_pools_client_example_go123_test.go +++ b/compute/apiv1/storage_pools_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/storage_pools_client_example_test.go b/compute/apiv1/storage_pools_client_example_test.go index 744af0131390..6eb1681ee4cd 100644 --- a/compute/apiv1/storage_pools_client_example_test.go +++ b/compute/apiv1/storage_pools_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/subnetworks_client.go b/compute/apiv1/subnetworks_client.go index 740f09e21ee6..cace86dd8694 100755 --- a/compute/apiv1/subnetworks_client.go +++ b/compute/apiv1/subnetworks_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/subnetworks_client_example_go123_test.go b/compute/apiv1/subnetworks_client_example_go123_test.go index 286bf1883fba..add86bb417ed 100644 --- a/compute/apiv1/subnetworks_client_example_go123_test.go +++ b/compute/apiv1/subnetworks_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/subnetworks_client_example_test.go b/compute/apiv1/subnetworks_client_example_test.go index b1e21184f8fc..da5dabbee278 100644 --- a/compute/apiv1/subnetworks_client_example_test.go +++ b/compute/apiv1/subnetworks_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/target_grpc_proxies_client.go b/compute/apiv1/target_grpc_proxies_client.go index 6bade4e88373..93e3c06702a4 100755 --- a/compute/apiv1/target_grpc_proxies_client.go +++ b/compute/apiv1/target_grpc_proxies_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/target_grpc_proxies_client_example_go123_test.go b/compute/apiv1/target_grpc_proxies_client_example_go123_test.go index 93d8d0904064..86bfecd9c550 100644 --- a/compute/apiv1/target_grpc_proxies_client_example_go123_test.go +++ b/compute/apiv1/target_grpc_proxies_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/target_grpc_proxies_client_example_test.go b/compute/apiv1/target_grpc_proxies_client_example_test.go index 44fdba1e2197..360812452ecf 100644 --- a/compute/apiv1/target_grpc_proxies_client_example_test.go +++ b/compute/apiv1/target_grpc_proxies_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/target_http_proxies_client.go b/compute/apiv1/target_http_proxies_client.go index 3759a06d5712..fec5e0cabcb3 100755 --- a/compute/apiv1/target_http_proxies_client.go +++ b/compute/apiv1/target_http_proxies_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/target_http_proxies_client_example_go123_test.go b/compute/apiv1/target_http_proxies_client_example_go123_test.go index 09a099906e6c..f8c330c7de95 100644 --- a/compute/apiv1/target_http_proxies_client_example_go123_test.go +++ b/compute/apiv1/target_http_proxies_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/target_http_proxies_client_example_test.go b/compute/apiv1/target_http_proxies_client_example_test.go index f24893f24d69..23c39103ead2 100644 --- a/compute/apiv1/target_http_proxies_client_example_test.go +++ b/compute/apiv1/target_http_proxies_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/target_https_proxies_client.go b/compute/apiv1/target_https_proxies_client.go index dbb0e9665dc8..752420193812 100755 --- a/compute/apiv1/target_https_proxies_client.go +++ b/compute/apiv1/target_https_proxies_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/target_https_proxies_client_example_go123_test.go b/compute/apiv1/target_https_proxies_client_example_go123_test.go index 104b7504333c..6461a01918af 100644 --- a/compute/apiv1/target_https_proxies_client_example_go123_test.go +++ b/compute/apiv1/target_https_proxies_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/target_https_proxies_client_example_test.go b/compute/apiv1/target_https_proxies_client_example_test.go index 9924051f2095..a7860116b041 100644 --- a/compute/apiv1/target_https_proxies_client_example_test.go +++ b/compute/apiv1/target_https_proxies_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/target_instances_client.go b/compute/apiv1/target_instances_client.go index ebaf3d1a23a4..49c8617bfbde 100755 --- a/compute/apiv1/target_instances_client.go +++ b/compute/apiv1/target_instances_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/target_instances_client_example_go123_test.go b/compute/apiv1/target_instances_client_example_go123_test.go index 1fc761dd12c9..d9a696f0eb1a 100644 --- a/compute/apiv1/target_instances_client_example_go123_test.go +++ b/compute/apiv1/target_instances_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/target_instances_client_example_test.go b/compute/apiv1/target_instances_client_example_test.go index cb28fb9e082a..730b4ea1b33e 100644 --- a/compute/apiv1/target_instances_client_example_test.go +++ b/compute/apiv1/target_instances_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/target_pools_client.go b/compute/apiv1/target_pools_client.go index 3b62387f335f..cf485a201223 100755 --- a/compute/apiv1/target_pools_client.go +++ b/compute/apiv1/target_pools_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/target_pools_client_example_go123_test.go b/compute/apiv1/target_pools_client_example_go123_test.go index ce0cb147ae35..0124677c6ce5 100644 --- a/compute/apiv1/target_pools_client_example_go123_test.go +++ b/compute/apiv1/target_pools_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/target_pools_client_example_test.go b/compute/apiv1/target_pools_client_example_test.go index afd107466c30..7737bf79cbbd 100644 --- a/compute/apiv1/target_pools_client_example_test.go +++ b/compute/apiv1/target_pools_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/target_ssl_proxies_client.go b/compute/apiv1/target_ssl_proxies_client.go index 7ca4d78f79b8..9ca01b4b8957 100755 --- a/compute/apiv1/target_ssl_proxies_client.go +++ b/compute/apiv1/target_ssl_proxies_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/target_ssl_proxies_client_example_go123_test.go b/compute/apiv1/target_ssl_proxies_client_example_go123_test.go index 8804f7e58279..48bcf0efee99 100644 --- a/compute/apiv1/target_ssl_proxies_client_example_go123_test.go +++ b/compute/apiv1/target_ssl_proxies_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/target_ssl_proxies_client_example_test.go b/compute/apiv1/target_ssl_proxies_client_example_test.go index 6da4c71649a6..ba1d554d8ca8 100644 --- a/compute/apiv1/target_ssl_proxies_client_example_test.go +++ b/compute/apiv1/target_ssl_proxies_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/target_tcp_proxies_client.go b/compute/apiv1/target_tcp_proxies_client.go index e533bcd8982f..87eb013124ae 100755 --- a/compute/apiv1/target_tcp_proxies_client.go +++ b/compute/apiv1/target_tcp_proxies_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/target_tcp_proxies_client_example_go123_test.go b/compute/apiv1/target_tcp_proxies_client_example_go123_test.go index 9392f30f41d1..14cd973f964a 100644 --- a/compute/apiv1/target_tcp_proxies_client_example_go123_test.go +++ b/compute/apiv1/target_tcp_proxies_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/target_tcp_proxies_client_example_test.go b/compute/apiv1/target_tcp_proxies_client_example_test.go index 2893a06fb3d9..333a223db393 100644 --- a/compute/apiv1/target_tcp_proxies_client_example_test.go +++ b/compute/apiv1/target_tcp_proxies_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/target_vpn_gateways_client.go b/compute/apiv1/target_vpn_gateways_client.go index 59124ed7d075..16ccd65681cd 100755 --- a/compute/apiv1/target_vpn_gateways_client.go +++ b/compute/apiv1/target_vpn_gateways_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/target_vpn_gateways_client_example_go123_test.go b/compute/apiv1/target_vpn_gateways_client_example_go123_test.go index 6dde60b492c6..df858ec43f5a 100644 --- a/compute/apiv1/target_vpn_gateways_client_example_go123_test.go +++ b/compute/apiv1/target_vpn_gateways_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/target_vpn_gateways_client_example_test.go b/compute/apiv1/target_vpn_gateways_client_example_test.go index bcffc1295337..350dbaf472c5 100644 --- a/compute/apiv1/target_vpn_gateways_client_example_test.go +++ b/compute/apiv1/target_vpn_gateways_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/url_maps_client.go b/compute/apiv1/url_maps_client.go index bde745d07a02..331c6aadba8b 100755 --- a/compute/apiv1/url_maps_client.go +++ b/compute/apiv1/url_maps_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/url_maps_client_example_go123_test.go b/compute/apiv1/url_maps_client_example_go123_test.go index 517a1ca2ffa6..529fb91b6fd6 100644 --- a/compute/apiv1/url_maps_client_example_go123_test.go +++ b/compute/apiv1/url_maps_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/url_maps_client_example_test.go b/compute/apiv1/url_maps_client_example_test.go index b439388848c0..65c582ae60e1 100644 --- a/compute/apiv1/url_maps_client_example_test.go +++ b/compute/apiv1/url_maps_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/vpn_gateways_client.go b/compute/apiv1/vpn_gateways_client.go index e49ae3bbed17..96fa6546d2ea 100755 --- a/compute/apiv1/vpn_gateways_client.go +++ b/compute/apiv1/vpn_gateways_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/vpn_gateways_client_example_go123_test.go b/compute/apiv1/vpn_gateways_client_example_go123_test.go index 85937a698940..3d1de2de9113 100644 --- a/compute/apiv1/vpn_gateways_client_example_go123_test.go +++ b/compute/apiv1/vpn_gateways_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/vpn_gateways_client_example_test.go b/compute/apiv1/vpn_gateways_client_example_test.go index 8ad13e11ad44..b418d3ab6d01 100644 --- a/compute/apiv1/vpn_gateways_client_example_test.go +++ b/compute/apiv1/vpn_gateways_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/vpn_tunnels_client.go b/compute/apiv1/vpn_tunnels_client.go index 8750a1d3c578..e4a717717818 100755 --- a/compute/apiv1/vpn_tunnels_client.go +++ b/compute/apiv1/vpn_tunnels_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/vpn_tunnels_client_example_go123_test.go b/compute/apiv1/vpn_tunnels_client_example_go123_test.go index fa05a16d93a7..ea2dbd645b6b 100644 --- a/compute/apiv1/vpn_tunnels_client_example_go123_test.go +++ b/compute/apiv1/vpn_tunnels_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/vpn_tunnels_client_example_test.go b/compute/apiv1/vpn_tunnels_client_example_test.go index a4f89b81530d..ab8aea551bc9 100644 --- a/compute/apiv1/vpn_tunnels_client_example_test.go +++ b/compute/apiv1/vpn_tunnels_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/zone_operations_client.go b/compute/apiv1/zone_operations_client.go index 61c65903de74..0f049cbc0277 100755 --- a/compute/apiv1/zone_operations_client.go +++ b/compute/apiv1/zone_operations_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/zone_operations_client_example_go123_test.go b/compute/apiv1/zone_operations_client_example_go123_test.go index 7b5a9670f8b4..681f0bc1f54d 100644 --- a/compute/apiv1/zone_operations_client_example_go123_test.go +++ b/compute/apiv1/zone_operations_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/zone_operations_client_example_test.go b/compute/apiv1/zone_operations_client_example_test.go index 0355a64987c9..82fdccade3fe 100644 --- a/compute/apiv1/zone_operations_client_example_test.go +++ b/compute/apiv1/zone_operations_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/zones_client.go b/compute/apiv1/zones_client.go index ba703884de90..ceb76f93bea6 100755 --- a/compute/apiv1/zones_client.go +++ b/compute/apiv1/zones_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/zones_client_example_go123_test.go b/compute/apiv1/zones_client_example_go123_test.go index 6d3fb22f56dc..e602a13b3280 100644 --- a/compute/apiv1/zones_client_example_go123_test.go +++ b/compute/apiv1/zones_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/compute/apiv1/zones_client_example_test.go b/compute/apiv1/zones_client_example_test.go index 003bcf854817..1f82f02477d4 100644 --- a/compute/apiv1/zones_client_example_test.go +++ b/compute/apiv1/zones_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/confidentialcomputing/apiv1/auxiliary.go b/confidentialcomputing/apiv1/auxiliary.go index 0849d641aeda..54be0978b635 100755 --- a/confidentialcomputing/apiv1/auxiliary.go +++ b/confidentialcomputing/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/confidentialcomputing/apiv1/auxiliary_go123.go b/confidentialcomputing/apiv1/auxiliary_go123.go index 97755ab4256a..13ed80f43049 100755 --- a/confidentialcomputing/apiv1/auxiliary_go123.go +++ b/confidentialcomputing/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/confidentialcomputing/apiv1/confidential_computing_client.go b/confidentialcomputing/apiv1/confidential_computing_client.go index a2716507c78e..dd90fea3bb38 100755 --- a/confidentialcomputing/apiv1/confidential_computing_client.go +++ b/confidentialcomputing/apiv1/confidential_computing_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/confidentialcomputing/apiv1/confidential_computing_client_example_go123_test.go b/confidentialcomputing/apiv1/confidential_computing_client_example_go123_test.go index 655a3d0599d4..e383fde4e1f9 100644 --- a/confidentialcomputing/apiv1/confidential_computing_client_example_go123_test.go +++ b/confidentialcomputing/apiv1/confidential_computing_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/confidentialcomputing/apiv1/confidential_computing_client_example_test.go b/confidentialcomputing/apiv1/confidential_computing_client_example_test.go index 84fe4184f17b..109eace25456 100644 --- a/confidentialcomputing/apiv1/confidential_computing_client_example_test.go +++ b/confidentialcomputing/apiv1/confidential_computing_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/confidentialcomputing/apiv1/doc.go b/confidentialcomputing/apiv1/doc.go index 45f6640303a3..3181899fb76e 100755 --- a/confidentialcomputing/apiv1/doc.go +++ b/confidentialcomputing/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/confidentialcomputing/apiv1/helpers.go b/confidentialcomputing/apiv1/helpers.go index c6838d3a4f63..d906ef115f4c 100755 --- a/confidentialcomputing/apiv1/helpers.go +++ b/confidentialcomputing/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/confidentialcomputing/apiv1alpha1/auxiliary.go b/confidentialcomputing/apiv1alpha1/auxiliary.go index 0849d641aeda..54be0978b635 100755 --- a/confidentialcomputing/apiv1alpha1/auxiliary.go +++ b/confidentialcomputing/apiv1alpha1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/confidentialcomputing/apiv1alpha1/auxiliary_go123.go b/confidentialcomputing/apiv1alpha1/auxiliary_go123.go index 97755ab4256a..13ed80f43049 100755 --- a/confidentialcomputing/apiv1alpha1/auxiliary_go123.go +++ b/confidentialcomputing/apiv1alpha1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/confidentialcomputing/apiv1alpha1/confidential_computing_client.go b/confidentialcomputing/apiv1alpha1/confidential_computing_client.go index fc59dee75d85..2a48b2ccbd39 100755 --- a/confidentialcomputing/apiv1alpha1/confidential_computing_client.go +++ b/confidentialcomputing/apiv1alpha1/confidential_computing_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/confidentialcomputing/apiv1alpha1/confidential_computing_client_example_go123_test.go b/confidentialcomputing/apiv1alpha1/confidential_computing_client_example_go123_test.go index 4b9bae5a2e0a..39bec5b7e7ee 100644 --- a/confidentialcomputing/apiv1alpha1/confidential_computing_client_example_go123_test.go +++ b/confidentialcomputing/apiv1alpha1/confidential_computing_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/confidentialcomputing/apiv1alpha1/confidential_computing_client_example_test.go b/confidentialcomputing/apiv1alpha1/confidential_computing_client_example_test.go index 2fba1ee19511..d1573a3f17fc 100644 --- a/confidentialcomputing/apiv1alpha1/confidential_computing_client_example_test.go +++ b/confidentialcomputing/apiv1alpha1/confidential_computing_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/confidentialcomputing/apiv1alpha1/doc.go b/confidentialcomputing/apiv1alpha1/doc.go index 45020df02779..419b0bba560e 100755 --- a/confidentialcomputing/apiv1alpha1/doc.go +++ b/confidentialcomputing/apiv1alpha1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/confidentialcomputing/apiv1alpha1/helpers.go b/confidentialcomputing/apiv1alpha1/helpers.go index c6838d3a4f63..d906ef115f4c 100755 --- a/confidentialcomputing/apiv1alpha1/helpers.go +++ b/confidentialcomputing/apiv1alpha1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/config/apiv1/auxiliary.go b/config/apiv1/auxiliary.go index c0fa11a33fba..343a0dd88fa6 100755 --- a/config/apiv1/auxiliary.go +++ b/config/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/config/apiv1/auxiliary_go123.go b/config/apiv1/auxiliary_go123.go index ccdf9cf363df..5bb5b3f2d1c2 100755 --- a/config/apiv1/auxiliary_go123.go +++ b/config/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/config/apiv1/config_client.go b/config/apiv1/config_client.go index dbd94d29113e..0c716bb9a215 100755 --- a/config/apiv1/config_client.go +++ b/config/apiv1/config_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/config/apiv1/config_client_example_go123_test.go b/config/apiv1/config_client_example_go123_test.go index b24747221793..8c67825b10e2 100644 --- a/config/apiv1/config_client_example_go123_test.go +++ b/config/apiv1/config_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/config/apiv1/config_client_example_test.go b/config/apiv1/config_client_example_test.go index 71acc115a911..26a23bc775ee 100644 --- a/config/apiv1/config_client_example_test.go +++ b/config/apiv1/config_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/config/apiv1/doc.go b/config/apiv1/doc.go index 8d5cff523b2e..f46e04fc5f04 100755 --- a/config/apiv1/doc.go +++ b/config/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/config/apiv1/helpers.go b/config/apiv1/helpers.go index 26097e000775..78fe182c0336 100755 --- a/config/apiv1/helpers.go +++ b/config/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/contactcenterinsights/apiv1/auxiliary.go b/contactcenterinsights/apiv1/auxiliary.go index c06eb00478da..a85b8fdca095 100755 --- a/contactcenterinsights/apiv1/auxiliary.go +++ b/contactcenterinsights/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/contactcenterinsights/apiv1/auxiliary_go123.go b/contactcenterinsights/apiv1/auxiliary_go123.go index 733f543f5879..ba51cdaf0b65 100755 --- a/contactcenterinsights/apiv1/auxiliary_go123.go +++ b/contactcenterinsights/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/contactcenterinsights/apiv1/contact_center_insights_client.go b/contactcenterinsights/apiv1/contact_center_insights_client.go index e75b87048d27..70756e016eeb 100755 --- a/contactcenterinsights/apiv1/contact_center_insights_client.go +++ b/contactcenterinsights/apiv1/contact_center_insights_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/contactcenterinsights/apiv1/contact_center_insights_client_example_go123_test.go b/contactcenterinsights/apiv1/contact_center_insights_client_example_go123_test.go index 118dbbee3cf0..a9972ee52506 100644 --- a/contactcenterinsights/apiv1/contact_center_insights_client_example_go123_test.go +++ b/contactcenterinsights/apiv1/contact_center_insights_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/contactcenterinsights/apiv1/contact_center_insights_client_example_test.go b/contactcenterinsights/apiv1/contact_center_insights_client_example_test.go index 304e82864eed..61969fa32d06 100644 --- a/contactcenterinsights/apiv1/contact_center_insights_client_example_test.go +++ b/contactcenterinsights/apiv1/contact_center_insights_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/contactcenterinsights/apiv1/doc.go b/contactcenterinsights/apiv1/doc.go index 23e310c93968..ea07204d50d8 100755 --- a/contactcenterinsights/apiv1/doc.go +++ b/contactcenterinsights/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/contactcenterinsights/apiv1/helpers.go b/contactcenterinsights/apiv1/helpers.go index cf0fedc3e3d6..b33bcfb21d32 100755 --- a/contactcenterinsights/apiv1/helpers.go +++ b/contactcenterinsights/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/container/apiv1/auxiliary.go b/container/apiv1/auxiliary.go index 1b9aa9bb5f39..372959801ab4 100755 --- a/container/apiv1/auxiliary.go +++ b/container/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/container/apiv1/auxiliary_go123.go b/container/apiv1/auxiliary_go123.go index 8f47a79e4cfd..75d783448b0f 100755 --- a/container/apiv1/auxiliary_go123.go +++ b/container/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/container/apiv1/cluster_manager_client.go b/container/apiv1/cluster_manager_client.go index e40a44328638..f408319e71c7 100755 --- a/container/apiv1/cluster_manager_client.go +++ b/container/apiv1/cluster_manager_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/container/apiv1/cluster_manager_client_example_go123_test.go b/container/apiv1/cluster_manager_client_example_go123_test.go index 6f20a39474e4..aa10b52039a4 100644 --- a/container/apiv1/cluster_manager_client_example_go123_test.go +++ b/container/apiv1/cluster_manager_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/container/apiv1/cluster_manager_client_example_test.go b/container/apiv1/cluster_manager_client_example_test.go index 2bf7afaea44f..d8a64f518e62 100644 --- a/container/apiv1/cluster_manager_client_example_test.go +++ b/container/apiv1/cluster_manager_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/container/apiv1/doc.go b/container/apiv1/doc.go index 6ce7be75edbf..198280f16939 100755 --- a/container/apiv1/doc.go +++ b/container/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/container/apiv1/helpers.go b/container/apiv1/helpers.go index 8292dc8e58bf..37a8f9d8ac53 100755 --- a/container/apiv1/helpers.go +++ b/container/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/containeranalysis/apiv1beta1/auxiliary.go b/containeranalysis/apiv1beta1/auxiliary.go index cd8316ddf3a3..be70f4ffd767 100755 --- a/containeranalysis/apiv1beta1/auxiliary.go +++ b/containeranalysis/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/containeranalysis/apiv1beta1/auxiliary_go123.go b/containeranalysis/apiv1beta1/auxiliary_go123.go index 066e27cc44a2..dce846c0fac2 100755 --- a/containeranalysis/apiv1beta1/auxiliary_go123.go +++ b/containeranalysis/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/containeranalysis/apiv1beta1/container_analysis_v1_beta1_client.go b/containeranalysis/apiv1beta1/container_analysis_v1_beta1_client.go index ae469f3a1fc1..d4ac4713c74f 100755 --- a/containeranalysis/apiv1beta1/container_analysis_v1_beta1_client.go +++ b/containeranalysis/apiv1beta1/container_analysis_v1_beta1_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/containeranalysis/apiv1beta1/container_analysis_v1_beta1_client_example_go123_test.go b/containeranalysis/apiv1beta1/container_analysis_v1_beta1_client_example_go123_test.go index 35f8b1b619f3..44d4a7c882fb 100644 --- a/containeranalysis/apiv1beta1/container_analysis_v1_beta1_client_example_go123_test.go +++ b/containeranalysis/apiv1beta1/container_analysis_v1_beta1_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/containeranalysis/apiv1beta1/container_analysis_v1_beta1_client_example_test.go b/containeranalysis/apiv1beta1/container_analysis_v1_beta1_client_example_test.go index ef5898eb01b5..1928acae5ad7 100644 --- a/containeranalysis/apiv1beta1/container_analysis_v1_beta1_client_example_test.go +++ b/containeranalysis/apiv1beta1/container_analysis_v1_beta1_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/containeranalysis/apiv1beta1/doc.go b/containeranalysis/apiv1beta1/doc.go index 76a58e4d2691..e83793ea79c9 100755 --- a/containeranalysis/apiv1beta1/doc.go +++ b/containeranalysis/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/containeranalysis/apiv1beta1/grafeas_v1_beta1_client.go b/containeranalysis/apiv1beta1/grafeas_v1_beta1_client.go index 42073c0d158f..ff22c2dd162f 100755 --- a/containeranalysis/apiv1beta1/grafeas_v1_beta1_client.go +++ b/containeranalysis/apiv1beta1/grafeas_v1_beta1_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/containeranalysis/apiv1beta1/grafeas_v1_beta1_client_example_go123_test.go b/containeranalysis/apiv1beta1/grafeas_v1_beta1_client_example_go123_test.go index a551fb3c377d..214a609eb620 100644 --- a/containeranalysis/apiv1beta1/grafeas_v1_beta1_client_example_go123_test.go +++ b/containeranalysis/apiv1beta1/grafeas_v1_beta1_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/containeranalysis/apiv1beta1/grafeas_v1_beta1_client_example_test.go b/containeranalysis/apiv1beta1/grafeas_v1_beta1_client_example_test.go index 65153f082088..6ff23004c592 100644 --- a/containeranalysis/apiv1beta1/grafeas_v1_beta1_client_example_test.go +++ b/containeranalysis/apiv1beta1/grafeas_v1_beta1_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/containeranalysis/apiv1beta1/helpers.go b/containeranalysis/apiv1beta1/helpers.go index 90d56de2a3f5..a983878d967e 100755 --- a/containeranalysis/apiv1beta1/helpers.go +++ b/containeranalysis/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/apiv1/auxiliary.go b/datacatalog/apiv1/auxiliary.go index 99c1121db3b5..db01f5623d59 100755 --- a/datacatalog/apiv1/auxiliary.go +++ b/datacatalog/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/apiv1/auxiliary_go123.go b/datacatalog/apiv1/auxiliary_go123.go index ff190727c99e..e0de0e7d8a62 100755 --- a/datacatalog/apiv1/auxiliary_go123.go +++ b/datacatalog/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/apiv1/data_catalog_client.go b/datacatalog/apiv1/data_catalog_client.go index 6e4b78ecb305..4ff850dcb51c 100755 --- a/datacatalog/apiv1/data_catalog_client.go +++ b/datacatalog/apiv1/data_catalog_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/apiv1/data_catalog_client_example_go123_test.go b/datacatalog/apiv1/data_catalog_client_example_go123_test.go index 534111957a7b..a928cee993f3 100644 --- a/datacatalog/apiv1/data_catalog_client_example_go123_test.go +++ b/datacatalog/apiv1/data_catalog_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/apiv1/data_catalog_client_example_test.go b/datacatalog/apiv1/data_catalog_client_example_test.go index 8f2d569334ed..bfd8a97b49be 100644 --- a/datacatalog/apiv1/data_catalog_client_example_test.go +++ b/datacatalog/apiv1/data_catalog_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/apiv1/doc.go b/datacatalog/apiv1/doc.go index 85e024d3616e..b8607d02aea0 100755 --- a/datacatalog/apiv1/doc.go +++ b/datacatalog/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/apiv1/helpers.go b/datacatalog/apiv1/helpers.go index 449380aa5a7d..bb959b752517 100755 --- a/datacatalog/apiv1/helpers.go +++ b/datacatalog/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/apiv1/policy_tag_manager_client.go b/datacatalog/apiv1/policy_tag_manager_client.go index e1003f8f7780..7a4af7904e6e 100755 --- a/datacatalog/apiv1/policy_tag_manager_client.go +++ b/datacatalog/apiv1/policy_tag_manager_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/apiv1/policy_tag_manager_client_example_go123_test.go b/datacatalog/apiv1/policy_tag_manager_client_example_go123_test.go index 34615624b7d4..c600039b1d9a 100644 --- a/datacatalog/apiv1/policy_tag_manager_client_example_go123_test.go +++ b/datacatalog/apiv1/policy_tag_manager_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/apiv1/policy_tag_manager_client_example_test.go b/datacatalog/apiv1/policy_tag_manager_client_example_test.go index 974d73fa32cc..c5e36918d755 100644 --- a/datacatalog/apiv1/policy_tag_manager_client_example_test.go +++ b/datacatalog/apiv1/policy_tag_manager_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/apiv1/policy_tag_manager_serialization_client.go b/datacatalog/apiv1/policy_tag_manager_serialization_client.go index 9b24c39399fb..6d473950551b 100755 --- a/datacatalog/apiv1/policy_tag_manager_serialization_client.go +++ b/datacatalog/apiv1/policy_tag_manager_serialization_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/apiv1/policy_tag_manager_serialization_client_example_go123_test.go b/datacatalog/apiv1/policy_tag_manager_serialization_client_example_go123_test.go index a08dc03dc763..fdacc5fdd4ae 100644 --- a/datacatalog/apiv1/policy_tag_manager_serialization_client_example_go123_test.go +++ b/datacatalog/apiv1/policy_tag_manager_serialization_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/apiv1/policy_tag_manager_serialization_client_example_test.go b/datacatalog/apiv1/policy_tag_manager_serialization_client_example_test.go index b5cf18306c5b..912a11af258b 100644 --- a/datacatalog/apiv1/policy_tag_manager_serialization_client_example_test.go +++ b/datacatalog/apiv1/policy_tag_manager_serialization_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/apiv1beta1/auxiliary.go b/datacatalog/apiv1beta1/auxiliary.go index bc66db2639b6..56ec1c8ff868 100755 --- a/datacatalog/apiv1beta1/auxiliary.go +++ b/datacatalog/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/apiv1beta1/auxiliary_go123.go b/datacatalog/apiv1beta1/auxiliary_go123.go index 58c2ead1c59c..b43b327709b5 100755 --- a/datacatalog/apiv1beta1/auxiliary_go123.go +++ b/datacatalog/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/apiv1beta1/data_catalog_client.go b/datacatalog/apiv1beta1/data_catalog_client.go index f0fb166d2a03..ad7fc0f5d364 100755 --- a/datacatalog/apiv1beta1/data_catalog_client.go +++ b/datacatalog/apiv1beta1/data_catalog_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/apiv1beta1/data_catalog_client_example_go123_test.go b/datacatalog/apiv1beta1/data_catalog_client_example_go123_test.go index 6279a3ebce8d..8045322a9af1 100644 --- a/datacatalog/apiv1beta1/data_catalog_client_example_go123_test.go +++ b/datacatalog/apiv1beta1/data_catalog_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/apiv1beta1/data_catalog_client_example_test.go b/datacatalog/apiv1beta1/data_catalog_client_example_test.go index 5059963e9547..360f8bcd35d7 100644 --- a/datacatalog/apiv1beta1/data_catalog_client_example_test.go +++ b/datacatalog/apiv1beta1/data_catalog_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/apiv1beta1/datacatalogpb/datacatalog.pb.go b/datacatalog/apiv1beta1/datacatalogpb/datacatalog.pb.go index 7bf9014ee512..28c41ab2ceb2 100755 --- a/datacatalog/apiv1beta1/datacatalogpb/datacatalog.pb.go +++ b/datacatalog/apiv1beta1/datacatalogpb/datacatalog.pb.go @@ -1679,12 +1679,14 @@ type CreateTagRequest struct { unknownFields protoimpl.UnknownFields // Required. The name of the resource to attach this tag to. Tags can be - // attached to Entries. Example: + // attached to // - // * projects/{project_id}/locations/{location}/entryGroups/{entry_group_id}/entries/{entry_id} + // Entries. Example: // - // Note that this Tag and its child resources may not actually be stored in - // the location in this name. + // * projects/{project_id}/locations/{location}/entryGroups/{entry_group_id}/entries/{entry_id} + // + // Note that this Tag and its child resources may not actually be stored in + // the location in this name. Parent string `protobuf:"bytes,1,opt,name=parent,proto3" json:"parent,omitempty"` // Required. The tag to create. Tag *Tag `protobuf:"bytes,2,opt,name=tag,proto3" json:"tag,omitempty"` @@ -3454,7 +3456,7 @@ var file_google_cloud_datacatalog_v1beta1_datacatalog_proto_rawDesc = []byte{ 0x6d, 0xd2, 0x41, 0x2e, 0x68, 0x74, 0x74, 0x70, 0x73, 0x3a, 0x2f, 0x2f, 0x77, 0x77, 0x77, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x61, 0x75, 0x74, 0x68, 0x2f, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2d, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, - 0x72, 0x6d, 0x42, 0xa3, 0x03, 0xea, 0x41, 0xc0, 0x01, 0x0a, 0x34, 0x64, 0x61, 0x74, 0x61, 0x63, + 0x72, 0x6d, 0x42, 0xa0, 0x03, 0xea, 0x41, 0xc0, 0x01, 0x0a, 0x34, 0x64, 0x61, 0x74, 0x61, 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x54, 0x61, 0x67, 0x54, 0x65, 0x6d, 0x70, 0x6c, 0x61, 0x74, 0x65, 0x46, 0x69, 0x65, 0x6c, 0x64, 0x45, 0x6e, 0x75, 0x6d, 0x56, 0x61, 0x6c, 0x75, 0x65, 0x12, @@ -3473,14 +3475,14 @@ var file_google_cloud_datacatalog_v1beta1_datacatalog_proto_rawDesc = []byte{ 0x63, 0x6f, 0x6d, 0x2f, 0x67, 0x6f, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x2f, 0x61, 0x70, 0x69, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x70, 0x62, 0x3b, 0x64, 0x61, 0x74, 0x61, - 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x70, 0x62, 0xf8, 0x01, 0x01, 0xaa, 0x02, 0x20, 0x47, - 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x44, 0x61, 0x74, 0x61, - 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x2e, 0x56, 0x31, 0x42, 0x65, 0x74, 0x61, 0x31, 0xca, - 0x02, 0x20, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x5c, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x5c, 0x44, - 0x61, 0x74, 0x61, 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x5c, 0x56, 0x31, 0x62, 0x65, 0x74, - 0x61, 0x31, 0xea, 0x02, 0x23, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x3a, 0x3a, 0x43, 0x6c, 0x6f, - 0x75, 0x64, 0x3a, 0x3a, 0x44, 0x61, 0x74, 0x61, 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x3a, - 0x3a, 0x56, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, + 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x70, 0x62, 0xaa, 0x02, 0x20, 0x47, 0x6f, 0x6f, 0x67, + 0x6c, 0x65, 0x2e, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x43, 0x61, 0x74, + 0x61, 0x6c, 0x6f, 0x67, 0x2e, 0x56, 0x31, 0x42, 0x65, 0x74, 0x61, 0x31, 0xca, 0x02, 0x20, 0x47, + 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x5c, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x5c, 0x44, 0x61, 0x74, 0x61, + 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x5c, 0x56, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0xea, + 0x02, 0x23, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x3a, 0x3a, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x3a, + 0x3a, 0x44, 0x61, 0x74, 0x61, 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x3a, 0x3a, 0x56, 0x31, + 0x62, 0x65, 0x74, 0x61, 0x31, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, } var ( diff --git a/datacatalog/apiv1beta1/datacatalogpb/policytagmanagerserialization.pb.go b/datacatalog/apiv1beta1/datacatalogpb/policytagmanagerserialization.pb.go index 885b7f33eaf0..67ca0c784792 100755 --- a/datacatalog/apiv1beta1/datacatalogpb/policytagmanagerserialization.pb.go +++ b/datacatalog/apiv1beta1/datacatalogpb/policytagmanagerserialization.pb.go @@ -642,7 +642,7 @@ var file_google_cloud_datacatalog_v1beta1_policytagmanagerserialization_proto_ra 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0xd2, 0x41, 0x2e, 0x68, 0x74, 0x74, 0x70, 0x73, 0x3a, 0x2f, 0x2f, 0x77, 0x77, 0x77, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x61, 0x75, 0x74, 0x68, 0x2f, - 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2d, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x42, 0x83, + 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2d, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x42, 0x80, 0x02, 0x0a, 0x24, 0x63, 0x6f, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x42, 0x22, 0x50, 0x6f, 0x6c, 0x69, 0x63, 0x79, 0x54, @@ -652,14 +652,14 @@ var file_google_cloud_datacatalog_v1beta1_policytagmanagerserialization_proto_ra 0x67, 0x6f, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x2f, 0x61, 0x70, 0x69, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x70, 0x62, 0x3b, 0x64, 0x61, 0x74, 0x61, 0x63, 0x61, 0x74, 0x61, - 0x6c, 0x6f, 0x67, 0x70, 0x62, 0xf8, 0x01, 0x01, 0xaa, 0x02, 0x20, 0x47, 0x6f, 0x6f, 0x67, 0x6c, - 0x65, 0x2e, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x43, 0x61, 0x74, 0x61, - 0x6c, 0x6f, 0x67, 0x2e, 0x56, 0x31, 0x42, 0x65, 0x74, 0x61, 0x31, 0xca, 0x02, 0x20, 0x47, 0x6f, - 0x6f, 0x67, 0x6c, 0x65, 0x5c, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x5c, 0x44, 0x61, 0x74, 0x61, 0x43, - 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x5c, 0x56, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0xea, 0x02, - 0x23, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x3a, 0x3a, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x3a, 0x3a, - 0x44, 0x61, 0x74, 0x61, 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x3a, 0x3a, 0x56, 0x31, 0x62, - 0x65, 0x74, 0x61, 0x31, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, + 0x6c, 0x6f, 0x67, 0x70, 0x62, 0xaa, 0x02, 0x20, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x43, + 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, + 0x2e, 0x56, 0x31, 0x42, 0x65, 0x74, 0x61, 0x31, 0xca, 0x02, 0x20, 0x47, 0x6f, 0x6f, 0x67, 0x6c, + 0x65, 0x5c, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x5c, 0x44, 0x61, 0x74, 0x61, 0x43, 0x61, 0x74, 0x61, + 0x6c, 0x6f, 0x67, 0x5c, 0x56, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0xea, 0x02, 0x23, 0x47, 0x6f, + 0x6f, 0x67, 0x6c, 0x65, 0x3a, 0x3a, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x3a, 0x3a, 0x44, 0x61, 0x74, + 0x61, 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x3a, 0x3a, 0x56, 0x31, 0x62, 0x65, 0x74, 0x61, + 0x31, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, } var ( diff --git a/datacatalog/apiv1beta1/datacatalogpb/schema.pb.go b/datacatalog/apiv1beta1/datacatalogpb/schema.pb.go index 4381b7940238..e6e976cb9019 100755 --- a/datacatalog/apiv1beta1/datacatalogpb/schema.pb.go +++ b/datacatalog/apiv1beta1/datacatalogpb/schema.pb.go @@ -200,22 +200,21 @@ var file_google_cloud_datacatalog_v1beta1_schema_proto_rawDesc = []byte{ 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x43, 0x6f, 0x6c, 0x75, 0x6d, 0x6e, 0x53, 0x63, 0x68, 0x65, 0x6d, 0x61, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0a, 0x73, 0x75, 0x62, - 0x63, 0x6f, 0x6c, 0x75, 0x6d, 0x6e, 0x73, 0x42, 0xdf, 0x01, 0x0a, 0x24, 0x63, 0x6f, 0x6d, 0x2e, + 0x63, 0x6f, 0x6c, 0x75, 0x6d, 0x6e, 0x73, 0x42, 0xdc, 0x01, 0x0a, 0x24, 0x63, 0x6f, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x50, 0x01, 0x5a, 0x46, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x67, 0x6f, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x2f, 0x61, 0x70, 0x69, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x70, 0x62, 0x3b, 0x64, 0x61, 0x74, - 0x61, 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x70, 0x62, 0xf8, 0x01, 0x01, 0xaa, 0x02, 0x20, - 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x44, 0x61, 0x74, - 0x61, 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x2e, 0x56, 0x31, 0x42, 0x65, 0x74, 0x61, 0x31, - 0xca, 0x02, 0x20, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x5c, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x5c, - 0x44, 0x61, 0x74, 0x61, 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x5c, 0x56, 0x31, 0x62, 0x65, - 0x74, 0x61, 0x31, 0xea, 0x02, 0x23, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x3a, 0x3a, 0x43, 0x6c, - 0x6f, 0x75, 0x64, 0x3a, 0x3a, 0x44, 0x61, 0x74, 0x61, 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, - 0x3a, 0x3a, 0x56, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, - 0x33, + 0x61, 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x70, 0x62, 0xaa, 0x02, 0x20, 0x47, 0x6f, 0x6f, + 0x67, 0x6c, 0x65, 0x2e, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x43, 0x61, + 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x2e, 0x56, 0x31, 0x42, 0x65, 0x74, 0x61, 0x31, 0xca, 0x02, 0x20, + 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x5c, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x5c, 0x44, 0x61, 0x74, + 0x61, 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x5c, 0x56, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, + 0xea, 0x02, 0x23, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x3a, 0x3a, 0x43, 0x6c, 0x6f, 0x75, 0x64, + 0x3a, 0x3a, 0x44, 0x61, 0x74, 0x61, 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x3a, 0x3a, 0x56, + 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, } var ( diff --git a/datacatalog/apiv1beta1/datacatalogpb/search.pb.go b/datacatalog/apiv1beta1/datacatalogpb/search.pb.go index db37a115cb9d..39acead97f55 100755 --- a/datacatalog/apiv1beta1/datacatalogpb/search.pb.go +++ b/datacatalog/apiv1beta1/datacatalogpb/search.pb.go @@ -229,21 +229,21 @@ var file_google_cloud_datacatalog_v1beta1_search_proto_rawDesc = []byte{ 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x09, 0x0a, 0x05, 0x45, 0x4e, 0x54, 0x52, 0x59, 0x10, 0x01, 0x12, 0x10, 0x0a, 0x0c, 0x54, 0x41, 0x47, 0x5f, 0x54, 0x45, 0x4d, 0x50, 0x4c, 0x41, 0x54, 0x45, 0x10, 0x02, 0x12, 0x0f, 0x0a, 0x0b, 0x45, 0x4e, 0x54, 0x52, 0x59, 0x5f, 0x47, 0x52, 0x4f, 0x55, - 0x50, 0x10, 0x03, 0x42, 0xdf, 0x01, 0x0a, 0x24, 0x63, 0x6f, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, + 0x50, 0x10, 0x03, 0x42, 0xdc, 0x01, 0x0a, 0x24, 0x63, 0x6f, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x50, 0x01, 0x5a, 0x46, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x67, 0x6f, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x2f, 0x61, 0x70, 0x69, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x70, 0x62, 0x3b, 0x64, 0x61, 0x74, 0x61, 0x63, 0x61, 0x74, - 0x61, 0x6c, 0x6f, 0x67, 0x70, 0x62, 0xf8, 0x01, 0x01, 0xaa, 0x02, 0x20, 0x47, 0x6f, 0x6f, 0x67, - 0x6c, 0x65, 0x2e, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x43, 0x61, 0x74, - 0x61, 0x6c, 0x6f, 0x67, 0x2e, 0x56, 0x31, 0x42, 0x65, 0x74, 0x61, 0x31, 0xca, 0x02, 0x20, 0x47, - 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x5c, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x5c, 0x44, 0x61, 0x74, 0x61, - 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x5c, 0x56, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0xea, - 0x02, 0x23, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x3a, 0x3a, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x3a, - 0x3a, 0x44, 0x61, 0x74, 0x61, 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x3a, 0x3a, 0x56, 0x31, - 0x62, 0x65, 0x74, 0x61, 0x31, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, + 0x61, 0x6c, 0x6f, 0x67, 0x70, 0x62, 0xaa, 0x02, 0x20, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, + 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, + 0x67, 0x2e, 0x56, 0x31, 0x42, 0x65, 0x74, 0x61, 0x31, 0xca, 0x02, 0x20, 0x47, 0x6f, 0x6f, 0x67, + 0x6c, 0x65, 0x5c, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x5c, 0x44, 0x61, 0x74, 0x61, 0x43, 0x61, 0x74, + 0x61, 0x6c, 0x6f, 0x67, 0x5c, 0x56, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0xea, 0x02, 0x23, 0x47, + 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x3a, 0x3a, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x3a, 0x3a, 0x44, 0x61, + 0x74, 0x61, 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x3a, 0x3a, 0x56, 0x31, 0x62, 0x65, 0x74, + 0x61, 0x31, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, } var ( diff --git a/datacatalog/apiv1beta1/datacatalogpb/table_spec.pb.go b/datacatalog/apiv1beta1/datacatalogpb/table_spec.pb.go index 495057b0dabf..71ca197c5a81 100755 --- a/datacatalog/apiv1beta1/datacatalogpb/table_spec.pb.go +++ b/datacatalog/apiv1beta1/datacatalogpb/table_spec.pb.go @@ -415,22 +415,21 @@ var file_google_cloud_datacatalog_v1beta1_table_spec_proto_rawDesc = []byte{ 0x45, 0x57, 0x10, 0x02, 0x12, 0x12, 0x0a, 0x0e, 0x42, 0x49, 0x47, 0x51, 0x55, 0x45, 0x52, 0x59, 0x5f, 0x54, 0x41, 0x42, 0x4c, 0x45, 0x10, 0x05, 0x12, 0x1e, 0x0a, 0x1a, 0x42, 0x49, 0x47, 0x51, 0x55, 0x45, 0x52, 0x59, 0x5f, 0x4d, 0x41, 0x54, 0x45, 0x52, 0x49, 0x41, 0x4c, 0x49, 0x5a, 0x45, - 0x44, 0x5f, 0x56, 0x49, 0x45, 0x57, 0x10, 0x07, 0x42, 0xdf, 0x01, 0x0a, 0x24, 0x63, 0x6f, 0x6d, + 0x44, 0x5f, 0x56, 0x49, 0x45, 0x57, 0x10, 0x07, 0x42, 0xdc, 0x01, 0x0a, 0x24, 0x63, 0x6f, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x50, 0x01, 0x5a, 0x46, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x67, 0x6f, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x2f, 0x61, 0x70, 0x69, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x70, 0x62, 0x3b, 0x64, 0x61, - 0x74, 0x61, 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x70, 0x62, 0xf8, 0x01, 0x01, 0xaa, 0x02, - 0x20, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x44, 0x61, - 0x74, 0x61, 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x2e, 0x56, 0x31, 0x42, 0x65, 0x74, 0x61, - 0x31, 0xca, 0x02, 0x20, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x5c, 0x43, 0x6c, 0x6f, 0x75, 0x64, - 0x5c, 0x44, 0x61, 0x74, 0x61, 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x5c, 0x56, 0x31, 0x62, - 0x65, 0x74, 0x61, 0x31, 0xea, 0x02, 0x23, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x3a, 0x3a, 0x43, - 0x6c, 0x6f, 0x75, 0x64, 0x3a, 0x3a, 0x44, 0x61, 0x74, 0x61, 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, - 0x67, 0x3a, 0x3a, 0x56, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, - 0x6f, 0x33, + 0x74, 0x61, 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x70, 0x62, 0xaa, 0x02, 0x20, 0x47, 0x6f, + 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x43, + 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x2e, 0x56, 0x31, 0x42, 0x65, 0x74, 0x61, 0x31, 0xca, 0x02, + 0x20, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x5c, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x5c, 0x44, 0x61, + 0x74, 0x61, 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x5c, 0x56, 0x31, 0x62, 0x65, 0x74, 0x61, + 0x31, 0xea, 0x02, 0x23, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x3a, 0x3a, 0x43, 0x6c, 0x6f, 0x75, + 0x64, 0x3a, 0x3a, 0x44, 0x61, 0x74, 0x61, 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x3a, 0x3a, + 0x56, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, } var ( diff --git a/datacatalog/apiv1beta1/datacatalogpb/tags.pb.go b/datacatalog/apiv1beta1/datacatalogpb/tags.pb.go index b70172cf11fe..f6294155b6a4 100755 --- a/datacatalog/apiv1beta1/datacatalogpb/tags.pb.go +++ b/datacatalog/apiv1beta1/datacatalogpb/tags.pb.go @@ -1013,21 +1013,21 @@ var file_google_cloud_datacatalog_v1beta1_tags_proto_rawDesc = []byte{ 0x0a, 0x0a, 0x06, 0x53, 0x54, 0x52, 0x49, 0x4e, 0x47, 0x10, 0x02, 0x12, 0x08, 0x0a, 0x04, 0x42, 0x4f, 0x4f, 0x4c, 0x10, 0x03, 0x12, 0x0d, 0x0a, 0x09, 0x54, 0x49, 0x4d, 0x45, 0x53, 0x54, 0x41, 0x4d, 0x50, 0x10, 0x04, 0x42, 0x0b, 0x0a, 0x09, 0x74, 0x79, 0x70, 0x65, 0x5f, 0x64, 0x65, 0x63, - 0x6c, 0x42, 0xdf, 0x01, 0x0a, 0x24, 0x63, 0x6f, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, + 0x6c, 0x42, 0xdc, 0x01, 0x0a, 0x24, 0x63, 0x6f, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x50, 0x01, 0x5a, 0x46, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x67, 0x6f, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x2f, 0x61, 0x70, 0x69, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x70, 0x62, 0x3b, 0x64, 0x61, 0x74, 0x61, 0x63, 0x61, 0x74, 0x61, 0x6c, - 0x6f, 0x67, 0x70, 0x62, 0xf8, 0x01, 0x01, 0xaa, 0x02, 0x20, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, - 0x2e, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x43, 0x61, 0x74, 0x61, 0x6c, - 0x6f, 0x67, 0x2e, 0x56, 0x31, 0x42, 0x65, 0x74, 0x61, 0x31, 0xca, 0x02, 0x20, 0x47, 0x6f, 0x6f, - 0x67, 0x6c, 0x65, 0x5c, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x5c, 0x44, 0x61, 0x74, 0x61, 0x43, 0x61, - 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x5c, 0x56, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0xea, 0x02, 0x23, - 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x3a, 0x3a, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x3a, 0x3a, 0x44, - 0x61, 0x74, 0x61, 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x3a, 0x3a, 0x56, 0x31, 0x62, 0x65, - 0x74, 0x61, 0x31, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, + 0x6f, 0x67, 0x70, 0x62, 0xaa, 0x02, 0x20, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x43, 0x6c, + 0x6f, 0x75, 0x64, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x2e, + 0x56, 0x31, 0x42, 0x65, 0x74, 0x61, 0x31, 0xca, 0x02, 0x20, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, + 0x5c, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x5c, 0x44, 0x61, 0x74, 0x61, 0x43, 0x61, 0x74, 0x61, 0x6c, + 0x6f, 0x67, 0x5c, 0x56, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0xea, 0x02, 0x23, 0x47, 0x6f, 0x6f, + 0x67, 0x6c, 0x65, 0x3a, 0x3a, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x3a, 0x3a, 0x44, 0x61, 0x74, 0x61, + 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x3a, 0x3a, 0x56, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, + 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, } var ( diff --git a/datacatalog/apiv1beta1/datacatalogpb/usage.pb.go b/datacatalog/apiv1beta1/datacatalogpb/usage.pb.go index 1627c0e08266..7fc7fa7d86e8 100755 --- a/datacatalog/apiv1beta1/datacatalogpb/usage.pb.go +++ b/datacatalog/apiv1beta1/datacatalogpb/usage.pb.go @@ -220,21 +220,21 @@ var file_google_cloud_datacatalog_v1beta1_usage_proto_rawDesc = []byte{ 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x55, 0x73, 0x61, 0x67, 0x65, 0x53, 0x74, 0x61, 0x74, 0x73, 0x52, 0x05, 0x76, 0x61, 0x6c, - 0x75, 0x65, 0x3a, 0x02, 0x38, 0x01, 0x42, 0xdf, 0x01, 0x0a, 0x24, 0x63, 0x6f, 0x6d, 0x2e, 0x67, + 0x75, 0x65, 0x3a, 0x02, 0x38, 0x01, 0x42, 0xdc, 0x01, 0x0a, 0x24, 0x63, 0x6f, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x64, 0x61, 0x74, 0x61, 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x2e, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x50, 0x01, 0x5a, 0x46, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x67, 0x6f, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x2f, 0x61, 0x70, 0x69, 0x76, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x64, 0x61, 0x74, 0x61, 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x70, 0x62, 0x3b, 0x64, 0x61, 0x74, 0x61, - 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x70, 0x62, 0xf8, 0x01, 0x01, 0xaa, 0x02, 0x20, 0x47, - 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x44, 0x61, 0x74, 0x61, - 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x2e, 0x56, 0x31, 0x42, 0x65, 0x74, 0x61, 0x31, 0xca, - 0x02, 0x20, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x5c, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x5c, 0x44, - 0x61, 0x74, 0x61, 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x5c, 0x56, 0x31, 0x62, 0x65, 0x74, - 0x61, 0x31, 0xea, 0x02, 0x23, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x3a, 0x3a, 0x43, 0x6c, 0x6f, - 0x75, 0x64, 0x3a, 0x3a, 0x44, 0x61, 0x74, 0x61, 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x3a, - 0x3a, 0x56, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, + 0x63, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x70, 0x62, 0xaa, 0x02, 0x20, 0x47, 0x6f, 0x6f, 0x67, + 0x6c, 0x65, 0x2e, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x43, 0x61, 0x74, + 0x61, 0x6c, 0x6f, 0x67, 0x2e, 0x56, 0x31, 0x42, 0x65, 0x74, 0x61, 0x31, 0xca, 0x02, 0x20, 0x47, + 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x5c, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x5c, 0x44, 0x61, 0x74, 0x61, + 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x5c, 0x56, 0x31, 0x62, 0x65, 0x74, 0x61, 0x31, 0xea, + 0x02, 0x23, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x3a, 0x3a, 0x43, 0x6c, 0x6f, 0x75, 0x64, 0x3a, + 0x3a, 0x44, 0x61, 0x74, 0x61, 0x43, 0x61, 0x74, 0x61, 0x6c, 0x6f, 0x67, 0x3a, 0x3a, 0x56, 0x31, + 0x62, 0x65, 0x74, 0x61, 0x31, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, } var ( diff --git a/datacatalog/apiv1beta1/doc.go b/datacatalog/apiv1beta1/doc.go index 9b86f883e5b9..9a9993a395d7 100755 --- a/datacatalog/apiv1beta1/doc.go +++ b/datacatalog/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/apiv1beta1/helpers.go b/datacatalog/apiv1beta1/helpers.go index 449380aa5a7d..bb959b752517 100755 --- a/datacatalog/apiv1beta1/helpers.go +++ b/datacatalog/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/apiv1beta1/policy_tag_manager_client.go b/datacatalog/apiv1beta1/policy_tag_manager_client.go index 7c5ca09c6986..708f73077ff6 100755 --- a/datacatalog/apiv1beta1/policy_tag_manager_client.go +++ b/datacatalog/apiv1beta1/policy_tag_manager_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/apiv1beta1/policy_tag_manager_client_example_go123_test.go b/datacatalog/apiv1beta1/policy_tag_manager_client_example_go123_test.go index 36d1c489ead9..363f480248f5 100644 --- a/datacatalog/apiv1beta1/policy_tag_manager_client_example_go123_test.go +++ b/datacatalog/apiv1beta1/policy_tag_manager_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/apiv1beta1/policy_tag_manager_client_example_test.go b/datacatalog/apiv1beta1/policy_tag_manager_client_example_test.go index cfe3214793f3..36661beb6679 100644 --- a/datacatalog/apiv1beta1/policy_tag_manager_client_example_test.go +++ b/datacatalog/apiv1beta1/policy_tag_manager_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/apiv1beta1/policy_tag_manager_serialization_client.go b/datacatalog/apiv1beta1/policy_tag_manager_serialization_client.go index cf3313880fbb..198ba267b06c 100755 --- a/datacatalog/apiv1beta1/policy_tag_manager_serialization_client.go +++ b/datacatalog/apiv1beta1/policy_tag_manager_serialization_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/apiv1beta1/policy_tag_manager_serialization_client_example_go123_test.go b/datacatalog/apiv1beta1/policy_tag_manager_serialization_client_example_go123_test.go index 0f0a5ae9b721..b59c28092949 100644 --- a/datacatalog/apiv1beta1/policy_tag_manager_serialization_client_example_go123_test.go +++ b/datacatalog/apiv1beta1/policy_tag_manager_serialization_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/apiv1beta1/policy_tag_manager_serialization_client_example_test.go b/datacatalog/apiv1beta1/policy_tag_manager_serialization_client_example_test.go index b5df9f1b664c..744d863af457 100644 --- a/datacatalog/apiv1beta1/policy_tag_manager_serialization_client_example_test.go +++ b/datacatalog/apiv1beta1/policy_tag_manager_serialization_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/lineage/apiv1/auxiliary.go b/datacatalog/lineage/apiv1/auxiliary.go index b11244e139ea..70f56ecb9b3a 100755 --- a/datacatalog/lineage/apiv1/auxiliary.go +++ b/datacatalog/lineage/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/lineage/apiv1/auxiliary_go123.go b/datacatalog/lineage/apiv1/auxiliary_go123.go index fbcf94c81402..c0af9f48e163 100755 --- a/datacatalog/lineage/apiv1/auxiliary_go123.go +++ b/datacatalog/lineage/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/lineage/apiv1/doc.go b/datacatalog/lineage/apiv1/doc.go index b2c8eb5cd3a8..2446547b8778 100755 --- a/datacatalog/lineage/apiv1/doc.go +++ b/datacatalog/lineage/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/lineage/apiv1/helpers.go b/datacatalog/lineage/apiv1/helpers.go index dbba3b598208..4e22b874f8a7 100755 --- a/datacatalog/lineage/apiv1/helpers.go +++ b/datacatalog/lineage/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/lineage/apiv1/lineage_client.go b/datacatalog/lineage/apiv1/lineage_client.go index 30ae49d6fd79..81c519334685 100755 --- a/datacatalog/lineage/apiv1/lineage_client.go +++ b/datacatalog/lineage/apiv1/lineage_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/lineage/apiv1/lineage_client_example_go123_test.go b/datacatalog/lineage/apiv1/lineage_client_example_go123_test.go index ba652e31037f..0c7c222297ee 100644 --- a/datacatalog/lineage/apiv1/lineage_client_example_go123_test.go +++ b/datacatalog/lineage/apiv1/lineage_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datacatalog/lineage/apiv1/lineage_client_example_test.go b/datacatalog/lineage/apiv1/lineage_client_example_test.go index c396f3dcda6b..70bb5c75f377 100644 --- a/datacatalog/lineage/apiv1/lineage_client_example_test.go +++ b/datacatalog/lineage/apiv1/lineage_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataflow/apiv1beta3/auxiliary.go b/dataflow/apiv1beta3/auxiliary.go index 4c1e1f99a5f9..c9f2b5410659 100755 --- a/dataflow/apiv1beta3/auxiliary.go +++ b/dataflow/apiv1beta3/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataflow/apiv1beta3/auxiliary_go123.go b/dataflow/apiv1beta3/auxiliary_go123.go index 9d8ac9f287e9..534d5794d478 100755 --- a/dataflow/apiv1beta3/auxiliary_go123.go +++ b/dataflow/apiv1beta3/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataflow/apiv1beta3/doc.go b/dataflow/apiv1beta3/doc.go index 09bfe7398e10..7b7412d4535d 100755 --- a/dataflow/apiv1beta3/doc.go +++ b/dataflow/apiv1beta3/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataflow/apiv1beta3/flex_templates_client.go b/dataflow/apiv1beta3/flex_templates_client.go index aa30d4e987fd..cce430852ec4 100755 --- a/dataflow/apiv1beta3/flex_templates_client.go +++ b/dataflow/apiv1beta3/flex_templates_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataflow/apiv1beta3/flex_templates_client_example_go123_test.go b/dataflow/apiv1beta3/flex_templates_client_example_go123_test.go index 129c65cfffc3..efd3c2ff6232 100644 --- a/dataflow/apiv1beta3/flex_templates_client_example_go123_test.go +++ b/dataflow/apiv1beta3/flex_templates_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataflow/apiv1beta3/flex_templates_client_example_test.go b/dataflow/apiv1beta3/flex_templates_client_example_test.go index 3188f10c4f84..e61bdd4e6a78 100644 --- a/dataflow/apiv1beta3/flex_templates_client_example_test.go +++ b/dataflow/apiv1beta3/flex_templates_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataflow/apiv1beta3/helpers.go b/dataflow/apiv1beta3/helpers.go index 88661c96bcda..52f52d0820a5 100755 --- a/dataflow/apiv1beta3/helpers.go +++ b/dataflow/apiv1beta3/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataflow/apiv1beta3/jobs_v1_beta3_client.go b/dataflow/apiv1beta3/jobs_v1_beta3_client.go index 2dc825fbcf54..513a38a71e37 100755 --- a/dataflow/apiv1beta3/jobs_v1_beta3_client.go +++ b/dataflow/apiv1beta3/jobs_v1_beta3_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataflow/apiv1beta3/jobs_v1_beta3_client_example_go123_test.go b/dataflow/apiv1beta3/jobs_v1_beta3_client_example_go123_test.go index 64d1b50eb0f3..284496cb51ef 100644 --- a/dataflow/apiv1beta3/jobs_v1_beta3_client_example_go123_test.go +++ b/dataflow/apiv1beta3/jobs_v1_beta3_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataflow/apiv1beta3/jobs_v1_beta3_client_example_test.go b/dataflow/apiv1beta3/jobs_v1_beta3_client_example_test.go index 63b187c130b9..9120b04cabb9 100644 --- a/dataflow/apiv1beta3/jobs_v1_beta3_client_example_test.go +++ b/dataflow/apiv1beta3/jobs_v1_beta3_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataflow/apiv1beta3/messages_v1_beta3_client.go b/dataflow/apiv1beta3/messages_v1_beta3_client.go index aacefd093e67..56c898e2b709 100755 --- a/dataflow/apiv1beta3/messages_v1_beta3_client.go +++ b/dataflow/apiv1beta3/messages_v1_beta3_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataflow/apiv1beta3/messages_v1_beta3_client_example_go123_test.go b/dataflow/apiv1beta3/messages_v1_beta3_client_example_go123_test.go index 661f1db81801..4b0864fff625 100644 --- a/dataflow/apiv1beta3/messages_v1_beta3_client_example_go123_test.go +++ b/dataflow/apiv1beta3/messages_v1_beta3_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataflow/apiv1beta3/messages_v1_beta3_client_example_test.go b/dataflow/apiv1beta3/messages_v1_beta3_client_example_test.go index 345c504c3a62..9e4675eb16d1 100644 --- a/dataflow/apiv1beta3/messages_v1_beta3_client_example_test.go +++ b/dataflow/apiv1beta3/messages_v1_beta3_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataflow/apiv1beta3/metrics_v1_beta3_client.go b/dataflow/apiv1beta3/metrics_v1_beta3_client.go index f65650e8d6e1..9c86ff4bb08b 100755 --- a/dataflow/apiv1beta3/metrics_v1_beta3_client.go +++ b/dataflow/apiv1beta3/metrics_v1_beta3_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataflow/apiv1beta3/metrics_v1_beta3_client_example_go123_test.go b/dataflow/apiv1beta3/metrics_v1_beta3_client_example_go123_test.go index dbe7fa95357e..570689c8a29b 100644 --- a/dataflow/apiv1beta3/metrics_v1_beta3_client_example_go123_test.go +++ b/dataflow/apiv1beta3/metrics_v1_beta3_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataflow/apiv1beta3/metrics_v1_beta3_client_example_test.go b/dataflow/apiv1beta3/metrics_v1_beta3_client_example_test.go index 72c777cfc8a2..e157cdadb50d 100644 --- a/dataflow/apiv1beta3/metrics_v1_beta3_client_example_test.go +++ b/dataflow/apiv1beta3/metrics_v1_beta3_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataflow/apiv1beta3/snapshots_v1_beta3_client.go b/dataflow/apiv1beta3/snapshots_v1_beta3_client.go index 5bb83f9ef8a5..1363d8a0e605 100755 --- a/dataflow/apiv1beta3/snapshots_v1_beta3_client.go +++ b/dataflow/apiv1beta3/snapshots_v1_beta3_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataflow/apiv1beta3/snapshots_v1_beta3_client_example_go123_test.go b/dataflow/apiv1beta3/snapshots_v1_beta3_client_example_go123_test.go index 129c65cfffc3..efd3c2ff6232 100644 --- a/dataflow/apiv1beta3/snapshots_v1_beta3_client_example_go123_test.go +++ b/dataflow/apiv1beta3/snapshots_v1_beta3_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataflow/apiv1beta3/snapshots_v1_beta3_client_example_test.go b/dataflow/apiv1beta3/snapshots_v1_beta3_client_example_test.go index a14516fe1c73..dcab4ff5bd28 100644 --- a/dataflow/apiv1beta3/snapshots_v1_beta3_client_example_test.go +++ b/dataflow/apiv1beta3/snapshots_v1_beta3_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataflow/apiv1beta3/templates_client.go b/dataflow/apiv1beta3/templates_client.go index 20152ac6604e..922ac010e933 100755 --- a/dataflow/apiv1beta3/templates_client.go +++ b/dataflow/apiv1beta3/templates_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataflow/apiv1beta3/templates_client_example_go123_test.go b/dataflow/apiv1beta3/templates_client_example_go123_test.go index 129c65cfffc3..efd3c2ff6232 100644 --- a/dataflow/apiv1beta3/templates_client_example_go123_test.go +++ b/dataflow/apiv1beta3/templates_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataflow/apiv1beta3/templates_client_example_test.go b/dataflow/apiv1beta3/templates_client_example_test.go index 94c784b3ecc1..2bb33d77aed7 100644 --- a/dataflow/apiv1beta3/templates_client_example_test.go +++ b/dataflow/apiv1beta3/templates_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataform/apiv1alpha2/auxiliary.go b/dataform/apiv1alpha2/auxiliary.go index 96527faed8ae..a213eb2074f7 100755 --- a/dataform/apiv1alpha2/auxiliary.go +++ b/dataform/apiv1alpha2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataform/apiv1alpha2/auxiliary_go123.go b/dataform/apiv1alpha2/auxiliary_go123.go index 9be5a5a57565..debc991622da 100755 --- a/dataform/apiv1alpha2/auxiliary_go123.go +++ b/dataform/apiv1alpha2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataform/apiv1alpha2/dataform_client.go b/dataform/apiv1alpha2/dataform_client.go index 524dbfa38119..b58b8339346c 100755 --- a/dataform/apiv1alpha2/dataform_client.go +++ b/dataform/apiv1alpha2/dataform_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataform/apiv1alpha2/dataform_client_example_go123_test.go b/dataform/apiv1alpha2/dataform_client_example_go123_test.go index 4351714e9135..d7a88899f69c 100644 --- a/dataform/apiv1alpha2/dataform_client_example_go123_test.go +++ b/dataform/apiv1alpha2/dataform_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataform/apiv1alpha2/dataform_client_example_test.go b/dataform/apiv1alpha2/dataform_client_example_test.go index 71d8563d9ba4..9d058a27c218 100644 --- a/dataform/apiv1alpha2/dataform_client_example_test.go +++ b/dataform/apiv1alpha2/dataform_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataform/apiv1alpha2/doc.go b/dataform/apiv1alpha2/doc.go index 5dba51af211e..e44672179fbb 100755 --- a/dataform/apiv1alpha2/doc.go +++ b/dataform/apiv1alpha2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataform/apiv1alpha2/helpers.go b/dataform/apiv1alpha2/helpers.go index 7a5a24336743..b14a2cc386e6 100755 --- a/dataform/apiv1alpha2/helpers.go +++ b/dataform/apiv1alpha2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataform/apiv1beta1/auxiliary.go b/dataform/apiv1beta1/auxiliary.go index 707f1e98c6d6..e299d88c61fa 100755 --- a/dataform/apiv1beta1/auxiliary.go +++ b/dataform/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataform/apiv1beta1/auxiliary_go123.go b/dataform/apiv1beta1/auxiliary_go123.go index 86c22a3a7d25..87a8ff8d5635 100755 --- a/dataform/apiv1beta1/auxiliary_go123.go +++ b/dataform/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataform/apiv1beta1/dataform_client.go b/dataform/apiv1beta1/dataform_client.go index f8a08bed68d6..fc3a3720e755 100755 --- a/dataform/apiv1beta1/dataform_client.go +++ b/dataform/apiv1beta1/dataform_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataform/apiv1beta1/dataform_client_example_go123_test.go b/dataform/apiv1beta1/dataform_client_example_go123_test.go index 847f5c0d8496..40ce8a018da6 100644 --- a/dataform/apiv1beta1/dataform_client_example_go123_test.go +++ b/dataform/apiv1beta1/dataform_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataform/apiv1beta1/dataform_client_example_test.go b/dataform/apiv1beta1/dataform_client_example_test.go index d0daaf0ecd7a..457ab2b5d3d4 100644 --- a/dataform/apiv1beta1/dataform_client_example_test.go +++ b/dataform/apiv1beta1/dataform_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataform/apiv1beta1/doc.go b/dataform/apiv1beta1/doc.go index c01bbaa0c5c4..b28180559ef5 100755 --- a/dataform/apiv1beta1/doc.go +++ b/dataform/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataform/apiv1beta1/helpers.go b/dataform/apiv1beta1/helpers.go index 7a5a24336743..b14a2cc386e6 100755 --- a/dataform/apiv1beta1/helpers.go +++ b/dataform/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datafusion/apiv1/auxiliary.go b/datafusion/apiv1/auxiliary.go index d97ddef8df20..35adcb91c29d 100755 --- a/datafusion/apiv1/auxiliary.go +++ b/datafusion/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datafusion/apiv1/auxiliary_go123.go b/datafusion/apiv1/auxiliary_go123.go index 0c71b4e688e2..cbe6a70de377 100755 --- a/datafusion/apiv1/auxiliary_go123.go +++ b/datafusion/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datafusion/apiv1/data_fusion_client.go b/datafusion/apiv1/data_fusion_client.go index a3a668fd2fa7..296920750c23 100755 --- a/datafusion/apiv1/data_fusion_client.go +++ b/datafusion/apiv1/data_fusion_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datafusion/apiv1/data_fusion_client_example_go123_test.go b/datafusion/apiv1/data_fusion_client_example_go123_test.go index 7ba449d1692c..3ee771d0f184 100644 --- a/datafusion/apiv1/data_fusion_client_example_go123_test.go +++ b/datafusion/apiv1/data_fusion_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datafusion/apiv1/data_fusion_client_example_test.go b/datafusion/apiv1/data_fusion_client_example_test.go index 186fd946a4d7..cd80b9fd992d 100644 --- a/datafusion/apiv1/data_fusion_client_example_test.go +++ b/datafusion/apiv1/data_fusion_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datafusion/apiv1/doc.go b/datafusion/apiv1/doc.go index 6f9add4e6325..846fe0af36ee 100755 --- a/datafusion/apiv1/doc.go +++ b/datafusion/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datafusion/apiv1/helpers.go b/datafusion/apiv1/helpers.go index 023111294992..bfc51995970c 100755 --- a/datafusion/apiv1/helpers.go +++ b/datafusion/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datalabeling/apiv1beta1/auxiliary.go b/datalabeling/apiv1beta1/auxiliary.go index 42a68bca2c6c..62cde6d856b6 100755 --- a/datalabeling/apiv1beta1/auxiliary.go +++ b/datalabeling/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datalabeling/apiv1beta1/auxiliary_go123.go b/datalabeling/apiv1beta1/auxiliary_go123.go index c738aa399f11..aaf9ff873922 100755 --- a/datalabeling/apiv1beta1/auxiliary_go123.go +++ b/datalabeling/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datalabeling/apiv1beta1/data_labeling_client.go b/datalabeling/apiv1beta1/data_labeling_client.go index a6d2ad8429b4..6f00b8e4b115 100755 --- a/datalabeling/apiv1beta1/data_labeling_client.go +++ b/datalabeling/apiv1beta1/data_labeling_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datalabeling/apiv1beta1/data_labeling_client_example_go123_test.go b/datalabeling/apiv1beta1/data_labeling_client_example_go123_test.go index c6df2c388426..6930d20bb9a5 100644 --- a/datalabeling/apiv1beta1/data_labeling_client_example_go123_test.go +++ b/datalabeling/apiv1beta1/data_labeling_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datalabeling/apiv1beta1/data_labeling_client_example_test.go b/datalabeling/apiv1beta1/data_labeling_client_example_test.go index f7b816487c2d..bbd3d1d73aec 100644 --- a/datalabeling/apiv1beta1/data_labeling_client_example_test.go +++ b/datalabeling/apiv1beta1/data_labeling_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datalabeling/apiv1beta1/doc.go b/datalabeling/apiv1beta1/doc.go index 847ae4e3374c..a7fd7d4c9c91 100755 --- a/datalabeling/apiv1beta1/doc.go +++ b/datalabeling/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datalabeling/apiv1beta1/helpers.go b/datalabeling/apiv1beta1/helpers.go index 278b050ea962..0825a1d2404f 100755 --- a/datalabeling/apiv1beta1/helpers.go +++ b/datalabeling/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataplex/apiv1/auxiliary.go b/dataplex/apiv1/auxiliary.go index 8b5cdfd65e44..96ea434a5d9d 100755 --- a/dataplex/apiv1/auxiliary.go +++ b/dataplex/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataplex/apiv1/auxiliary_go123.go b/dataplex/apiv1/auxiliary_go123.go index a4834e98c782..34db46a9c3f2 100755 --- a/dataplex/apiv1/auxiliary_go123.go +++ b/dataplex/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataplex/apiv1/catalog_client.go b/dataplex/apiv1/catalog_client.go index 1d0715d6b93b..cb10c816ab29 100755 --- a/dataplex/apiv1/catalog_client.go +++ b/dataplex/apiv1/catalog_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataplex/apiv1/catalog_client_example_go123_test.go b/dataplex/apiv1/catalog_client_example_go123_test.go index eed1522f63ce..a9db42edfa77 100644 --- a/dataplex/apiv1/catalog_client_example_go123_test.go +++ b/dataplex/apiv1/catalog_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataplex/apiv1/catalog_client_example_test.go b/dataplex/apiv1/catalog_client_example_test.go index c248292c4dbd..ba4bd321b7b2 100644 --- a/dataplex/apiv1/catalog_client_example_test.go +++ b/dataplex/apiv1/catalog_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataplex/apiv1/content_client.go b/dataplex/apiv1/content_client.go index 9b756c2ad3db..52d8773e79a3 100755 --- a/dataplex/apiv1/content_client.go +++ b/dataplex/apiv1/content_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataplex/apiv1/content_client_example_go123_test.go b/dataplex/apiv1/content_client_example_go123_test.go index 221c31e11538..576399b4bdc9 100644 --- a/dataplex/apiv1/content_client_example_go123_test.go +++ b/dataplex/apiv1/content_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataplex/apiv1/content_client_example_test.go b/dataplex/apiv1/content_client_example_test.go index aaf5671b87eb..d370305b285b 100644 --- a/dataplex/apiv1/content_client_example_test.go +++ b/dataplex/apiv1/content_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataplex/apiv1/data_scan_client.go b/dataplex/apiv1/data_scan_client.go index 2d13a192f3c7..4bc0ef9ac64f 100755 --- a/dataplex/apiv1/data_scan_client.go +++ b/dataplex/apiv1/data_scan_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataplex/apiv1/data_scan_client_example_go123_test.go b/dataplex/apiv1/data_scan_client_example_go123_test.go index 9c7202518949..ffb55c6cb623 100644 --- a/dataplex/apiv1/data_scan_client_example_go123_test.go +++ b/dataplex/apiv1/data_scan_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataplex/apiv1/data_scan_client_example_test.go b/dataplex/apiv1/data_scan_client_example_test.go index fbca97a0d384..391c37546b1b 100644 --- a/dataplex/apiv1/data_scan_client_example_test.go +++ b/dataplex/apiv1/data_scan_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataplex/apiv1/data_taxonomy_client.go b/dataplex/apiv1/data_taxonomy_client.go index 16d9dd71504e..bcd725e696fa 100755 --- a/dataplex/apiv1/data_taxonomy_client.go +++ b/dataplex/apiv1/data_taxonomy_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataplex/apiv1/data_taxonomy_client_example_go123_test.go b/dataplex/apiv1/data_taxonomy_client_example_go123_test.go index 419c4c554001..f656f950eb5a 100644 --- a/dataplex/apiv1/data_taxonomy_client_example_go123_test.go +++ b/dataplex/apiv1/data_taxonomy_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataplex/apiv1/data_taxonomy_client_example_test.go b/dataplex/apiv1/data_taxonomy_client_example_test.go index d27d58d8d871..16d2eb050968 100644 --- a/dataplex/apiv1/data_taxonomy_client_example_test.go +++ b/dataplex/apiv1/data_taxonomy_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataplex/apiv1/dataplex_client.go b/dataplex/apiv1/dataplex_client.go index 463de24ca32a..c99db4197bfe 100755 --- a/dataplex/apiv1/dataplex_client.go +++ b/dataplex/apiv1/dataplex_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataplex/apiv1/dataplex_client_example_go123_test.go b/dataplex/apiv1/dataplex_client_example_go123_test.go index 864bf98604cf..f66f5ccb9c71 100644 --- a/dataplex/apiv1/dataplex_client_example_go123_test.go +++ b/dataplex/apiv1/dataplex_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataplex/apiv1/dataplex_client_example_test.go b/dataplex/apiv1/dataplex_client_example_test.go index 9e665a0b144f..61bc5fe983de 100644 --- a/dataplex/apiv1/dataplex_client_example_test.go +++ b/dataplex/apiv1/dataplex_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataplex/apiv1/doc.go b/dataplex/apiv1/doc.go index 3572c31629bf..57be2d0591d8 100755 --- a/dataplex/apiv1/doc.go +++ b/dataplex/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataplex/apiv1/helpers.go b/dataplex/apiv1/helpers.go index edaccdfabd88..99554177ef2b 100755 --- a/dataplex/apiv1/helpers.go +++ b/dataplex/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataplex/apiv1/metadata_client.go b/dataplex/apiv1/metadata_client.go index b2cd3b53d62f..dca89cd79dfb 100755 --- a/dataplex/apiv1/metadata_client.go +++ b/dataplex/apiv1/metadata_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataplex/apiv1/metadata_client_example_go123_test.go b/dataplex/apiv1/metadata_client_example_go123_test.go index b2a54197c319..104b41747e4a 100644 --- a/dataplex/apiv1/metadata_client_example_go123_test.go +++ b/dataplex/apiv1/metadata_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataplex/apiv1/metadata_client_example_test.go b/dataplex/apiv1/metadata_client_example_test.go index e1810e44f16c..1baf49182dd2 100644 --- a/dataplex/apiv1/metadata_client_example_test.go +++ b/dataplex/apiv1/metadata_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataproc/apiv1/autoscaling_policy_client.go b/dataproc/apiv1/autoscaling_policy_client.go index 6ddce8c87a68..adea0acb0183 100755 --- a/dataproc/apiv1/autoscaling_policy_client.go +++ b/dataproc/apiv1/autoscaling_policy_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataproc/apiv1/autoscaling_policy_client_example_go123_test.go b/dataproc/apiv1/autoscaling_policy_client_example_go123_test.go index b5e784c59ecb..9affd3e531f0 100644 --- a/dataproc/apiv1/autoscaling_policy_client_example_go123_test.go +++ b/dataproc/apiv1/autoscaling_policy_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataproc/apiv1/autoscaling_policy_client_example_test.go b/dataproc/apiv1/autoscaling_policy_client_example_test.go index bf27cf7f5b73..3e9bee28dfa4 100644 --- a/dataproc/apiv1/autoscaling_policy_client_example_test.go +++ b/dataproc/apiv1/autoscaling_policy_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataproc/apiv1/auxiliary.go b/dataproc/apiv1/auxiliary.go index 0ed3fae8acd5..a76f230f8cbd 100755 --- a/dataproc/apiv1/auxiliary.go +++ b/dataproc/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataproc/apiv1/auxiliary_go123.go b/dataproc/apiv1/auxiliary_go123.go index 4092234d5d33..42bbc642792b 100755 --- a/dataproc/apiv1/auxiliary_go123.go +++ b/dataproc/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataproc/apiv1/batch_controller_client.go b/dataproc/apiv1/batch_controller_client.go index a8ff88e38e2b..2698a3e6e020 100755 --- a/dataproc/apiv1/batch_controller_client.go +++ b/dataproc/apiv1/batch_controller_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataproc/apiv1/batch_controller_client_example_go123_test.go b/dataproc/apiv1/batch_controller_client_example_go123_test.go index a035d562653e..a7f03e237cc8 100644 --- a/dataproc/apiv1/batch_controller_client_example_go123_test.go +++ b/dataproc/apiv1/batch_controller_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataproc/apiv1/batch_controller_client_example_test.go b/dataproc/apiv1/batch_controller_client_example_test.go index 0ae8d936c86b..a33058dc5f10 100644 --- a/dataproc/apiv1/batch_controller_client_example_test.go +++ b/dataproc/apiv1/batch_controller_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataproc/apiv1/cluster_controller_client.go b/dataproc/apiv1/cluster_controller_client.go index a6030592d405..b98a06fb4dc1 100755 --- a/dataproc/apiv1/cluster_controller_client.go +++ b/dataproc/apiv1/cluster_controller_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataproc/apiv1/cluster_controller_client_example_go123_test.go b/dataproc/apiv1/cluster_controller_client_example_go123_test.go index f68c1e0af367..edbf9664d670 100644 --- a/dataproc/apiv1/cluster_controller_client_example_go123_test.go +++ b/dataproc/apiv1/cluster_controller_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataproc/apiv1/cluster_controller_client_example_test.go b/dataproc/apiv1/cluster_controller_client_example_test.go index 210e8ef1440f..a5accdf25988 100644 --- a/dataproc/apiv1/cluster_controller_client_example_test.go +++ b/dataproc/apiv1/cluster_controller_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataproc/apiv1/doc.go b/dataproc/apiv1/doc.go index 6ee1502c9a0e..7c94453159a0 100755 --- a/dataproc/apiv1/doc.go +++ b/dataproc/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataproc/apiv1/helpers.go b/dataproc/apiv1/helpers.go index 3a89cbfdcbcd..d95bc5321ed3 100755 --- a/dataproc/apiv1/helpers.go +++ b/dataproc/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataproc/apiv1/job_controller_client.go b/dataproc/apiv1/job_controller_client.go index 2495783b30ca..13da571ff4d9 100755 --- a/dataproc/apiv1/job_controller_client.go +++ b/dataproc/apiv1/job_controller_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataproc/apiv1/job_controller_client_example_go123_test.go b/dataproc/apiv1/job_controller_client_example_go123_test.go index 5c19f73fd112..c5f4431cb509 100644 --- a/dataproc/apiv1/job_controller_client_example_go123_test.go +++ b/dataproc/apiv1/job_controller_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataproc/apiv1/job_controller_client_example_test.go b/dataproc/apiv1/job_controller_client_example_test.go index a41f288c288f..cf865a3867b6 100644 --- a/dataproc/apiv1/job_controller_client_example_test.go +++ b/dataproc/apiv1/job_controller_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataproc/apiv1/node_group_controller_client.go b/dataproc/apiv1/node_group_controller_client.go index e53d8efb436e..97ef7f7b2544 100755 --- a/dataproc/apiv1/node_group_controller_client.go +++ b/dataproc/apiv1/node_group_controller_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataproc/apiv1/node_group_controller_client_example_go123_test.go b/dataproc/apiv1/node_group_controller_client_example_go123_test.go index 8729fa255bf4..c54ed38ad76f 100644 --- a/dataproc/apiv1/node_group_controller_client_example_go123_test.go +++ b/dataproc/apiv1/node_group_controller_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataproc/apiv1/node_group_controller_client_example_test.go b/dataproc/apiv1/node_group_controller_client_example_test.go index 99740a8666c0..a3542f4f4ddc 100644 --- a/dataproc/apiv1/node_group_controller_client_example_test.go +++ b/dataproc/apiv1/node_group_controller_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataproc/apiv1/session_controller_client.go b/dataproc/apiv1/session_controller_client.go index e757c00222d3..62dae6277e6d 100755 --- a/dataproc/apiv1/session_controller_client.go +++ b/dataproc/apiv1/session_controller_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataproc/apiv1/session_controller_client_example_go123_test.go b/dataproc/apiv1/session_controller_client_example_go123_test.go index 51d31024da64..78abe762b531 100644 --- a/dataproc/apiv1/session_controller_client_example_go123_test.go +++ b/dataproc/apiv1/session_controller_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataproc/apiv1/session_controller_client_example_test.go b/dataproc/apiv1/session_controller_client_example_test.go index 011a5054b2db..d59e8775085f 100644 --- a/dataproc/apiv1/session_controller_client_example_test.go +++ b/dataproc/apiv1/session_controller_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataproc/apiv1/session_template_controller_client.go b/dataproc/apiv1/session_template_controller_client.go index 5aaf5236cf8b..ee320569d335 100755 --- a/dataproc/apiv1/session_template_controller_client.go +++ b/dataproc/apiv1/session_template_controller_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataproc/apiv1/session_template_controller_client_example_go123_test.go b/dataproc/apiv1/session_template_controller_client_example_go123_test.go index a67b5320633c..3a315d4f62d0 100644 --- a/dataproc/apiv1/session_template_controller_client_example_go123_test.go +++ b/dataproc/apiv1/session_template_controller_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataproc/apiv1/session_template_controller_client_example_test.go b/dataproc/apiv1/session_template_controller_client_example_test.go index e1084995932d..7dbbe4796ed4 100644 --- a/dataproc/apiv1/session_template_controller_client_example_test.go +++ b/dataproc/apiv1/session_template_controller_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataproc/apiv1/workflow_template_client.go b/dataproc/apiv1/workflow_template_client.go index 0e0bdd044c19..9c95c5205f0f 100755 --- a/dataproc/apiv1/workflow_template_client.go +++ b/dataproc/apiv1/workflow_template_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataproc/apiv1/workflow_template_client_example_go123_test.go b/dataproc/apiv1/workflow_template_client_example_go123_test.go index 8feb4293cb54..c23c91a9299b 100644 --- a/dataproc/apiv1/workflow_template_client_example_go123_test.go +++ b/dataproc/apiv1/workflow_template_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataproc/apiv1/workflow_template_client_example_test.go b/dataproc/apiv1/workflow_template_client_example_test.go index 9a6a6ba724d6..6b28107229a1 100644 --- a/dataproc/apiv1/workflow_template_client_example_test.go +++ b/dataproc/apiv1/workflow_template_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataqna/apiv1alpha/auto_suggestion_client.go b/dataqna/apiv1alpha/auto_suggestion_client.go index 0a17fffce4c8..a5f309e6f0fe 100755 --- a/dataqna/apiv1alpha/auto_suggestion_client.go +++ b/dataqna/apiv1alpha/auto_suggestion_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataqna/apiv1alpha/auto_suggestion_client_example_go123_test.go b/dataqna/apiv1alpha/auto_suggestion_client_example_go123_test.go index 78d1c4add7ce..601c9cb56990 100644 --- a/dataqna/apiv1alpha/auto_suggestion_client_example_go123_test.go +++ b/dataqna/apiv1alpha/auto_suggestion_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataqna/apiv1alpha/auto_suggestion_client_example_test.go b/dataqna/apiv1alpha/auto_suggestion_client_example_test.go index 29c88645385d..dadc6d2adf80 100644 --- a/dataqna/apiv1alpha/auto_suggestion_client_example_test.go +++ b/dataqna/apiv1alpha/auto_suggestion_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataqna/apiv1alpha/auxiliary.go b/dataqna/apiv1alpha/auxiliary.go index a7942539de2a..adeddd145366 100755 --- a/dataqna/apiv1alpha/auxiliary.go +++ b/dataqna/apiv1alpha/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataqna/apiv1alpha/auxiliary_go123.go b/dataqna/apiv1alpha/auxiliary_go123.go index a5c785b8d096..1a7e9b10a683 100755 --- a/dataqna/apiv1alpha/auxiliary_go123.go +++ b/dataqna/apiv1alpha/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataqna/apiv1alpha/doc.go b/dataqna/apiv1alpha/doc.go index be2b15f61e17..f00aff6a2619 100755 --- a/dataqna/apiv1alpha/doc.go +++ b/dataqna/apiv1alpha/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataqna/apiv1alpha/helpers.go b/dataqna/apiv1alpha/helpers.go index c35f2a6ff320..842c618ca964 100755 --- a/dataqna/apiv1alpha/helpers.go +++ b/dataqna/apiv1alpha/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataqna/apiv1alpha/question_client.go b/dataqna/apiv1alpha/question_client.go index 7ac182b43693..4df325001378 100755 --- a/dataqna/apiv1alpha/question_client.go +++ b/dataqna/apiv1alpha/question_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataqna/apiv1alpha/question_client_example_go123_test.go b/dataqna/apiv1alpha/question_client_example_go123_test.go index 78d1c4add7ce..601c9cb56990 100644 --- a/dataqna/apiv1alpha/question_client_example_go123_test.go +++ b/dataqna/apiv1alpha/question_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dataqna/apiv1alpha/question_client_example_test.go b/dataqna/apiv1alpha/question_client_example_test.go index b2ba56aa5eb5..d8cc3e68c0db 100644 --- a/dataqna/apiv1alpha/question_client_example_test.go +++ b/dataqna/apiv1alpha/question_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datastore/admin/apiv1/auxiliary.go b/datastore/admin/apiv1/auxiliary.go index 44d43bc31ddc..80afa91f0590 100755 --- a/datastore/admin/apiv1/auxiliary.go +++ b/datastore/admin/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datastore/admin/apiv1/auxiliary_go123.go b/datastore/admin/apiv1/auxiliary_go123.go index eae01ce860b0..d587d8d5ca48 100755 --- a/datastore/admin/apiv1/auxiliary_go123.go +++ b/datastore/admin/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datastore/admin/apiv1/datastore_admin_client.go b/datastore/admin/apiv1/datastore_admin_client.go index 0f3e73f7e53f..dcba1312aa42 100755 --- a/datastore/admin/apiv1/datastore_admin_client.go +++ b/datastore/admin/apiv1/datastore_admin_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datastore/admin/apiv1/datastore_admin_client_example_go123_test.go b/datastore/admin/apiv1/datastore_admin_client_example_go123_test.go index 2f35ff764dde..338d0498e3ed 100644 --- a/datastore/admin/apiv1/datastore_admin_client_example_go123_test.go +++ b/datastore/admin/apiv1/datastore_admin_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datastore/admin/apiv1/datastore_admin_client_example_test.go b/datastore/admin/apiv1/datastore_admin_client_example_test.go index 9083f03babba..473351909427 100644 --- a/datastore/admin/apiv1/datastore_admin_client_example_test.go +++ b/datastore/admin/apiv1/datastore_admin_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datastore/admin/apiv1/doc.go b/datastore/admin/apiv1/doc.go index b6b5c926faf9..4ea42dad10ca 100755 --- a/datastore/admin/apiv1/doc.go +++ b/datastore/admin/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datastore/admin/apiv1/helpers.go b/datastore/admin/apiv1/helpers.go index 4e9ca2b41c5e..8919b824ea65 100755 --- a/datastore/admin/apiv1/helpers.go +++ b/datastore/admin/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datastream/apiv1/auxiliary.go b/datastream/apiv1/auxiliary.go index 7bc17663db3a..626d6f63e824 100755 --- a/datastream/apiv1/auxiliary.go +++ b/datastream/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datastream/apiv1/auxiliary_go123.go b/datastream/apiv1/auxiliary_go123.go index ad431f4aeb79..439e5aeda039 100755 --- a/datastream/apiv1/auxiliary_go123.go +++ b/datastream/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datastream/apiv1/datastream_client.go b/datastream/apiv1/datastream_client.go index 0ac3884ea463..ca92848501a9 100755 --- a/datastream/apiv1/datastream_client.go +++ b/datastream/apiv1/datastream_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datastream/apiv1/datastream_client_example_go123_test.go b/datastream/apiv1/datastream_client_example_go123_test.go index bba50dcda543..f0f5f8c04c7e 100644 --- a/datastream/apiv1/datastream_client_example_go123_test.go +++ b/datastream/apiv1/datastream_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datastream/apiv1/datastream_client_example_test.go b/datastream/apiv1/datastream_client_example_test.go index 4c0913cd5242..72ec3c2192ad 100644 --- a/datastream/apiv1/datastream_client_example_test.go +++ b/datastream/apiv1/datastream_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datastream/apiv1/doc.go b/datastream/apiv1/doc.go index beb4fe2e5b73..3dea25672abb 100755 --- a/datastream/apiv1/doc.go +++ b/datastream/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datastream/apiv1/helpers.go b/datastream/apiv1/helpers.go index f7235edafe8e..2617bea1784b 100755 --- a/datastream/apiv1/helpers.go +++ b/datastream/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datastream/apiv1alpha1/auxiliary.go b/datastream/apiv1alpha1/auxiliary.go index 622d274c82ab..2b138f4da57c 100755 --- a/datastream/apiv1alpha1/auxiliary.go +++ b/datastream/apiv1alpha1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datastream/apiv1alpha1/auxiliary_go123.go b/datastream/apiv1alpha1/auxiliary_go123.go index 384c5550360d..711397e5ef8b 100755 --- a/datastream/apiv1alpha1/auxiliary_go123.go +++ b/datastream/apiv1alpha1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datastream/apiv1alpha1/datastream_client.go b/datastream/apiv1alpha1/datastream_client.go index ec43462d64ad..6e86fc46350a 100755 --- a/datastream/apiv1alpha1/datastream_client.go +++ b/datastream/apiv1alpha1/datastream_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datastream/apiv1alpha1/datastream_client_example_go123_test.go b/datastream/apiv1alpha1/datastream_client_example_go123_test.go index c83d9815c4f0..8ac731932ad9 100644 --- a/datastream/apiv1alpha1/datastream_client_example_go123_test.go +++ b/datastream/apiv1alpha1/datastream_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datastream/apiv1alpha1/datastream_client_example_test.go b/datastream/apiv1alpha1/datastream_client_example_test.go index 977212b5dfb8..947bbd535a9a 100644 --- a/datastream/apiv1alpha1/datastream_client_example_test.go +++ b/datastream/apiv1alpha1/datastream_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datastream/apiv1alpha1/doc.go b/datastream/apiv1alpha1/doc.go index 65cadeca43d6..9b2699e9e8dd 100755 --- a/datastream/apiv1alpha1/doc.go +++ b/datastream/apiv1alpha1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/datastream/apiv1alpha1/helpers.go b/datastream/apiv1alpha1/helpers.go index f7235edafe8e..2617bea1784b 100755 --- a/datastream/apiv1alpha1/helpers.go +++ b/datastream/apiv1alpha1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/deploy/apiv1/auxiliary.go b/deploy/apiv1/auxiliary.go index ae401a26f8d9..b943675d61d9 100755 --- a/deploy/apiv1/auxiliary.go +++ b/deploy/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/deploy/apiv1/auxiliary_go123.go b/deploy/apiv1/auxiliary_go123.go index 78fc3dbc9c24..06bf5284eda9 100755 --- a/deploy/apiv1/auxiliary_go123.go +++ b/deploy/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/deploy/apiv1/cloud_deploy_client.go b/deploy/apiv1/cloud_deploy_client.go index b3d1418dc2f5..aa6ecf8d6bef 100755 --- a/deploy/apiv1/cloud_deploy_client.go +++ b/deploy/apiv1/cloud_deploy_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/deploy/apiv1/cloud_deploy_client_example_go123_test.go b/deploy/apiv1/cloud_deploy_client_example_go123_test.go index 4506ab5af551..a6082204ed39 100644 --- a/deploy/apiv1/cloud_deploy_client_example_go123_test.go +++ b/deploy/apiv1/cloud_deploy_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/deploy/apiv1/cloud_deploy_client_example_test.go b/deploy/apiv1/cloud_deploy_client_example_test.go index a0ff056b6684..b099b56d7027 100644 --- a/deploy/apiv1/cloud_deploy_client_example_test.go +++ b/deploy/apiv1/cloud_deploy_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/deploy/apiv1/doc.go b/deploy/apiv1/doc.go index a7c7f4a42f5e..f635956f7e36 100755 --- a/deploy/apiv1/doc.go +++ b/deploy/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/deploy/apiv1/helpers.go b/deploy/apiv1/helpers.go index fdde2ade433f..5cd81504a695 100755 --- a/deploy/apiv1/helpers.go +++ b/deploy/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/developerconnect/apiv1/auxiliary.go b/developerconnect/apiv1/auxiliary.go index 2a72161540c2..021f6cf71e2c 100755 --- a/developerconnect/apiv1/auxiliary.go +++ b/developerconnect/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/developerconnect/apiv1/auxiliary_go123.go b/developerconnect/apiv1/auxiliary_go123.go index 52accf2acf9d..af78accb2778 100755 --- a/developerconnect/apiv1/auxiliary_go123.go +++ b/developerconnect/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/developerconnect/apiv1/developer_connect_client.go b/developerconnect/apiv1/developer_connect_client.go index 3397478372bb..237fe6872c9d 100755 --- a/developerconnect/apiv1/developer_connect_client.go +++ b/developerconnect/apiv1/developer_connect_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/developerconnect/apiv1/developer_connect_client_example_go123_test.go b/developerconnect/apiv1/developer_connect_client_example_go123_test.go index 175ba4de8fef..797f1b0320bc 100644 --- a/developerconnect/apiv1/developer_connect_client_example_go123_test.go +++ b/developerconnect/apiv1/developer_connect_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/developerconnect/apiv1/developer_connect_client_example_test.go b/developerconnect/apiv1/developer_connect_client_example_test.go index 811cdc3f2a92..324de37148ed 100644 --- a/developerconnect/apiv1/developer_connect_client_example_test.go +++ b/developerconnect/apiv1/developer_connect_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/developerconnect/apiv1/doc.go b/developerconnect/apiv1/doc.go index 0867d3097ee1..9eb49bfb5c73 100755 --- a/developerconnect/apiv1/doc.go +++ b/developerconnect/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/developerconnect/apiv1/helpers.go b/developerconnect/apiv1/helpers.go index bcd8c57c1e75..0bf6a0dd6003 100755 --- a/developerconnect/apiv1/helpers.go +++ b/developerconnect/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/agents_client.go b/dialogflow/apiv2/agents_client.go index 7068826dab08..52a3a748c807 100755 --- a/dialogflow/apiv2/agents_client.go +++ b/dialogflow/apiv2/agents_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/agents_client_example_go123_test.go b/dialogflow/apiv2/agents_client_example_go123_test.go index 878eabea7030..3833da3f0cf3 100644 --- a/dialogflow/apiv2/agents_client_example_go123_test.go +++ b/dialogflow/apiv2/agents_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/agents_client_example_test.go b/dialogflow/apiv2/agents_client_example_test.go index 8dff42600417..fe02a6d01129 100644 --- a/dialogflow/apiv2/agents_client_example_test.go +++ b/dialogflow/apiv2/agents_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/answer_records_client.go b/dialogflow/apiv2/answer_records_client.go index 66edf7b2027a..a354eb2a7ba4 100755 --- a/dialogflow/apiv2/answer_records_client.go +++ b/dialogflow/apiv2/answer_records_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/answer_records_client_example_go123_test.go b/dialogflow/apiv2/answer_records_client_example_go123_test.go index 5cb7c7678462..e356d893dea2 100644 --- a/dialogflow/apiv2/answer_records_client_example_go123_test.go +++ b/dialogflow/apiv2/answer_records_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/answer_records_client_example_test.go b/dialogflow/apiv2/answer_records_client_example_test.go index 7a547262df28..3ebe046f53c9 100644 --- a/dialogflow/apiv2/answer_records_client_example_test.go +++ b/dialogflow/apiv2/answer_records_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/auxiliary.go b/dialogflow/apiv2/auxiliary.go index a21ca7c76bfb..304110d66730 100755 --- a/dialogflow/apiv2/auxiliary.go +++ b/dialogflow/apiv2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/auxiliary_go123.go b/dialogflow/apiv2/auxiliary_go123.go index 7fe78ed7ca0a..235b56f349d3 100755 --- a/dialogflow/apiv2/auxiliary_go123.go +++ b/dialogflow/apiv2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/contexts_client.go b/dialogflow/apiv2/contexts_client.go index c73ec1cde3f3..4b449b1b2459 100755 --- a/dialogflow/apiv2/contexts_client.go +++ b/dialogflow/apiv2/contexts_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/contexts_client_example_go123_test.go b/dialogflow/apiv2/contexts_client_example_go123_test.go index 508d83a88d11..ef828814d4b8 100644 --- a/dialogflow/apiv2/contexts_client_example_go123_test.go +++ b/dialogflow/apiv2/contexts_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/contexts_client_example_test.go b/dialogflow/apiv2/contexts_client_example_test.go index acd5c28afecf..099f5ebea721 100644 --- a/dialogflow/apiv2/contexts_client_example_test.go +++ b/dialogflow/apiv2/contexts_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/conversation_datasets_client.go b/dialogflow/apiv2/conversation_datasets_client.go index ef27bdbff482..cc743aaaf659 100755 --- a/dialogflow/apiv2/conversation_datasets_client.go +++ b/dialogflow/apiv2/conversation_datasets_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/conversation_datasets_client_example_go123_test.go b/dialogflow/apiv2/conversation_datasets_client_example_go123_test.go index b3e4b909c041..f1e099da8f05 100644 --- a/dialogflow/apiv2/conversation_datasets_client_example_go123_test.go +++ b/dialogflow/apiv2/conversation_datasets_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/conversation_datasets_client_example_test.go b/dialogflow/apiv2/conversation_datasets_client_example_test.go index 307b68917855..d29388fcaaac 100644 --- a/dialogflow/apiv2/conversation_datasets_client_example_test.go +++ b/dialogflow/apiv2/conversation_datasets_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/conversation_models_client.go b/dialogflow/apiv2/conversation_models_client.go index c3d5930c6ac2..0aed777c35b1 100755 --- a/dialogflow/apiv2/conversation_models_client.go +++ b/dialogflow/apiv2/conversation_models_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/conversation_models_client_example_go123_test.go b/dialogflow/apiv2/conversation_models_client_example_go123_test.go index cc0a05ddc18b..6ba896a10770 100644 --- a/dialogflow/apiv2/conversation_models_client_example_go123_test.go +++ b/dialogflow/apiv2/conversation_models_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/conversation_models_client_example_test.go b/dialogflow/apiv2/conversation_models_client_example_test.go index 7981fa7aa341..9affd897ef1c 100644 --- a/dialogflow/apiv2/conversation_models_client_example_test.go +++ b/dialogflow/apiv2/conversation_models_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/conversation_profiles_client.go b/dialogflow/apiv2/conversation_profiles_client.go index b67b15a1beff..6122fee05b9e 100755 --- a/dialogflow/apiv2/conversation_profiles_client.go +++ b/dialogflow/apiv2/conversation_profiles_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/conversation_profiles_client_example_go123_test.go b/dialogflow/apiv2/conversation_profiles_client_example_go123_test.go index 2be6f73335f7..5d6656e46aec 100644 --- a/dialogflow/apiv2/conversation_profiles_client_example_go123_test.go +++ b/dialogflow/apiv2/conversation_profiles_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/conversation_profiles_client_example_test.go b/dialogflow/apiv2/conversation_profiles_client_example_test.go index 40f55d565640..150e9c0ca952 100644 --- a/dialogflow/apiv2/conversation_profiles_client_example_test.go +++ b/dialogflow/apiv2/conversation_profiles_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/conversations_client.go b/dialogflow/apiv2/conversations_client.go index c7b28a3d03a6..66051554ad4a 100755 --- a/dialogflow/apiv2/conversations_client.go +++ b/dialogflow/apiv2/conversations_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/conversations_client_example_go123_test.go b/dialogflow/apiv2/conversations_client_example_go123_test.go index 5e6182bd7645..c7fe494f40c0 100644 --- a/dialogflow/apiv2/conversations_client_example_go123_test.go +++ b/dialogflow/apiv2/conversations_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/conversations_client_example_test.go b/dialogflow/apiv2/conversations_client_example_test.go index d187e8ac08c6..4b6416328103 100644 --- a/dialogflow/apiv2/conversations_client_example_test.go +++ b/dialogflow/apiv2/conversations_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/doc.go b/dialogflow/apiv2/doc.go index f376b0d5bf74..9addcdc343b1 100755 --- a/dialogflow/apiv2/doc.go +++ b/dialogflow/apiv2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/documents_client.go b/dialogflow/apiv2/documents_client.go index 4e97e1df4fd6..aa9d96c37db1 100755 --- a/dialogflow/apiv2/documents_client.go +++ b/dialogflow/apiv2/documents_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/documents_client_example_go123_test.go b/dialogflow/apiv2/documents_client_example_go123_test.go index 854ce5491218..bde4ed902b30 100644 --- a/dialogflow/apiv2/documents_client_example_go123_test.go +++ b/dialogflow/apiv2/documents_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/documents_client_example_test.go b/dialogflow/apiv2/documents_client_example_test.go index 3f82f2971a1f..51d7898e9022 100644 --- a/dialogflow/apiv2/documents_client_example_test.go +++ b/dialogflow/apiv2/documents_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/encryption_spec_client.go b/dialogflow/apiv2/encryption_spec_client.go index f51ef9127895..dec22cc6d640 100755 --- a/dialogflow/apiv2/encryption_spec_client.go +++ b/dialogflow/apiv2/encryption_spec_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/encryption_spec_client_example_go123_test.go b/dialogflow/apiv2/encryption_spec_client_example_go123_test.go index 2be9e190f59b..7ef59768cd03 100644 --- a/dialogflow/apiv2/encryption_spec_client_example_go123_test.go +++ b/dialogflow/apiv2/encryption_spec_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/encryption_spec_client_example_test.go b/dialogflow/apiv2/encryption_spec_client_example_test.go index 31f456005054..d9d34858a29f 100644 --- a/dialogflow/apiv2/encryption_spec_client_example_test.go +++ b/dialogflow/apiv2/encryption_spec_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/entity_types_client.go b/dialogflow/apiv2/entity_types_client.go index 4556160767f0..ad757abe1a16 100755 --- a/dialogflow/apiv2/entity_types_client.go +++ b/dialogflow/apiv2/entity_types_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/entity_types_client_example_go123_test.go b/dialogflow/apiv2/entity_types_client_example_go123_test.go index d869069f1f4d..567909ad7998 100644 --- a/dialogflow/apiv2/entity_types_client_example_go123_test.go +++ b/dialogflow/apiv2/entity_types_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/entity_types_client_example_test.go b/dialogflow/apiv2/entity_types_client_example_test.go index 9125ac92f208..e3567c9ed59e 100644 --- a/dialogflow/apiv2/entity_types_client_example_test.go +++ b/dialogflow/apiv2/entity_types_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/environments_client.go b/dialogflow/apiv2/environments_client.go index c8bf32237874..0f4ad57b85de 100755 --- a/dialogflow/apiv2/environments_client.go +++ b/dialogflow/apiv2/environments_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/environments_client_example_go123_test.go b/dialogflow/apiv2/environments_client_example_go123_test.go index 3e44d274df8d..3afff25e1d26 100644 --- a/dialogflow/apiv2/environments_client_example_go123_test.go +++ b/dialogflow/apiv2/environments_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/environments_client_example_test.go b/dialogflow/apiv2/environments_client_example_test.go index b53a1c9096df..6abb7de5fa56 100644 --- a/dialogflow/apiv2/environments_client_example_test.go +++ b/dialogflow/apiv2/environments_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/fulfillments_client.go b/dialogflow/apiv2/fulfillments_client.go index bde776aca95a..8fe62fa0e09d 100755 --- a/dialogflow/apiv2/fulfillments_client.go +++ b/dialogflow/apiv2/fulfillments_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/fulfillments_client_example_go123_test.go b/dialogflow/apiv2/fulfillments_client_example_go123_test.go index 770e8ca70c3a..4860f89ee9ea 100644 --- a/dialogflow/apiv2/fulfillments_client_example_go123_test.go +++ b/dialogflow/apiv2/fulfillments_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/fulfillments_client_example_test.go b/dialogflow/apiv2/fulfillments_client_example_test.go index 528dad4ece9e..cb55147218f4 100644 --- a/dialogflow/apiv2/fulfillments_client_example_test.go +++ b/dialogflow/apiv2/fulfillments_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/generators_client.go b/dialogflow/apiv2/generators_client.go index 57ab2ebc768f..e64cb81a1163 100755 --- a/dialogflow/apiv2/generators_client.go +++ b/dialogflow/apiv2/generators_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/generators_client_example_go123_test.go b/dialogflow/apiv2/generators_client_example_go123_test.go index 71267d837919..d0dfed41d1d5 100644 --- a/dialogflow/apiv2/generators_client_example_go123_test.go +++ b/dialogflow/apiv2/generators_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/generators_client_example_test.go b/dialogflow/apiv2/generators_client_example_test.go index 56fdcc1eb4a4..e7655b34a346 100644 --- a/dialogflow/apiv2/generators_client_example_test.go +++ b/dialogflow/apiv2/generators_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/helpers.go b/dialogflow/apiv2/helpers.go index 304ffa716908..da4e0f4ec164 100755 --- a/dialogflow/apiv2/helpers.go +++ b/dialogflow/apiv2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/intents_client.go b/dialogflow/apiv2/intents_client.go index e57cb57df472..232955ad9d25 100755 --- a/dialogflow/apiv2/intents_client.go +++ b/dialogflow/apiv2/intents_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/intents_client_example_go123_test.go b/dialogflow/apiv2/intents_client_example_go123_test.go index 82a047379f96..2bb4497ef599 100644 --- a/dialogflow/apiv2/intents_client_example_go123_test.go +++ b/dialogflow/apiv2/intents_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/intents_client_example_test.go b/dialogflow/apiv2/intents_client_example_test.go index 39044b956946..89b9035c4e31 100644 --- a/dialogflow/apiv2/intents_client_example_test.go +++ b/dialogflow/apiv2/intents_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/knowledge_bases_client.go b/dialogflow/apiv2/knowledge_bases_client.go index 2483a7b2fdf2..cf392bed106f 100755 --- a/dialogflow/apiv2/knowledge_bases_client.go +++ b/dialogflow/apiv2/knowledge_bases_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/knowledge_bases_client_example_go123_test.go b/dialogflow/apiv2/knowledge_bases_client_example_go123_test.go index ae41bcaffec5..84fc08102d22 100644 --- a/dialogflow/apiv2/knowledge_bases_client_example_go123_test.go +++ b/dialogflow/apiv2/knowledge_bases_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/knowledge_bases_client_example_test.go b/dialogflow/apiv2/knowledge_bases_client_example_test.go index dcd5efbb9a22..00b56aceebfa 100644 --- a/dialogflow/apiv2/knowledge_bases_client_example_test.go +++ b/dialogflow/apiv2/knowledge_bases_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/participants_client.go b/dialogflow/apiv2/participants_client.go index d5407ddfeeab..1c59d7816515 100755 --- a/dialogflow/apiv2/participants_client.go +++ b/dialogflow/apiv2/participants_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/participants_client_example_go123_test.go b/dialogflow/apiv2/participants_client_example_go123_test.go index ccef5b5499fe..41c8a266a1f3 100644 --- a/dialogflow/apiv2/participants_client_example_go123_test.go +++ b/dialogflow/apiv2/participants_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/participants_client_example_test.go b/dialogflow/apiv2/participants_client_example_test.go index 2ecad69ad5b4..eea06508f44c 100644 --- a/dialogflow/apiv2/participants_client_example_test.go +++ b/dialogflow/apiv2/participants_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/session_entity_types_client.go b/dialogflow/apiv2/session_entity_types_client.go index 3d38603c4039..caa09e7c46b4 100755 --- a/dialogflow/apiv2/session_entity_types_client.go +++ b/dialogflow/apiv2/session_entity_types_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/session_entity_types_client_example_go123_test.go b/dialogflow/apiv2/session_entity_types_client_example_go123_test.go index 083d92082378..478d5b745eb2 100644 --- a/dialogflow/apiv2/session_entity_types_client_example_go123_test.go +++ b/dialogflow/apiv2/session_entity_types_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/session_entity_types_client_example_test.go b/dialogflow/apiv2/session_entity_types_client_example_test.go index 7b7403513b4d..8daf4455481f 100644 --- a/dialogflow/apiv2/session_entity_types_client_example_test.go +++ b/dialogflow/apiv2/session_entity_types_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/sessions_client.go b/dialogflow/apiv2/sessions_client.go index 614b9ceeb1d6..4f23d3fce7e2 100755 --- a/dialogflow/apiv2/sessions_client.go +++ b/dialogflow/apiv2/sessions_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/sessions_client_example_go123_test.go b/dialogflow/apiv2/sessions_client_example_go123_test.go index dca057d8e698..a234778e9c61 100644 --- a/dialogflow/apiv2/sessions_client_example_go123_test.go +++ b/dialogflow/apiv2/sessions_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/sessions_client_example_test.go b/dialogflow/apiv2/sessions_client_example_test.go index 26478dac4b7d..dbd7f800b2ec 100644 --- a/dialogflow/apiv2/sessions_client_example_test.go +++ b/dialogflow/apiv2/sessions_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/versions_client.go b/dialogflow/apiv2/versions_client.go index f1f17ab7cc70..3aac123dc5e9 100755 --- a/dialogflow/apiv2/versions_client.go +++ b/dialogflow/apiv2/versions_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/versions_client_example_go123_test.go b/dialogflow/apiv2/versions_client_example_go123_test.go index 2bb66b9c3e15..e44226ddadcd 100644 --- a/dialogflow/apiv2/versions_client_example_go123_test.go +++ b/dialogflow/apiv2/versions_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2/versions_client_example_test.go b/dialogflow/apiv2/versions_client_example_test.go index 41f492fbea7f..c77a2edcae53 100644 --- a/dialogflow/apiv2/versions_client_example_test.go +++ b/dialogflow/apiv2/versions_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/agents_client.go b/dialogflow/apiv2beta1/agents_client.go index 44c635468f34..fcb8d4848718 100755 --- a/dialogflow/apiv2beta1/agents_client.go +++ b/dialogflow/apiv2beta1/agents_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/agents_client_example_go123_test.go b/dialogflow/apiv2beta1/agents_client_example_go123_test.go index 4c72742e4715..cf20d217754e 100644 --- a/dialogflow/apiv2beta1/agents_client_example_go123_test.go +++ b/dialogflow/apiv2beta1/agents_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/agents_client_example_test.go b/dialogflow/apiv2beta1/agents_client_example_test.go index c8a45c68857b..42397427c14d 100644 --- a/dialogflow/apiv2beta1/agents_client_example_test.go +++ b/dialogflow/apiv2beta1/agents_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/answer_records_client.go b/dialogflow/apiv2beta1/answer_records_client.go index 9dda497c0422..4747671cdf40 100755 --- a/dialogflow/apiv2beta1/answer_records_client.go +++ b/dialogflow/apiv2beta1/answer_records_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/answer_records_client_example_go123_test.go b/dialogflow/apiv2beta1/answer_records_client_example_go123_test.go index 3235d28d29df..0b87796a2ac4 100644 --- a/dialogflow/apiv2beta1/answer_records_client_example_go123_test.go +++ b/dialogflow/apiv2beta1/answer_records_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/answer_records_client_example_test.go b/dialogflow/apiv2beta1/answer_records_client_example_test.go index 9e5512c66f92..c8ee45ad7c8a 100644 --- a/dialogflow/apiv2beta1/answer_records_client_example_test.go +++ b/dialogflow/apiv2beta1/answer_records_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/auxiliary.go b/dialogflow/apiv2beta1/auxiliary.go index 2b4dce11eb14..7f122381968f 100755 --- a/dialogflow/apiv2beta1/auxiliary.go +++ b/dialogflow/apiv2beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/auxiliary_go123.go b/dialogflow/apiv2beta1/auxiliary_go123.go index 2c447669a674..56b805700cf1 100755 --- a/dialogflow/apiv2beta1/auxiliary_go123.go +++ b/dialogflow/apiv2beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/contexts_client.go b/dialogflow/apiv2beta1/contexts_client.go index e39d9628872b..152aa1032d1d 100755 --- a/dialogflow/apiv2beta1/contexts_client.go +++ b/dialogflow/apiv2beta1/contexts_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/contexts_client_example_go123_test.go b/dialogflow/apiv2beta1/contexts_client_example_go123_test.go index 802f176ca32e..02c3a08505f6 100644 --- a/dialogflow/apiv2beta1/contexts_client_example_go123_test.go +++ b/dialogflow/apiv2beta1/contexts_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/contexts_client_example_test.go b/dialogflow/apiv2beta1/contexts_client_example_test.go index 982aa9ab1222..656644823045 100644 --- a/dialogflow/apiv2beta1/contexts_client_example_test.go +++ b/dialogflow/apiv2beta1/contexts_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/conversation_profiles_client.go b/dialogflow/apiv2beta1/conversation_profiles_client.go index 1cbbcfdafb4f..3ccef7297d02 100755 --- a/dialogflow/apiv2beta1/conversation_profiles_client.go +++ b/dialogflow/apiv2beta1/conversation_profiles_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/conversation_profiles_client_example_go123_test.go b/dialogflow/apiv2beta1/conversation_profiles_client_example_go123_test.go index 1c057d0d587b..b0ca94a22294 100644 --- a/dialogflow/apiv2beta1/conversation_profiles_client_example_go123_test.go +++ b/dialogflow/apiv2beta1/conversation_profiles_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/conversation_profiles_client_example_test.go b/dialogflow/apiv2beta1/conversation_profiles_client_example_test.go index e42750c67b78..260efe380d97 100644 --- a/dialogflow/apiv2beta1/conversation_profiles_client_example_test.go +++ b/dialogflow/apiv2beta1/conversation_profiles_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/conversations_client.go b/dialogflow/apiv2beta1/conversations_client.go index 0748259dd513..4eaf51f4fdee 100755 --- a/dialogflow/apiv2beta1/conversations_client.go +++ b/dialogflow/apiv2beta1/conversations_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/conversations_client_example_go123_test.go b/dialogflow/apiv2beta1/conversations_client_example_go123_test.go index c94e1e970db2..f0ebdb62fe0c 100644 --- a/dialogflow/apiv2beta1/conversations_client_example_go123_test.go +++ b/dialogflow/apiv2beta1/conversations_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/conversations_client_example_test.go b/dialogflow/apiv2beta1/conversations_client_example_test.go index 7157ff5b5dd6..67099ea99de1 100644 --- a/dialogflow/apiv2beta1/conversations_client_example_test.go +++ b/dialogflow/apiv2beta1/conversations_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/doc.go b/dialogflow/apiv2beta1/doc.go index a5a343d19127..2f32b580927f 100755 --- a/dialogflow/apiv2beta1/doc.go +++ b/dialogflow/apiv2beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/documents_client.go b/dialogflow/apiv2beta1/documents_client.go index 52b8896e44ba..ec2c30fdd616 100755 --- a/dialogflow/apiv2beta1/documents_client.go +++ b/dialogflow/apiv2beta1/documents_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/documents_client_example_go123_test.go b/dialogflow/apiv2beta1/documents_client_example_go123_test.go index 1b3b3b26a3a2..86527a3aa00f 100644 --- a/dialogflow/apiv2beta1/documents_client_example_go123_test.go +++ b/dialogflow/apiv2beta1/documents_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/documents_client_example_test.go b/dialogflow/apiv2beta1/documents_client_example_test.go index 1929ce19e851..0179b3780cda 100644 --- a/dialogflow/apiv2beta1/documents_client_example_test.go +++ b/dialogflow/apiv2beta1/documents_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/encryption_spec_client.go b/dialogflow/apiv2beta1/encryption_spec_client.go index 3b947285eca4..e06feecb594a 100755 --- a/dialogflow/apiv2beta1/encryption_spec_client.go +++ b/dialogflow/apiv2beta1/encryption_spec_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/encryption_spec_client_example_go123_test.go b/dialogflow/apiv2beta1/encryption_spec_client_example_go123_test.go index 75173484acf0..af199ffc3b9a 100644 --- a/dialogflow/apiv2beta1/encryption_spec_client_example_go123_test.go +++ b/dialogflow/apiv2beta1/encryption_spec_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/encryption_spec_client_example_test.go b/dialogflow/apiv2beta1/encryption_spec_client_example_test.go index cf99306705cc..0c5c83c39665 100644 --- a/dialogflow/apiv2beta1/encryption_spec_client_example_test.go +++ b/dialogflow/apiv2beta1/encryption_spec_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/entity_types_client.go b/dialogflow/apiv2beta1/entity_types_client.go index a2d894a7a910..654fde296af4 100755 --- a/dialogflow/apiv2beta1/entity_types_client.go +++ b/dialogflow/apiv2beta1/entity_types_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/entity_types_client_example_go123_test.go b/dialogflow/apiv2beta1/entity_types_client_example_go123_test.go index f5be83fd6d51..e177399c2fdb 100644 --- a/dialogflow/apiv2beta1/entity_types_client_example_go123_test.go +++ b/dialogflow/apiv2beta1/entity_types_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/entity_types_client_example_test.go b/dialogflow/apiv2beta1/entity_types_client_example_test.go index dfe8ebb7e44a..5c64d39b3a39 100644 --- a/dialogflow/apiv2beta1/entity_types_client_example_test.go +++ b/dialogflow/apiv2beta1/entity_types_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/environments_client.go b/dialogflow/apiv2beta1/environments_client.go index 0da43793de62..d3e78fd5aaa8 100755 --- a/dialogflow/apiv2beta1/environments_client.go +++ b/dialogflow/apiv2beta1/environments_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/environments_client_example_go123_test.go b/dialogflow/apiv2beta1/environments_client_example_go123_test.go index a38099ee2135..cbf1585629b7 100644 --- a/dialogflow/apiv2beta1/environments_client_example_go123_test.go +++ b/dialogflow/apiv2beta1/environments_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/environments_client_example_test.go b/dialogflow/apiv2beta1/environments_client_example_test.go index 052dfe8416dd..6c6d695f63f5 100644 --- a/dialogflow/apiv2beta1/environments_client_example_test.go +++ b/dialogflow/apiv2beta1/environments_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/fulfillments_client.go b/dialogflow/apiv2beta1/fulfillments_client.go index f4f03caa336c..7a6ece5b6338 100755 --- a/dialogflow/apiv2beta1/fulfillments_client.go +++ b/dialogflow/apiv2beta1/fulfillments_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/fulfillments_client_example_go123_test.go b/dialogflow/apiv2beta1/fulfillments_client_example_go123_test.go index fc70238bef7a..16da775eaae8 100644 --- a/dialogflow/apiv2beta1/fulfillments_client_example_go123_test.go +++ b/dialogflow/apiv2beta1/fulfillments_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/fulfillments_client_example_test.go b/dialogflow/apiv2beta1/fulfillments_client_example_test.go index c10c89a4403d..2aa2925fae3c 100644 --- a/dialogflow/apiv2beta1/fulfillments_client_example_test.go +++ b/dialogflow/apiv2beta1/fulfillments_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/generators_client.go b/dialogflow/apiv2beta1/generators_client.go index 6719f912a68a..1350800c6d12 100755 --- a/dialogflow/apiv2beta1/generators_client.go +++ b/dialogflow/apiv2beta1/generators_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/generators_client_example_go123_test.go b/dialogflow/apiv2beta1/generators_client_example_go123_test.go index f6ac278e6543..138e0b49e2a4 100644 --- a/dialogflow/apiv2beta1/generators_client_example_go123_test.go +++ b/dialogflow/apiv2beta1/generators_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/generators_client_example_test.go b/dialogflow/apiv2beta1/generators_client_example_test.go index cdcceca6354c..8d127f4c0ffb 100644 --- a/dialogflow/apiv2beta1/generators_client_example_test.go +++ b/dialogflow/apiv2beta1/generators_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/helpers.go b/dialogflow/apiv2beta1/helpers.go index 304ffa716908..da4e0f4ec164 100755 --- a/dialogflow/apiv2beta1/helpers.go +++ b/dialogflow/apiv2beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/intents_client.go b/dialogflow/apiv2beta1/intents_client.go index 6e50032d4c84..64ebd9f2e850 100755 --- a/dialogflow/apiv2beta1/intents_client.go +++ b/dialogflow/apiv2beta1/intents_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/intents_client_example_go123_test.go b/dialogflow/apiv2beta1/intents_client_example_go123_test.go index c517baf33a9d..d7f39898f412 100644 --- a/dialogflow/apiv2beta1/intents_client_example_go123_test.go +++ b/dialogflow/apiv2beta1/intents_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/intents_client_example_test.go b/dialogflow/apiv2beta1/intents_client_example_test.go index 12f76e84da08..1dd2f9c94db1 100644 --- a/dialogflow/apiv2beta1/intents_client_example_test.go +++ b/dialogflow/apiv2beta1/intents_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/knowledge_bases_client.go b/dialogflow/apiv2beta1/knowledge_bases_client.go index 7fa15a4e11a5..b30a66f3d8d0 100755 --- a/dialogflow/apiv2beta1/knowledge_bases_client.go +++ b/dialogflow/apiv2beta1/knowledge_bases_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/knowledge_bases_client_example_go123_test.go b/dialogflow/apiv2beta1/knowledge_bases_client_example_go123_test.go index 590829478018..6d58f1974711 100644 --- a/dialogflow/apiv2beta1/knowledge_bases_client_example_go123_test.go +++ b/dialogflow/apiv2beta1/knowledge_bases_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/knowledge_bases_client_example_test.go b/dialogflow/apiv2beta1/knowledge_bases_client_example_test.go index cedd2f4cd226..fe1a767e32d0 100644 --- a/dialogflow/apiv2beta1/knowledge_bases_client_example_test.go +++ b/dialogflow/apiv2beta1/knowledge_bases_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/participants_client.go b/dialogflow/apiv2beta1/participants_client.go index f49caeced8ef..a56e4bf44bcc 100755 --- a/dialogflow/apiv2beta1/participants_client.go +++ b/dialogflow/apiv2beta1/participants_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/participants_client_example_go123_test.go b/dialogflow/apiv2beta1/participants_client_example_go123_test.go index d63b0d6f33ac..f964e59a2269 100644 --- a/dialogflow/apiv2beta1/participants_client_example_go123_test.go +++ b/dialogflow/apiv2beta1/participants_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/participants_client_example_test.go b/dialogflow/apiv2beta1/participants_client_example_test.go index d729738b1d88..d5fcf5045cee 100644 --- a/dialogflow/apiv2beta1/participants_client_example_test.go +++ b/dialogflow/apiv2beta1/participants_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/session_entity_types_client.go b/dialogflow/apiv2beta1/session_entity_types_client.go index e123da9e90d6..1ccf7ddc1d61 100755 --- a/dialogflow/apiv2beta1/session_entity_types_client.go +++ b/dialogflow/apiv2beta1/session_entity_types_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/session_entity_types_client_example_go123_test.go b/dialogflow/apiv2beta1/session_entity_types_client_example_go123_test.go index 79cc0fff136c..a65224031866 100644 --- a/dialogflow/apiv2beta1/session_entity_types_client_example_go123_test.go +++ b/dialogflow/apiv2beta1/session_entity_types_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/session_entity_types_client_example_test.go b/dialogflow/apiv2beta1/session_entity_types_client_example_test.go index 0eab37b4ebb7..22f6b2056f70 100644 --- a/dialogflow/apiv2beta1/session_entity_types_client_example_test.go +++ b/dialogflow/apiv2beta1/session_entity_types_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/sessions_client.go b/dialogflow/apiv2beta1/sessions_client.go index 357c1886dab7..4ad25608d9d1 100755 --- a/dialogflow/apiv2beta1/sessions_client.go +++ b/dialogflow/apiv2beta1/sessions_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/sessions_client_example_go123_test.go b/dialogflow/apiv2beta1/sessions_client_example_go123_test.go index 037b3e4626d8..6df4fc064d5c 100644 --- a/dialogflow/apiv2beta1/sessions_client_example_go123_test.go +++ b/dialogflow/apiv2beta1/sessions_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/sessions_client_example_test.go b/dialogflow/apiv2beta1/sessions_client_example_test.go index 7fe4ca2d7e33..aa38f116fd59 100644 --- a/dialogflow/apiv2beta1/sessions_client_example_test.go +++ b/dialogflow/apiv2beta1/sessions_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/sip_trunks_client.go b/dialogflow/apiv2beta1/sip_trunks_client.go index a0cb1d051453..7c49abcc3e5d 100755 --- a/dialogflow/apiv2beta1/sip_trunks_client.go +++ b/dialogflow/apiv2beta1/sip_trunks_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/sip_trunks_client_example_go123_test.go b/dialogflow/apiv2beta1/sip_trunks_client_example_go123_test.go index 38e0e96d215e..433fe61b435d 100644 --- a/dialogflow/apiv2beta1/sip_trunks_client_example_go123_test.go +++ b/dialogflow/apiv2beta1/sip_trunks_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/sip_trunks_client_example_test.go b/dialogflow/apiv2beta1/sip_trunks_client_example_test.go index 055ad75db192..02850e082986 100644 --- a/dialogflow/apiv2beta1/sip_trunks_client_example_test.go +++ b/dialogflow/apiv2beta1/sip_trunks_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/versions_client.go b/dialogflow/apiv2beta1/versions_client.go index 3c1ca42ccec7..224bc0b075a1 100755 --- a/dialogflow/apiv2beta1/versions_client.go +++ b/dialogflow/apiv2beta1/versions_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/versions_client_example_go123_test.go b/dialogflow/apiv2beta1/versions_client_example_go123_test.go index 2c2222d2a435..866c89615ef4 100644 --- a/dialogflow/apiv2beta1/versions_client_example_go123_test.go +++ b/dialogflow/apiv2beta1/versions_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/apiv2beta1/versions_client_example_test.go b/dialogflow/apiv2beta1/versions_client_example_test.go index 879c3b3cdbbd..97a13fd342ab 100644 --- a/dialogflow/apiv2beta1/versions_client_example_test.go +++ b/dialogflow/apiv2beta1/versions_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/agents_client.go b/dialogflow/cx/apiv3/agents_client.go index 133836929863..8b1fa8598428 100755 --- a/dialogflow/cx/apiv3/agents_client.go +++ b/dialogflow/cx/apiv3/agents_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/agents_client_example_go123_test.go b/dialogflow/cx/apiv3/agents_client_example_go123_test.go index 830b925eebbe..e68615afed77 100644 --- a/dialogflow/cx/apiv3/agents_client_example_go123_test.go +++ b/dialogflow/cx/apiv3/agents_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/agents_client_example_test.go b/dialogflow/cx/apiv3/agents_client_example_test.go index 387b3256b110..00d5cded31b5 100644 --- a/dialogflow/cx/apiv3/agents_client_example_test.go +++ b/dialogflow/cx/apiv3/agents_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/auxiliary.go b/dialogflow/cx/apiv3/auxiliary.go index aadb8af18f2a..16944d9df828 100755 --- a/dialogflow/cx/apiv3/auxiliary.go +++ b/dialogflow/cx/apiv3/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/auxiliary_go123.go b/dialogflow/cx/apiv3/auxiliary_go123.go index 41b3a7aa2814..4c67d2ba43df 100755 --- a/dialogflow/cx/apiv3/auxiliary_go123.go +++ b/dialogflow/cx/apiv3/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/changelogs_client.go b/dialogflow/cx/apiv3/changelogs_client.go index f309246c7850..75564853cf86 100755 --- a/dialogflow/cx/apiv3/changelogs_client.go +++ b/dialogflow/cx/apiv3/changelogs_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/changelogs_client_example_go123_test.go b/dialogflow/cx/apiv3/changelogs_client_example_go123_test.go index 45bc898f7e45..37614919df3e 100644 --- a/dialogflow/cx/apiv3/changelogs_client_example_go123_test.go +++ b/dialogflow/cx/apiv3/changelogs_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/changelogs_client_example_test.go b/dialogflow/cx/apiv3/changelogs_client_example_test.go index fb5cbfbf46a3..60f062a9b9a2 100644 --- a/dialogflow/cx/apiv3/changelogs_client_example_test.go +++ b/dialogflow/cx/apiv3/changelogs_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/deployments_client.go b/dialogflow/cx/apiv3/deployments_client.go index 956cf61a5b76..f9cc19bcd0d0 100755 --- a/dialogflow/cx/apiv3/deployments_client.go +++ b/dialogflow/cx/apiv3/deployments_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/deployments_client_example_go123_test.go b/dialogflow/cx/apiv3/deployments_client_example_go123_test.go index 59e4b2855d8f..01d766de4f79 100644 --- a/dialogflow/cx/apiv3/deployments_client_example_go123_test.go +++ b/dialogflow/cx/apiv3/deployments_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/deployments_client_example_test.go b/dialogflow/cx/apiv3/deployments_client_example_test.go index 718aea157948..c32de491713e 100644 --- a/dialogflow/cx/apiv3/deployments_client_example_test.go +++ b/dialogflow/cx/apiv3/deployments_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/doc.go b/dialogflow/cx/apiv3/doc.go index 881e24ff23b8..c7bae248e675 100755 --- a/dialogflow/cx/apiv3/doc.go +++ b/dialogflow/cx/apiv3/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/entity_types_client.go b/dialogflow/cx/apiv3/entity_types_client.go index baa80ff02b9b..73819f4e86cc 100755 --- a/dialogflow/cx/apiv3/entity_types_client.go +++ b/dialogflow/cx/apiv3/entity_types_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/entity_types_client_example_go123_test.go b/dialogflow/cx/apiv3/entity_types_client_example_go123_test.go index cb7d577d5bce..47085aa5448a 100644 --- a/dialogflow/cx/apiv3/entity_types_client_example_go123_test.go +++ b/dialogflow/cx/apiv3/entity_types_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/entity_types_client_example_test.go b/dialogflow/cx/apiv3/entity_types_client_example_test.go index 29265408c747..3c4228dde940 100644 --- a/dialogflow/cx/apiv3/entity_types_client_example_test.go +++ b/dialogflow/cx/apiv3/entity_types_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/environments_client.go b/dialogflow/cx/apiv3/environments_client.go index e26dbda0a351..6ad7584bf56a 100755 --- a/dialogflow/cx/apiv3/environments_client.go +++ b/dialogflow/cx/apiv3/environments_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/environments_client_example_go123_test.go b/dialogflow/cx/apiv3/environments_client_example_go123_test.go index 633565b2d8b1..1f82e4c642b8 100644 --- a/dialogflow/cx/apiv3/environments_client_example_go123_test.go +++ b/dialogflow/cx/apiv3/environments_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/environments_client_example_test.go b/dialogflow/cx/apiv3/environments_client_example_test.go index 6df0cdf4cb5f..7446565eba2d 100644 --- a/dialogflow/cx/apiv3/environments_client_example_test.go +++ b/dialogflow/cx/apiv3/environments_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/experiments_client.go b/dialogflow/cx/apiv3/experiments_client.go index d08e1de4f77c..d1db45bdedb7 100755 --- a/dialogflow/cx/apiv3/experiments_client.go +++ b/dialogflow/cx/apiv3/experiments_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/experiments_client_example_go123_test.go b/dialogflow/cx/apiv3/experiments_client_example_go123_test.go index 5c46baebcf98..0f419ea0148e 100644 --- a/dialogflow/cx/apiv3/experiments_client_example_go123_test.go +++ b/dialogflow/cx/apiv3/experiments_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/experiments_client_example_test.go b/dialogflow/cx/apiv3/experiments_client_example_test.go index e32026d65a47..5b33c44a09d6 100644 --- a/dialogflow/cx/apiv3/experiments_client_example_test.go +++ b/dialogflow/cx/apiv3/experiments_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/flows_client.go b/dialogflow/cx/apiv3/flows_client.go index 78db3feeac5b..e974a87c695b 100755 --- a/dialogflow/cx/apiv3/flows_client.go +++ b/dialogflow/cx/apiv3/flows_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/flows_client_example_go123_test.go b/dialogflow/cx/apiv3/flows_client_example_go123_test.go index 9b682924a9fd..78841b046a6e 100644 --- a/dialogflow/cx/apiv3/flows_client_example_go123_test.go +++ b/dialogflow/cx/apiv3/flows_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/flows_client_example_test.go b/dialogflow/cx/apiv3/flows_client_example_test.go index 08816ae6ebc1..b2bfe942ee87 100644 --- a/dialogflow/cx/apiv3/flows_client_example_test.go +++ b/dialogflow/cx/apiv3/flows_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/generators_client.go b/dialogflow/cx/apiv3/generators_client.go index 0c27a13f565c..864adb37a91c 100755 --- a/dialogflow/cx/apiv3/generators_client.go +++ b/dialogflow/cx/apiv3/generators_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/generators_client_example_go123_test.go b/dialogflow/cx/apiv3/generators_client_example_go123_test.go index f5fa55db9f5a..7f5a11dbfc72 100644 --- a/dialogflow/cx/apiv3/generators_client_example_go123_test.go +++ b/dialogflow/cx/apiv3/generators_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/generators_client_example_test.go b/dialogflow/cx/apiv3/generators_client_example_test.go index fe11d6190968..92a7ccf0c8b9 100644 --- a/dialogflow/cx/apiv3/generators_client_example_test.go +++ b/dialogflow/cx/apiv3/generators_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/helpers.go b/dialogflow/cx/apiv3/helpers.go index 1ccd240c8542..2dfb673fd154 100755 --- a/dialogflow/cx/apiv3/helpers.go +++ b/dialogflow/cx/apiv3/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/intents_client.go b/dialogflow/cx/apiv3/intents_client.go index 88a6f45b5299..265198a54f0d 100755 --- a/dialogflow/cx/apiv3/intents_client.go +++ b/dialogflow/cx/apiv3/intents_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/intents_client_example_go123_test.go b/dialogflow/cx/apiv3/intents_client_example_go123_test.go index 55190b3b49f5..45df8df4894b 100644 --- a/dialogflow/cx/apiv3/intents_client_example_go123_test.go +++ b/dialogflow/cx/apiv3/intents_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/intents_client_example_test.go b/dialogflow/cx/apiv3/intents_client_example_test.go index 08114758bbab..e2a186c54ebc 100644 --- a/dialogflow/cx/apiv3/intents_client_example_test.go +++ b/dialogflow/cx/apiv3/intents_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/pages_client.go b/dialogflow/cx/apiv3/pages_client.go index d330db7a895e..a8a27a3b4ee4 100755 --- a/dialogflow/cx/apiv3/pages_client.go +++ b/dialogflow/cx/apiv3/pages_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/pages_client_example_go123_test.go b/dialogflow/cx/apiv3/pages_client_example_go123_test.go index f48a642f48eb..1b8650b4897a 100644 --- a/dialogflow/cx/apiv3/pages_client_example_go123_test.go +++ b/dialogflow/cx/apiv3/pages_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/pages_client_example_test.go b/dialogflow/cx/apiv3/pages_client_example_test.go index a2ff5de73bda..a3aa1f7e0741 100644 --- a/dialogflow/cx/apiv3/pages_client_example_test.go +++ b/dialogflow/cx/apiv3/pages_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/security_settings_client.go b/dialogflow/cx/apiv3/security_settings_client.go index 2c0b4d87732c..2a0a1700d707 100755 --- a/dialogflow/cx/apiv3/security_settings_client.go +++ b/dialogflow/cx/apiv3/security_settings_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/security_settings_client_example_go123_test.go b/dialogflow/cx/apiv3/security_settings_client_example_go123_test.go index 37e3520457c7..405298ad9749 100644 --- a/dialogflow/cx/apiv3/security_settings_client_example_go123_test.go +++ b/dialogflow/cx/apiv3/security_settings_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/security_settings_client_example_test.go b/dialogflow/cx/apiv3/security_settings_client_example_test.go index 391f1286ae2c..03a5a8cb409e 100644 --- a/dialogflow/cx/apiv3/security_settings_client_example_test.go +++ b/dialogflow/cx/apiv3/security_settings_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/session_entity_types_client.go b/dialogflow/cx/apiv3/session_entity_types_client.go index eeaabb2cd111..da46a7526437 100755 --- a/dialogflow/cx/apiv3/session_entity_types_client.go +++ b/dialogflow/cx/apiv3/session_entity_types_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/session_entity_types_client_example_go123_test.go b/dialogflow/cx/apiv3/session_entity_types_client_example_go123_test.go index 63b37164e7c8..df253b6c318d 100644 --- a/dialogflow/cx/apiv3/session_entity_types_client_example_go123_test.go +++ b/dialogflow/cx/apiv3/session_entity_types_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/session_entity_types_client_example_test.go b/dialogflow/cx/apiv3/session_entity_types_client_example_test.go index d4dd6a75c29b..f248619e3cd5 100644 --- a/dialogflow/cx/apiv3/session_entity_types_client_example_test.go +++ b/dialogflow/cx/apiv3/session_entity_types_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/sessions_client.go b/dialogflow/cx/apiv3/sessions_client.go index 6216a42ca5f7..163a137a1607 100755 --- a/dialogflow/cx/apiv3/sessions_client.go +++ b/dialogflow/cx/apiv3/sessions_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/sessions_client_example_go123_test.go b/dialogflow/cx/apiv3/sessions_client_example_go123_test.go index 6c4fc81784c1..fd1f9e0ed5d4 100644 --- a/dialogflow/cx/apiv3/sessions_client_example_go123_test.go +++ b/dialogflow/cx/apiv3/sessions_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/sessions_client_example_test.go b/dialogflow/cx/apiv3/sessions_client_example_test.go index dbd7636da019..48d45145643f 100644 --- a/dialogflow/cx/apiv3/sessions_client_example_test.go +++ b/dialogflow/cx/apiv3/sessions_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/test_cases_client.go b/dialogflow/cx/apiv3/test_cases_client.go index 56a3fe553a68..3d6c7edbd34d 100755 --- a/dialogflow/cx/apiv3/test_cases_client.go +++ b/dialogflow/cx/apiv3/test_cases_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/test_cases_client_example_go123_test.go b/dialogflow/cx/apiv3/test_cases_client_example_go123_test.go index dc4785df54f1..25a1fa5f9d2a 100644 --- a/dialogflow/cx/apiv3/test_cases_client_example_go123_test.go +++ b/dialogflow/cx/apiv3/test_cases_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/test_cases_client_example_test.go b/dialogflow/cx/apiv3/test_cases_client_example_test.go index 1ba17a65c4bf..04737b7716ce 100644 --- a/dialogflow/cx/apiv3/test_cases_client_example_test.go +++ b/dialogflow/cx/apiv3/test_cases_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/transition_route_groups_client.go b/dialogflow/cx/apiv3/transition_route_groups_client.go index c7f8a95d902f..9f72bdfc4419 100755 --- a/dialogflow/cx/apiv3/transition_route_groups_client.go +++ b/dialogflow/cx/apiv3/transition_route_groups_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/transition_route_groups_client_example_go123_test.go b/dialogflow/cx/apiv3/transition_route_groups_client_example_go123_test.go index 5f9dc633e6a0..87e0ad95c8bc 100644 --- a/dialogflow/cx/apiv3/transition_route_groups_client_example_go123_test.go +++ b/dialogflow/cx/apiv3/transition_route_groups_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/transition_route_groups_client_example_test.go b/dialogflow/cx/apiv3/transition_route_groups_client_example_test.go index ae8c0f79d589..713ccdda7ed2 100644 --- a/dialogflow/cx/apiv3/transition_route_groups_client_example_test.go +++ b/dialogflow/cx/apiv3/transition_route_groups_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/versions_client.go b/dialogflow/cx/apiv3/versions_client.go index 71a69e945f83..978b1f6c987f 100755 --- a/dialogflow/cx/apiv3/versions_client.go +++ b/dialogflow/cx/apiv3/versions_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/versions_client_example_go123_test.go b/dialogflow/cx/apiv3/versions_client_example_go123_test.go index 78eb26ccf1ee..27e6b5547efa 100644 --- a/dialogflow/cx/apiv3/versions_client_example_go123_test.go +++ b/dialogflow/cx/apiv3/versions_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/versions_client_example_test.go b/dialogflow/cx/apiv3/versions_client_example_test.go index 7661b4535039..0f58cea52dbc 100644 --- a/dialogflow/cx/apiv3/versions_client_example_test.go +++ b/dialogflow/cx/apiv3/versions_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/webhooks_client.go b/dialogflow/cx/apiv3/webhooks_client.go index fd0f4b6a689f..0f9ee9f22ba0 100755 --- a/dialogflow/cx/apiv3/webhooks_client.go +++ b/dialogflow/cx/apiv3/webhooks_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/webhooks_client_example_go123_test.go b/dialogflow/cx/apiv3/webhooks_client_example_go123_test.go index 23356c45cd8d..9d2802e58c2b 100644 --- a/dialogflow/cx/apiv3/webhooks_client_example_go123_test.go +++ b/dialogflow/cx/apiv3/webhooks_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3/webhooks_client_example_test.go b/dialogflow/cx/apiv3/webhooks_client_example_test.go index 998a599546a3..c45e8084a4fc 100644 --- a/dialogflow/cx/apiv3/webhooks_client_example_test.go +++ b/dialogflow/cx/apiv3/webhooks_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/agents_client.go b/dialogflow/cx/apiv3beta1/agents_client.go index 41393b150f26..c37719835745 100755 --- a/dialogflow/cx/apiv3beta1/agents_client.go +++ b/dialogflow/cx/apiv3beta1/agents_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/agents_client_example_go123_test.go b/dialogflow/cx/apiv3beta1/agents_client_example_go123_test.go index cf01ac38c8f4..c490adb5fcdd 100644 --- a/dialogflow/cx/apiv3beta1/agents_client_example_go123_test.go +++ b/dialogflow/cx/apiv3beta1/agents_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/agents_client_example_test.go b/dialogflow/cx/apiv3beta1/agents_client_example_test.go index be4d9975ebd4..1c474e352e67 100644 --- a/dialogflow/cx/apiv3beta1/agents_client_example_test.go +++ b/dialogflow/cx/apiv3beta1/agents_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/auxiliary.go b/dialogflow/cx/apiv3beta1/auxiliary.go index d77b51bda8bc..861138afd447 100755 --- a/dialogflow/cx/apiv3beta1/auxiliary.go +++ b/dialogflow/cx/apiv3beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/auxiliary_go123.go b/dialogflow/cx/apiv3beta1/auxiliary_go123.go index b66289c47483..474041a62c44 100755 --- a/dialogflow/cx/apiv3beta1/auxiliary_go123.go +++ b/dialogflow/cx/apiv3beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/changelogs_client.go b/dialogflow/cx/apiv3beta1/changelogs_client.go index f4d1bf8e9616..3c4ee4d554cf 100755 --- a/dialogflow/cx/apiv3beta1/changelogs_client.go +++ b/dialogflow/cx/apiv3beta1/changelogs_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/changelogs_client_example_go123_test.go b/dialogflow/cx/apiv3beta1/changelogs_client_example_go123_test.go index 0fa07cb7c5a8..d6bc830cb53b 100644 --- a/dialogflow/cx/apiv3beta1/changelogs_client_example_go123_test.go +++ b/dialogflow/cx/apiv3beta1/changelogs_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/changelogs_client_example_test.go b/dialogflow/cx/apiv3beta1/changelogs_client_example_test.go index f42a0927c2ec..adef4479f8fe 100644 --- a/dialogflow/cx/apiv3beta1/changelogs_client_example_test.go +++ b/dialogflow/cx/apiv3beta1/changelogs_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/conversation_history_client.go b/dialogflow/cx/apiv3beta1/conversation_history_client.go index a8128d342253..2331836d99f8 100755 --- a/dialogflow/cx/apiv3beta1/conversation_history_client.go +++ b/dialogflow/cx/apiv3beta1/conversation_history_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/conversation_history_client_example_go123_test.go b/dialogflow/cx/apiv3beta1/conversation_history_client_example_go123_test.go index 2b3c6f341f54..29b94488d9ed 100644 --- a/dialogflow/cx/apiv3beta1/conversation_history_client_example_go123_test.go +++ b/dialogflow/cx/apiv3beta1/conversation_history_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/conversation_history_client_example_test.go b/dialogflow/cx/apiv3beta1/conversation_history_client_example_test.go index addde9242b43..7f050819b197 100644 --- a/dialogflow/cx/apiv3beta1/conversation_history_client_example_test.go +++ b/dialogflow/cx/apiv3beta1/conversation_history_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/deployments_client.go b/dialogflow/cx/apiv3beta1/deployments_client.go index 51fe8c62d99f..4d996c44e353 100755 --- a/dialogflow/cx/apiv3beta1/deployments_client.go +++ b/dialogflow/cx/apiv3beta1/deployments_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/deployments_client_example_go123_test.go b/dialogflow/cx/apiv3beta1/deployments_client_example_go123_test.go index d79801c86ae0..58720cd0593e 100644 --- a/dialogflow/cx/apiv3beta1/deployments_client_example_go123_test.go +++ b/dialogflow/cx/apiv3beta1/deployments_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/deployments_client_example_test.go b/dialogflow/cx/apiv3beta1/deployments_client_example_test.go index 8afe1b777157..04e5beff4d57 100644 --- a/dialogflow/cx/apiv3beta1/deployments_client_example_test.go +++ b/dialogflow/cx/apiv3beta1/deployments_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/doc.go b/dialogflow/cx/apiv3beta1/doc.go index 249ec593ee21..2b0e724e4d7f 100755 --- a/dialogflow/cx/apiv3beta1/doc.go +++ b/dialogflow/cx/apiv3beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/entity_types_client.go b/dialogflow/cx/apiv3beta1/entity_types_client.go index 59a475cbf3ae..a5107a64743f 100755 --- a/dialogflow/cx/apiv3beta1/entity_types_client.go +++ b/dialogflow/cx/apiv3beta1/entity_types_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/entity_types_client_example_go123_test.go b/dialogflow/cx/apiv3beta1/entity_types_client_example_go123_test.go index 6b4b81aa6520..dfaf193d48bf 100644 --- a/dialogflow/cx/apiv3beta1/entity_types_client_example_go123_test.go +++ b/dialogflow/cx/apiv3beta1/entity_types_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/entity_types_client_example_test.go b/dialogflow/cx/apiv3beta1/entity_types_client_example_test.go index e6640e764aff..53cb085eb0e1 100644 --- a/dialogflow/cx/apiv3beta1/entity_types_client_example_test.go +++ b/dialogflow/cx/apiv3beta1/entity_types_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/environments_client.go b/dialogflow/cx/apiv3beta1/environments_client.go index f1ee4d5f5cfd..9b17a7c1f355 100755 --- a/dialogflow/cx/apiv3beta1/environments_client.go +++ b/dialogflow/cx/apiv3beta1/environments_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/environments_client_example_go123_test.go b/dialogflow/cx/apiv3beta1/environments_client_example_go123_test.go index a2236d4068bc..957a19875fc5 100644 --- a/dialogflow/cx/apiv3beta1/environments_client_example_go123_test.go +++ b/dialogflow/cx/apiv3beta1/environments_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/environments_client_example_test.go b/dialogflow/cx/apiv3beta1/environments_client_example_test.go index 9dfc559ca3f8..24b3861c5831 100644 --- a/dialogflow/cx/apiv3beta1/environments_client_example_test.go +++ b/dialogflow/cx/apiv3beta1/environments_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/examples_client.go b/dialogflow/cx/apiv3beta1/examples_client.go index 9a78f52a55e8..c9c2f5c5e636 100755 --- a/dialogflow/cx/apiv3beta1/examples_client.go +++ b/dialogflow/cx/apiv3beta1/examples_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/examples_client_example_go123_test.go b/dialogflow/cx/apiv3beta1/examples_client_example_go123_test.go index c7428fd27616..6449ef47ed1e 100644 --- a/dialogflow/cx/apiv3beta1/examples_client_example_go123_test.go +++ b/dialogflow/cx/apiv3beta1/examples_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/examples_client_example_test.go b/dialogflow/cx/apiv3beta1/examples_client_example_test.go index df79a110101e..d2c15fc66ee7 100644 --- a/dialogflow/cx/apiv3beta1/examples_client_example_test.go +++ b/dialogflow/cx/apiv3beta1/examples_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/experiments_client.go b/dialogflow/cx/apiv3beta1/experiments_client.go index 7c3764d21d60..0f650e261d2d 100755 --- a/dialogflow/cx/apiv3beta1/experiments_client.go +++ b/dialogflow/cx/apiv3beta1/experiments_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/experiments_client_example_go123_test.go b/dialogflow/cx/apiv3beta1/experiments_client_example_go123_test.go index c610ead4bc15..9a0dd041a22f 100644 --- a/dialogflow/cx/apiv3beta1/experiments_client_example_go123_test.go +++ b/dialogflow/cx/apiv3beta1/experiments_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/experiments_client_example_test.go b/dialogflow/cx/apiv3beta1/experiments_client_example_test.go index 126c97cfaa69..aa6a15d0df8d 100644 --- a/dialogflow/cx/apiv3beta1/experiments_client_example_test.go +++ b/dialogflow/cx/apiv3beta1/experiments_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/flows_client.go b/dialogflow/cx/apiv3beta1/flows_client.go index bfebdaaccc16..e7eea872e80b 100755 --- a/dialogflow/cx/apiv3beta1/flows_client.go +++ b/dialogflow/cx/apiv3beta1/flows_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/flows_client_example_go123_test.go b/dialogflow/cx/apiv3beta1/flows_client_example_go123_test.go index 7bb71037d526..de3332e95ff3 100644 --- a/dialogflow/cx/apiv3beta1/flows_client_example_go123_test.go +++ b/dialogflow/cx/apiv3beta1/flows_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/flows_client_example_test.go b/dialogflow/cx/apiv3beta1/flows_client_example_test.go index 88a7eb217d5b..557c1a298511 100644 --- a/dialogflow/cx/apiv3beta1/flows_client_example_test.go +++ b/dialogflow/cx/apiv3beta1/flows_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/generators_client.go b/dialogflow/cx/apiv3beta1/generators_client.go index 74cfe6ec56a8..c2d66aedc4e6 100755 --- a/dialogflow/cx/apiv3beta1/generators_client.go +++ b/dialogflow/cx/apiv3beta1/generators_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/generators_client_example_go123_test.go b/dialogflow/cx/apiv3beta1/generators_client_example_go123_test.go index 9b92941f69a3..b307c2280164 100644 --- a/dialogflow/cx/apiv3beta1/generators_client_example_go123_test.go +++ b/dialogflow/cx/apiv3beta1/generators_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/generators_client_example_test.go b/dialogflow/cx/apiv3beta1/generators_client_example_test.go index 05ad5a443427..81562bbfafc0 100644 --- a/dialogflow/cx/apiv3beta1/generators_client_example_test.go +++ b/dialogflow/cx/apiv3beta1/generators_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/helpers.go b/dialogflow/cx/apiv3beta1/helpers.go index 1ccd240c8542..2dfb673fd154 100755 --- a/dialogflow/cx/apiv3beta1/helpers.go +++ b/dialogflow/cx/apiv3beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/intents_client.go b/dialogflow/cx/apiv3beta1/intents_client.go index 453987b10217..487ef86363eb 100755 --- a/dialogflow/cx/apiv3beta1/intents_client.go +++ b/dialogflow/cx/apiv3beta1/intents_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/intents_client_example_go123_test.go b/dialogflow/cx/apiv3beta1/intents_client_example_go123_test.go index 5e2d93833ca1..682f82c9f088 100644 --- a/dialogflow/cx/apiv3beta1/intents_client_example_go123_test.go +++ b/dialogflow/cx/apiv3beta1/intents_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/intents_client_example_test.go b/dialogflow/cx/apiv3beta1/intents_client_example_test.go index 2df386690c42..7c9a9ec2b534 100644 --- a/dialogflow/cx/apiv3beta1/intents_client_example_test.go +++ b/dialogflow/cx/apiv3beta1/intents_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/pages_client.go b/dialogflow/cx/apiv3beta1/pages_client.go index ce2036c7feea..670f653f16d9 100755 --- a/dialogflow/cx/apiv3beta1/pages_client.go +++ b/dialogflow/cx/apiv3beta1/pages_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/pages_client_example_go123_test.go b/dialogflow/cx/apiv3beta1/pages_client_example_go123_test.go index 895fbccb8b32..24107eaf91a2 100644 --- a/dialogflow/cx/apiv3beta1/pages_client_example_go123_test.go +++ b/dialogflow/cx/apiv3beta1/pages_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/pages_client_example_test.go b/dialogflow/cx/apiv3beta1/pages_client_example_test.go index 8e5dcc35809d..549322e0103d 100644 --- a/dialogflow/cx/apiv3beta1/pages_client_example_test.go +++ b/dialogflow/cx/apiv3beta1/pages_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/playbooks_client.go b/dialogflow/cx/apiv3beta1/playbooks_client.go index 52c7f76576b2..5fba41302f7c 100755 --- a/dialogflow/cx/apiv3beta1/playbooks_client.go +++ b/dialogflow/cx/apiv3beta1/playbooks_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/playbooks_client_example_go123_test.go b/dialogflow/cx/apiv3beta1/playbooks_client_example_go123_test.go index de417e39cf1d..7d8996a698dc 100644 --- a/dialogflow/cx/apiv3beta1/playbooks_client_example_go123_test.go +++ b/dialogflow/cx/apiv3beta1/playbooks_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/playbooks_client_example_test.go b/dialogflow/cx/apiv3beta1/playbooks_client_example_test.go index ca4e3921a2be..33c8e3bfb0e9 100644 --- a/dialogflow/cx/apiv3beta1/playbooks_client_example_test.go +++ b/dialogflow/cx/apiv3beta1/playbooks_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/security_settings_client.go b/dialogflow/cx/apiv3beta1/security_settings_client.go index a4ae0a04b282..de04c7de351f 100755 --- a/dialogflow/cx/apiv3beta1/security_settings_client.go +++ b/dialogflow/cx/apiv3beta1/security_settings_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/security_settings_client_example_go123_test.go b/dialogflow/cx/apiv3beta1/security_settings_client_example_go123_test.go index b9d8573a8a25..df8850363eea 100644 --- a/dialogflow/cx/apiv3beta1/security_settings_client_example_go123_test.go +++ b/dialogflow/cx/apiv3beta1/security_settings_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/security_settings_client_example_test.go b/dialogflow/cx/apiv3beta1/security_settings_client_example_test.go index 7b7edc18af65..1d7227e707db 100644 --- a/dialogflow/cx/apiv3beta1/security_settings_client_example_test.go +++ b/dialogflow/cx/apiv3beta1/security_settings_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/session_entity_types_client.go b/dialogflow/cx/apiv3beta1/session_entity_types_client.go index 13ea3cf1fa79..67686f3014f9 100755 --- a/dialogflow/cx/apiv3beta1/session_entity_types_client.go +++ b/dialogflow/cx/apiv3beta1/session_entity_types_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/session_entity_types_client_example_go123_test.go b/dialogflow/cx/apiv3beta1/session_entity_types_client_example_go123_test.go index a7bd9e930835..fe09ce8d2de9 100644 --- a/dialogflow/cx/apiv3beta1/session_entity_types_client_example_go123_test.go +++ b/dialogflow/cx/apiv3beta1/session_entity_types_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/session_entity_types_client_example_test.go b/dialogflow/cx/apiv3beta1/session_entity_types_client_example_test.go index d3454daae73e..ba1201c0535b 100644 --- a/dialogflow/cx/apiv3beta1/session_entity_types_client_example_test.go +++ b/dialogflow/cx/apiv3beta1/session_entity_types_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/sessions_client.go b/dialogflow/cx/apiv3beta1/sessions_client.go index 700a92a26dfd..cc59b49d116d 100755 --- a/dialogflow/cx/apiv3beta1/sessions_client.go +++ b/dialogflow/cx/apiv3beta1/sessions_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/sessions_client_example_go123_test.go b/dialogflow/cx/apiv3beta1/sessions_client_example_go123_test.go index 085419026ac8..cbee6894c469 100644 --- a/dialogflow/cx/apiv3beta1/sessions_client_example_go123_test.go +++ b/dialogflow/cx/apiv3beta1/sessions_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/sessions_client_example_test.go b/dialogflow/cx/apiv3beta1/sessions_client_example_test.go index 0087f64222d8..3c34ddfc94fb 100644 --- a/dialogflow/cx/apiv3beta1/sessions_client_example_test.go +++ b/dialogflow/cx/apiv3beta1/sessions_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/test_cases_client.go b/dialogflow/cx/apiv3beta1/test_cases_client.go index 2c6c95947c53..01f65367cf09 100755 --- a/dialogflow/cx/apiv3beta1/test_cases_client.go +++ b/dialogflow/cx/apiv3beta1/test_cases_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/test_cases_client_example_go123_test.go b/dialogflow/cx/apiv3beta1/test_cases_client_example_go123_test.go index 7699a5109f9d..94408f7f044f 100644 --- a/dialogflow/cx/apiv3beta1/test_cases_client_example_go123_test.go +++ b/dialogflow/cx/apiv3beta1/test_cases_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/test_cases_client_example_test.go b/dialogflow/cx/apiv3beta1/test_cases_client_example_test.go index 8cc185cad043..ba8c9e634a8a 100644 --- a/dialogflow/cx/apiv3beta1/test_cases_client_example_test.go +++ b/dialogflow/cx/apiv3beta1/test_cases_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/tools_client.go b/dialogflow/cx/apiv3beta1/tools_client.go index 107a8a2281a6..717635aa2fb7 100755 --- a/dialogflow/cx/apiv3beta1/tools_client.go +++ b/dialogflow/cx/apiv3beta1/tools_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/tools_client_example_go123_test.go b/dialogflow/cx/apiv3beta1/tools_client_example_go123_test.go index a8b792d5f77e..76c44e643914 100644 --- a/dialogflow/cx/apiv3beta1/tools_client_example_go123_test.go +++ b/dialogflow/cx/apiv3beta1/tools_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/tools_client_example_test.go b/dialogflow/cx/apiv3beta1/tools_client_example_test.go index 2138c34d42b2..750b0c150480 100644 --- a/dialogflow/cx/apiv3beta1/tools_client_example_test.go +++ b/dialogflow/cx/apiv3beta1/tools_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/transition_route_groups_client.go b/dialogflow/cx/apiv3beta1/transition_route_groups_client.go index a7e4efa933d4..1f841e5a3a1d 100755 --- a/dialogflow/cx/apiv3beta1/transition_route_groups_client.go +++ b/dialogflow/cx/apiv3beta1/transition_route_groups_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/transition_route_groups_client_example_go123_test.go b/dialogflow/cx/apiv3beta1/transition_route_groups_client_example_go123_test.go index c1c0fe10eb63..333f938155d7 100644 --- a/dialogflow/cx/apiv3beta1/transition_route_groups_client_example_go123_test.go +++ b/dialogflow/cx/apiv3beta1/transition_route_groups_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/transition_route_groups_client_example_test.go b/dialogflow/cx/apiv3beta1/transition_route_groups_client_example_test.go index dc16afa066e1..38b121119144 100644 --- a/dialogflow/cx/apiv3beta1/transition_route_groups_client_example_test.go +++ b/dialogflow/cx/apiv3beta1/transition_route_groups_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/versions_client.go b/dialogflow/cx/apiv3beta1/versions_client.go index 2f388efb4e5f..3512f405cc73 100755 --- a/dialogflow/cx/apiv3beta1/versions_client.go +++ b/dialogflow/cx/apiv3beta1/versions_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/versions_client_example_go123_test.go b/dialogflow/cx/apiv3beta1/versions_client_example_go123_test.go index ff3ced867027..aae077b33275 100644 --- a/dialogflow/cx/apiv3beta1/versions_client_example_go123_test.go +++ b/dialogflow/cx/apiv3beta1/versions_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/versions_client_example_test.go b/dialogflow/cx/apiv3beta1/versions_client_example_test.go index 8c7928cbaf94..b2c7a1ac5bea 100644 --- a/dialogflow/cx/apiv3beta1/versions_client_example_test.go +++ b/dialogflow/cx/apiv3beta1/versions_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/webhooks_client.go b/dialogflow/cx/apiv3beta1/webhooks_client.go index 32c3c9c49bd7..f7f9a8950c38 100755 --- a/dialogflow/cx/apiv3beta1/webhooks_client.go +++ b/dialogflow/cx/apiv3beta1/webhooks_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/webhooks_client_example_go123_test.go b/dialogflow/cx/apiv3beta1/webhooks_client_example_go123_test.go index e51acced3473..44a7d04aa155 100644 --- a/dialogflow/cx/apiv3beta1/webhooks_client_example_go123_test.go +++ b/dialogflow/cx/apiv3beta1/webhooks_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dialogflow/cx/apiv3beta1/webhooks_client_example_test.go b/dialogflow/cx/apiv3beta1/webhooks_client_example_test.go index b2f6fe6be7b8..3f1934d81b7b 100644 --- a/dialogflow/cx/apiv3beta1/webhooks_client_example_test.go +++ b/dialogflow/cx/apiv3beta1/webhooks_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/auxiliary.go b/discoveryengine/apiv1/auxiliary.go index 071d58b6b6c0..fc0caa460ba7 100755 --- a/discoveryengine/apiv1/auxiliary.go +++ b/discoveryengine/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/auxiliary_go123.go b/discoveryengine/apiv1/auxiliary_go123.go index 8994526eda95..1a7c3f047fc9 100755 --- a/discoveryengine/apiv1/auxiliary_go123.go +++ b/discoveryengine/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/completion_client.go b/discoveryengine/apiv1/completion_client.go index d531219ce87b..7241468e5637 100755 --- a/discoveryengine/apiv1/completion_client.go +++ b/discoveryengine/apiv1/completion_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/completion_client_example_go123_test.go b/discoveryengine/apiv1/completion_client_example_go123_test.go index 0385001d8220..d2bc151f457e 100644 --- a/discoveryengine/apiv1/completion_client_example_go123_test.go +++ b/discoveryengine/apiv1/completion_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/completion_client_example_test.go b/discoveryengine/apiv1/completion_client_example_test.go index e9d1da89cc2a..91d7a96bb504 100644 --- a/discoveryengine/apiv1/completion_client_example_test.go +++ b/discoveryengine/apiv1/completion_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/control_client.go b/discoveryengine/apiv1/control_client.go index 11bdd7379d2e..32553894dbe4 100755 --- a/discoveryengine/apiv1/control_client.go +++ b/discoveryengine/apiv1/control_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/control_client_example_go123_test.go b/discoveryengine/apiv1/control_client_example_go123_test.go index e4c69798067c..3b834dcdacd8 100644 --- a/discoveryengine/apiv1/control_client_example_go123_test.go +++ b/discoveryengine/apiv1/control_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/control_client_example_test.go b/discoveryengine/apiv1/control_client_example_test.go index 954b656f6761..4432a751d48f 100644 --- a/discoveryengine/apiv1/control_client_example_test.go +++ b/discoveryengine/apiv1/control_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/conversational_search_client.go b/discoveryengine/apiv1/conversational_search_client.go index daf2c6af7c6e..edc86019632c 100755 --- a/discoveryengine/apiv1/conversational_search_client.go +++ b/discoveryengine/apiv1/conversational_search_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/conversational_search_client_example_go123_test.go b/discoveryengine/apiv1/conversational_search_client_example_go123_test.go index 528a18279f86..11351ba8d55d 100644 --- a/discoveryengine/apiv1/conversational_search_client_example_go123_test.go +++ b/discoveryengine/apiv1/conversational_search_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/conversational_search_client_example_test.go b/discoveryengine/apiv1/conversational_search_client_example_test.go index 65575bb2ce74..695bc5da63e6 100644 --- a/discoveryengine/apiv1/conversational_search_client_example_test.go +++ b/discoveryengine/apiv1/conversational_search_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/data_store_client.go b/discoveryengine/apiv1/data_store_client.go index 53e43376e1d0..ec0c3cce9963 100755 --- a/discoveryengine/apiv1/data_store_client.go +++ b/discoveryengine/apiv1/data_store_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/data_store_client_example_go123_test.go b/discoveryengine/apiv1/data_store_client_example_go123_test.go index 89f89a9a780b..dc0527119dba 100644 --- a/discoveryengine/apiv1/data_store_client_example_go123_test.go +++ b/discoveryengine/apiv1/data_store_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/data_store_client_example_test.go b/discoveryengine/apiv1/data_store_client_example_test.go index 85ea6384f926..73e55b328083 100644 --- a/discoveryengine/apiv1/data_store_client_example_test.go +++ b/discoveryengine/apiv1/data_store_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/doc.go b/discoveryengine/apiv1/doc.go index 6367294601ce..adc033edf73c 100755 --- a/discoveryengine/apiv1/doc.go +++ b/discoveryengine/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/document_client.go b/discoveryengine/apiv1/document_client.go index 75c92cac4c09..5337701bb57b 100755 --- a/discoveryengine/apiv1/document_client.go +++ b/discoveryengine/apiv1/document_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/document_client_example_go123_test.go b/discoveryengine/apiv1/document_client_example_go123_test.go index bc739181c6ab..7ef2ae12a1b3 100644 --- a/discoveryengine/apiv1/document_client_example_go123_test.go +++ b/discoveryengine/apiv1/document_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/document_client_example_test.go b/discoveryengine/apiv1/document_client_example_test.go index ca6efc275956..c23ddd2535bb 100644 --- a/discoveryengine/apiv1/document_client_example_test.go +++ b/discoveryengine/apiv1/document_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/engine_client.go b/discoveryengine/apiv1/engine_client.go index 686d3d948a64..de89c7d408ea 100755 --- a/discoveryengine/apiv1/engine_client.go +++ b/discoveryengine/apiv1/engine_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/engine_client_example_go123_test.go b/discoveryengine/apiv1/engine_client_example_go123_test.go index 827554776346..351c9f0b5063 100644 --- a/discoveryengine/apiv1/engine_client_example_go123_test.go +++ b/discoveryengine/apiv1/engine_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/engine_client_example_test.go b/discoveryengine/apiv1/engine_client_example_test.go index ea32b0911203..a3a82295d60d 100644 --- a/discoveryengine/apiv1/engine_client_example_test.go +++ b/discoveryengine/apiv1/engine_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/grounded_generation_client.go b/discoveryengine/apiv1/grounded_generation_client.go index 589fb1123b11..947e69d43931 100755 --- a/discoveryengine/apiv1/grounded_generation_client.go +++ b/discoveryengine/apiv1/grounded_generation_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/grounded_generation_client_example_go123_test.go b/discoveryengine/apiv1/grounded_generation_client_example_go123_test.go index 4009419e4da7..1ad0d0d80d65 100644 --- a/discoveryengine/apiv1/grounded_generation_client_example_go123_test.go +++ b/discoveryengine/apiv1/grounded_generation_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/grounded_generation_client_example_test.go b/discoveryengine/apiv1/grounded_generation_client_example_test.go index f4e7c3149197..269bcde39a60 100644 --- a/discoveryengine/apiv1/grounded_generation_client_example_test.go +++ b/discoveryengine/apiv1/grounded_generation_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/helpers.go b/discoveryengine/apiv1/helpers.go index bbd882c8f9de..dd851b082643 100755 --- a/discoveryengine/apiv1/helpers.go +++ b/discoveryengine/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/project_client.go b/discoveryengine/apiv1/project_client.go index 293f12e075bc..9088e6760185 100755 --- a/discoveryengine/apiv1/project_client.go +++ b/discoveryengine/apiv1/project_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/project_client_example_go123_test.go b/discoveryengine/apiv1/project_client_example_go123_test.go index 892de0fbf5e9..a651a80460af 100644 --- a/discoveryengine/apiv1/project_client_example_go123_test.go +++ b/discoveryengine/apiv1/project_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/project_client_example_test.go b/discoveryengine/apiv1/project_client_example_test.go index 6837fe1baca2..0a4601bbf863 100644 --- a/discoveryengine/apiv1/project_client_example_test.go +++ b/discoveryengine/apiv1/project_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/rank_client.go b/discoveryengine/apiv1/rank_client.go index 1ce6b83c3c31..07f1b7892bd0 100755 --- a/discoveryengine/apiv1/rank_client.go +++ b/discoveryengine/apiv1/rank_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/rank_client_example_go123_test.go b/discoveryengine/apiv1/rank_client_example_go123_test.go index 899b5eb6c5c9..dd1e05143e11 100644 --- a/discoveryengine/apiv1/rank_client_example_go123_test.go +++ b/discoveryengine/apiv1/rank_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/rank_client_example_test.go b/discoveryengine/apiv1/rank_client_example_test.go index 8492ebd7a23e..d320fda2198b 100644 --- a/discoveryengine/apiv1/rank_client_example_test.go +++ b/discoveryengine/apiv1/rank_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/recommendation_client.go b/discoveryengine/apiv1/recommendation_client.go index 3feecce3c0ad..0bb30ad599e5 100755 --- a/discoveryengine/apiv1/recommendation_client.go +++ b/discoveryengine/apiv1/recommendation_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/recommendation_client_example_go123_test.go b/discoveryengine/apiv1/recommendation_client_example_go123_test.go index fc4d1cc7697f..e420de94e75c 100644 --- a/discoveryengine/apiv1/recommendation_client_example_go123_test.go +++ b/discoveryengine/apiv1/recommendation_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/recommendation_client_example_test.go b/discoveryengine/apiv1/recommendation_client_example_test.go index abfd696e98ab..62cdbac51cc9 100644 --- a/discoveryengine/apiv1/recommendation_client_example_test.go +++ b/discoveryengine/apiv1/recommendation_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/schema_client.go b/discoveryengine/apiv1/schema_client.go index b3d2e73d8de2..7339037a4491 100755 --- a/discoveryengine/apiv1/schema_client.go +++ b/discoveryengine/apiv1/schema_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/schema_client_example_go123_test.go b/discoveryengine/apiv1/schema_client_example_go123_test.go index 07ebaf236e31..a9cf07deca14 100644 --- a/discoveryengine/apiv1/schema_client_example_go123_test.go +++ b/discoveryengine/apiv1/schema_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/schema_client_example_test.go b/discoveryengine/apiv1/schema_client_example_test.go index 685d77c866bf..f82a01809f64 100644 --- a/discoveryengine/apiv1/schema_client_example_test.go +++ b/discoveryengine/apiv1/schema_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/search_client.go b/discoveryengine/apiv1/search_client.go index 3f20017839fc..9ad5c4af85ab 100755 --- a/discoveryengine/apiv1/search_client.go +++ b/discoveryengine/apiv1/search_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/search_client_example_go123_test.go b/discoveryengine/apiv1/search_client_example_go123_test.go index f085fd48aef8..5dd0f165a67b 100644 --- a/discoveryengine/apiv1/search_client_example_go123_test.go +++ b/discoveryengine/apiv1/search_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/search_client_example_test.go b/discoveryengine/apiv1/search_client_example_test.go index c44e8c69790b..3d72e8a17936 100644 --- a/discoveryengine/apiv1/search_client_example_test.go +++ b/discoveryengine/apiv1/search_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/search_tuning_client.go b/discoveryengine/apiv1/search_tuning_client.go index 648497cdbfe7..177fc5f5420e 100755 --- a/discoveryengine/apiv1/search_tuning_client.go +++ b/discoveryengine/apiv1/search_tuning_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/search_tuning_client_example_go123_test.go b/discoveryengine/apiv1/search_tuning_client_example_go123_test.go index 58a0224ba053..1142f86e41b3 100644 --- a/discoveryengine/apiv1/search_tuning_client_example_go123_test.go +++ b/discoveryengine/apiv1/search_tuning_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/search_tuning_client_example_test.go b/discoveryengine/apiv1/search_tuning_client_example_test.go index 426c2218b129..58c94f298f43 100644 --- a/discoveryengine/apiv1/search_tuning_client_example_test.go +++ b/discoveryengine/apiv1/search_tuning_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/site_search_engine_client.go b/discoveryengine/apiv1/site_search_engine_client.go index 1e755ce52bf4..a6a1fb201dc5 100755 --- a/discoveryengine/apiv1/site_search_engine_client.go +++ b/discoveryengine/apiv1/site_search_engine_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/site_search_engine_client_example_go123_test.go b/discoveryengine/apiv1/site_search_engine_client_example_go123_test.go index 4db63a48a7f1..57c008d1293b 100644 --- a/discoveryengine/apiv1/site_search_engine_client_example_go123_test.go +++ b/discoveryengine/apiv1/site_search_engine_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/site_search_engine_client_example_test.go b/discoveryengine/apiv1/site_search_engine_client_example_test.go index 0927e20b6a62..c3a47d46d761 100644 --- a/discoveryengine/apiv1/site_search_engine_client_example_test.go +++ b/discoveryengine/apiv1/site_search_engine_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/user_event_client.go b/discoveryengine/apiv1/user_event_client.go index 57b29d5bbe54..25fa26b41e0c 100755 --- a/discoveryengine/apiv1/user_event_client.go +++ b/discoveryengine/apiv1/user_event_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/user_event_client_example_go123_test.go b/discoveryengine/apiv1/user_event_client_example_go123_test.go index 268f9ada1e65..58a90e66ca30 100644 --- a/discoveryengine/apiv1/user_event_client_example_go123_test.go +++ b/discoveryengine/apiv1/user_event_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1/user_event_client_example_test.go b/discoveryengine/apiv1/user_event_client_example_test.go index 3fc9ca12e8c4..210b96ef7e5a 100644 --- a/discoveryengine/apiv1/user_event_client_example_test.go +++ b/discoveryengine/apiv1/user_event_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/acl_config_client.go b/discoveryengine/apiv1alpha/acl_config_client.go index 3e4dd7791740..cafcc50b3a41 100755 --- a/discoveryengine/apiv1alpha/acl_config_client.go +++ b/discoveryengine/apiv1alpha/acl_config_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/acl_config_client_example_go123_test.go b/discoveryengine/apiv1alpha/acl_config_client_example_go123_test.go index 108b2bbd7790..33161c6e7dbe 100644 --- a/discoveryengine/apiv1alpha/acl_config_client_example_go123_test.go +++ b/discoveryengine/apiv1alpha/acl_config_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/acl_config_client_example_test.go b/discoveryengine/apiv1alpha/acl_config_client_example_test.go index 1c39f31c6054..982b17717d6e 100644 --- a/discoveryengine/apiv1alpha/acl_config_client_example_test.go +++ b/discoveryengine/apiv1alpha/acl_config_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/auxiliary.go b/discoveryengine/apiv1alpha/auxiliary.go index 31c0f8f43d42..0b21396dbb13 100755 --- a/discoveryengine/apiv1alpha/auxiliary.go +++ b/discoveryengine/apiv1alpha/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/auxiliary_go123.go b/discoveryengine/apiv1alpha/auxiliary_go123.go index 5912d70ea5d3..16941b77a354 100755 --- a/discoveryengine/apiv1alpha/auxiliary_go123.go +++ b/discoveryengine/apiv1alpha/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/chunk_client.go b/discoveryengine/apiv1alpha/chunk_client.go index 8680c04d5dc5..6496310d1df3 100755 --- a/discoveryengine/apiv1alpha/chunk_client.go +++ b/discoveryengine/apiv1alpha/chunk_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/chunk_client_example_go123_test.go b/discoveryengine/apiv1alpha/chunk_client_example_go123_test.go index a954de367fc5..3f7746d89f19 100644 --- a/discoveryengine/apiv1alpha/chunk_client_example_go123_test.go +++ b/discoveryengine/apiv1alpha/chunk_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/chunk_client_example_test.go b/discoveryengine/apiv1alpha/chunk_client_example_test.go index 03a6f51adde2..930239477e4b 100644 --- a/discoveryengine/apiv1alpha/chunk_client_example_test.go +++ b/discoveryengine/apiv1alpha/chunk_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/completion_client.go b/discoveryengine/apiv1alpha/completion_client.go index 397e69d2ddf1..7fb76abff93d 100755 --- a/discoveryengine/apiv1alpha/completion_client.go +++ b/discoveryengine/apiv1alpha/completion_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/completion_client_example_go123_test.go b/discoveryengine/apiv1alpha/completion_client_example_go123_test.go index 8bb814067558..d4a506ce2846 100644 --- a/discoveryengine/apiv1alpha/completion_client_example_go123_test.go +++ b/discoveryengine/apiv1alpha/completion_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/completion_client_example_test.go b/discoveryengine/apiv1alpha/completion_client_example_test.go index 10d56481febe..ae94eb34fb63 100644 --- a/discoveryengine/apiv1alpha/completion_client_example_test.go +++ b/discoveryengine/apiv1alpha/completion_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/control_client.go b/discoveryengine/apiv1alpha/control_client.go index dd09061a910a..759052e713be 100755 --- a/discoveryengine/apiv1alpha/control_client.go +++ b/discoveryengine/apiv1alpha/control_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/control_client_example_go123_test.go b/discoveryengine/apiv1alpha/control_client_example_go123_test.go index 161eb6bfd98a..31f2c7e94643 100644 --- a/discoveryengine/apiv1alpha/control_client_example_go123_test.go +++ b/discoveryengine/apiv1alpha/control_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/control_client_example_test.go b/discoveryengine/apiv1alpha/control_client_example_test.go index 973a05503675..afd6490062ce 100644 --- a/discoveryengine/apiv1alpha/control_client_example_test.go +++ b/discoveryengine/apiv1alpha/control_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/conversational_search_client.go b/discoveryengine/apiv1alpha/conversational_search_client.go index 7dc41eb0fe17..25842f2f9732 100755 --- a/discoveryengine/apiv1alpha/conversational_search_client.go +++ b/discoveryengine/apiv1alpha/conversational_search_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/conversational_search_client_example_go123_test.go b/discoveryengine/apiv1alpha/conversational_search_client_example_go123_test.go index f0904f9cb0ce..fe7d3f93ed5c 100644 --- a/discoveryengine/apiv1alpha/conversational_search_client_example_go123_test.go +++ b/discoveryengine/apiv1alpha/conversational_search_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/conversational_search_client_example_test.go b/discoveryengine/apiv1alpha/conversational_search_client_example_test.go index 9d60c720b3fb..f82b0198e6a3 100644 --- a/discoveryengine/apiv1alpha/conversational_search_client_example_test.go +++ b/discoveryengine/apiv1alpha/conversational_search_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/data_store_client.go b/discoveryengine/apiv1alpha/data_store_client.go index cf2eda2fac57..12bf58649e02 100755 --- a/discoveryengine/apiv1alpha/data_store_client.go +++ b/discoveryengine/apiv1alpha/data_store_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/data_store_client_example_go123_test.go b/discoveryengine/apiv1alpha/data_store_client_example_go123_test.go index 4a9389caa9d9..570e3bf39712 100644 --- a/discoveryengine/apiv1alpha/data_store_client_example_go123_test.go +++ b/discoveryengine/apiv1alpha/data_store_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/data_store_client_example_test.go b/discoveryengine/apiv1alpha/data_store_client_example_test.go index b0f113330573..58aec0a83a99 100644 --- a/discoveryengine/apiv1alpha/data_store_client_example_test.go +++ b/discoveryengine/apiv1alpha/data_store_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/doc.go b/discoveryengine/apiv1alpha/doc.go index ca421bb27f3b..1295e825823d 100755 --- a/discoveryengine/apiv1alpha/doc.go +++ b/discoveryengine/apiv1alpha/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/document_client.go b/discoveryengine/apiv1alpha/document_client.go index 106e4ea91aa8..722eaf1b773d 100755 --- a/discoveryengine/apiv1alpha/document_client.go +++ b/discoveryengine/apiv1alpha/document_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/document_client_example_go123_test.go b/discoveryengine/apiv1alpha/document_client_example_go123_test.go index 02c8b882ecd6..26ef1d40619b 100644 --- a/discoveryengine/apiv1alpha/document_client_example_go123_test.go +++ b/discoveryengine/apiv1alpha/document_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/document_client_example_test.go b/discoveryengine/apiv1alpha/document_client_example_test.go index d19da5670615..a80241b261f8 100644 --- a/discoveryengine/apiv1alpha/document_client_example_test.go +++ b/discoveryengine/apiv1alpha/document_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/engine_client.go b/discoveryengine/apiv1alpha/engine_client.go index cbbb4e074c3e..24d1c3234050 100755 --- a/discoveryengine/apiv1alpha/engine_client.go +++ b/discoveryengine/apiv1alpha/engine_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/engine_client_example_go123_test.go b/discoveryengine/apiv1alpha/engine_client_example_go123_test.go index b81a0aea0c7b..8571400ca6d6 100644 --- a/discoveryengine/apiv1alpha/engine_client_example_go123_test.go +++ b/discoveryengine/apiv1alpha/engine_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/engine_client_example_test.go b/discoveryengine/apiv1alpha/engine_client_example_test.go index ddcb871b15d7..c643c44fd453 100644 --- a/discoveryengine/apiv1alpha/engine_client_example_test.go +++ b/discoveryengine/apiv1alpha/engine_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/estimate_billing_client.go b/discoveryengine/apiv1alpha/estimate_billing_client.go index dde4971e1661..451bca002563 100755 --- a/discoveryengine/apiv1alpha/estimate_billing_client.go +++ b/discoveryengine/apiv1alpha/estimate_billing_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/estimate_billing_client_example_go123_test.go b/discoveryengine/apiv1alpha/estimate_billing_client_example_go123_test.go index 79dcbee05a82..a070d4aa5a9e 100644 --- a/discoveryengine/apiv1alpha/estimate_billing_client_example_go123_test.go +++ b/discoveryengine/apiv1alpha/estimate_billing_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/estimate_billing_client_example_test.go b/discoveryengine/apiv1alpha/estimate_billing_client_example_test.go index 7ffd312ea37f..04316d255a19 100644 --- a/discoveryengine/apiv1alpha/estimate_billing_client_example_test.go +++ b/discoveryengine/apiv1alpha/estimate_billing_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/evaluation_client.go b/discoveryengine/apiv1alpha/evaluation_client.go index c8b574970caa..4872ad8207d9 100755 --- a/discoveryengine/apiv1alpha/evaluation_client.go +++ b/discoveryengine/apiv1alpha/evaluation_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/evaluation_client_example_go123_test.go b/discoveryengine/apiv1alpha/evaluation_client_example_go123_test.go index 0bd958bc470b..733d83eac68e 100644 --- a/discoveryengine/apiv1alpha/evaluation_client_example_go123_test.go +++ b/discoveryengine/apiv1alpha/evaluation_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/evaluation_client_example_test.go b/discoveryengine/apiv1alpha/evaluation_client_example_test.go index 780cf0194863..9eafde31be98 100644 --- a/discoveryengine/apiv1alpha/evaluation_client_example_test.go +++ b/discoveryengine/apiv1alpha/evaluation_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/grounded_generation_client.go b/discoveryengine/apiv1alpha/grounded_generation_client.go index c0970c4af2b2..c24f2ef39c2c 100755 --- a/discoveryengine/apiv1alpha/grounded_generation_client.go +++ b/discoveryengine/apiv1alpha/grounded_generation_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/grounded_generation_client_example_go123_test.go b/discoveryengine/apiv1alpha/grounded_generation_client_example_go123_test.go index 907c94e4b647..13c800b40b30 100644 --- a/discoveryengine/apiv1alpha/grounded_generation_client_example_go123_test.go +++ b/discoveryengine/apiv1alpha/grounded_generation_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/grounded_generation_client_example_test.go b/discoveryengine/apiv1alpha/grounded_generation_client_example_test.go index a5cc983d5bcb..2bf794ad8968 100644 --- a/discoveryengine/apiv1alpha/grounded_generation_client_example_test.go +++ b/discoveryengine/apiv1alpha/grounded_generation_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/helpers.go b/discoveryengine/apiv1alpha/helpers.go index bbd882c8f9de..dd851b082643 100755 --- a/discoveryengine/apiv1alpha/helpers.go +++ b/discoveryengine/apiv1alpha/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/project_client.go b/discoveryengine/apiv1alpha/project_client.go index b28c7291f57c..b0ec37b5b8a5 100755 --- a/discoveryengine/apiv1alpha/project_client.go +++ b/discoveryengine/apiv1alpha/project_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/project_client_example_go123_test.go b/discoveryengine/apiv1alpha/project_client_example_go123_test.go index d736b4e9f916..ac9bc0b9b161 100644 --- a/discoveryengine/apiv1alpha/project_client_example_go123_test.go +++ b/discoveryengine/apiv1alpha/project_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/project_client_example_test.go b/discoveryengine/apiv1alpha/project_client_example_test.go index 98ff4cea2141..234e211a2baa 100644 --- a/discoveryengine/apiv1alpha/project_client_example_test.go +++ b/discoveryengine/apiv1alpha/project_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/rank_client.go b/discoveryengine/apiv1alpha/rank_client.go index 927e68d972b7..adfcf245ea7a 100755 --- a/discoveryengine/apiv1alpha/rank_client.go +++ b/discoveryengine/apiv1alpha/rank_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/rank_client_example_go123_test.go b/discoveryengine/apiv1alpha/rank_client_example_go123_test.go index dc4a0ae03e4e..080f96718645 100644 --- a/discoveryengine/apiv1alpha/rank_client_example_go123_test.go +++ b/discoveryengine/apiv1alpha/rank_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/rank_client_example_test.go b/discoveryengine/apiv1alpha/rank_client_example_test.go index 9a1be22e1c20..e8f77f2b0165 100644 --- a/discoveryengine/apiv1alpha/rank_client_example_test.go +++ b/discoveryengine/apiv1alpha/rank_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/recommendation_client.go b/discoveryengine/apiv1alpha/recommendation_client.go index 72d8c4a0f6c0..a1aa704d7d7f 100755 --- a/discoveryengine/apiv1alpha/recommendation_client.go +++ b/discoveryengine/apiv1alpha/recommendation_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/recommendation_client_example_go123_test.go b/discoveryengine/apiv1alpha/recommendation_client_example_go123_test.go index 52b9e3b33be0..0549ad72f498 100644 --- a/discoveryengine/apiv1alpha/recommendation_client_example_go123_test.go +++ b/discoveryengine/apiv1alpha/recommendation_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/recommendation_client_example_test.go b/discoveryengine/apiv1alpha/recommendation_client_example_test.go index 4feaabb700be..e57abeea6a99 100644 --- a/discoveryengine/apiv1alpha/recommendation_client_example_test.go +++ b/discoveryengine/apiv1alpha/recommendation_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/sample_query_client.go b/discoveryengine/apiv1alpha/sample_query_client.go index ce47405f4e26..687ee99c7649 100755 --- a/discoveryengine/apiv1alpha/sample_query_client.go +++ b/discoveryengine/apiv1alpha/sample_query_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/sample_query_client_example_go123_test.go b/discoveryengine/apiv1alpha/sample_query_client_example_go123_test.go index d56f3b87b6cf..547fb6913cb0 100644 --- a/discoveryengine/apiv1alpha/sample_query_client_example_go123_test.go +++ b/discoveryengine/apiv1alpha/sample_query_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/sample_query_client_example_test.go b/discoveryengine/apiv1alpha/sample_query_client_example_test.go index 3ff260d5c3ab..96265df310be 100644 --- a/discoveryengine/apiv1alpha/sample_query_client_example_test.go +++ b/discoveryengine/apiv1alpha/sample_query_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/sample_query_set_client.go b/discoveryengine/apiv1alpha/sample_query_set_client.go index 085865925e09..8345b64de75c 100755 --- a/discoveryengine/apiv1alpha/sample_query_set_client.go +++ b/discoveryengine/apiv1alpha/sample_query_set_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/sample_query_set_client_example_go123_test.go b/discoveryengine/apiv1alpha/sample_query_set_client_example_go123_test.go index e1d46d80108d..6ddbdbc1a1e6 100644 --- a/discoveryengine/apiv1alpha/sample_query_set_client_example_go123_test.go +++ b/discoveryengine/apiv1alpha/sample_query_set_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/sample_query_set_client_example_test.go b/discoveryengine/apiv1alpha/sample_query_set_client_example_test.go index 625455a5a82c..2690504a4cfa 100644 --- a/discoveryengine/apiv1alpha/sample_query_set_client_example_test.go +++ b/discoveryengine/apiv1alpha/sample_query_set_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/schema_client.go b/discoveryengine/apiv1alpha/schema_client.go index 62314471a851..dc94f0c53364 100755 --- a/discoveryengine/apiv1alpha/schema_client.go +++ b/discoveryengine/apiv1alpha/schema_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/schema_client_example_go123_test.go b/discoveryengine/apiv1alpha/schema_client_example_go123_test.go index ffbfe41b34ab..4b4a2daf76d4 100644 --- a/discoveryengine/apiv1alpha/schema_client_example_go123_test.go +++ b/discoveryengine/apiv1alpha/schema_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/schema_client_example_test.go b/discoveryengine/apiv1alpha/schema_client_example_test.go index fbe10cf54896..816299110117 100644 --- a/discoveryengine/apiv1alpha/schema_client_example_test.go +++ b/discoveryengine/apiv1alpha/schema_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/search_client.go b/discoveryengine/apiv1alpha/search_client.go index 632e93173ebe..f6dbf6dbda4d 100755 --- a/discoveryengine/apiv1alpha/search_client.go +++ b/discoveryengine/apiv1alpha/search_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/search_client_example_go123_test.go b/discoveryengine/apiv1alpha/search_client_example_go123_test.go index be85cbf08032..b37720eb5255 100644 --- a/discoveryengine/apiv1alpha/search_client_example_go123_test.go +++ b/discoveryengine/apiv1alpha/search_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/search_client_example_test.go b/discoveryengine/apiv1alpha/search_client_example_test.go index 6f068d7075aa..a76ea68dd236 100644 --- a/discoveryengine/apiv1alpha/search_client_example_test.go +++ b/discoveryengine/apiv1alpha/search_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/search_tuning_client.go b/discoveryengine/apiv1alpha/search_tuning_client.go index 0691c960c869..1810daed0b8e 100755 --- a/discoveryengine/apiv1alpha/search_tuning_client.go +++ b/discoveryengine/apiv1alpha/search_tuning_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/search_tuning_client_example_go123_test.go b/discoveryengine/apiv1alpha/search_tuning_client_example_go123_test.go index 794a4d13fea5..49ee725040fe 100644 --- a/discoveryengine/apiv1alpha/search_tuning_client_example_go123_test.go +++ b/discoveryengine/apiv1alpha/search_tuning_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/search_tuning_client_example_test.go b/discoveryengine/apiv1alpha/search_tuning_client_example_test.go index 9ab240a4caf7..1acbe45c743c 100644 --- a/discoveryengine/apiv1alpha/search_tuning_client_example_test.go +++ b/discoveryengine/apiv1alpha/search_tuning_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/serving_config_client.go b/discoveryengine/apiv1alpha/serving_config_client.go index 14e9bcbd2b28..907ccb658d86 100755 --- a/discoveryengine/apiv1alpha/serving_config_client.go +++ b/discoveryengine/apiv1alpha/serving_config_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/serving_config_client_example_go123_test.go b/discoveryengine/apiv1alpha/serving_config_client_example_go123_test.go index 532031fcf8bd..188f61bc5e42 100644 --- a/discoveryengine/apiv1alpha/serving_config_client_example_go123_test.go +++ b/discoveryengine/apiv1alpha/serving_config_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/serving_config_client_example_test.go b/discoveryengine/apiv1alpha/serving_config_client_example_test.go index a02ee3e9c5f1..bfd7e466ea75 100644 --- a/discoveryengine/apiv1alpha/serving_config_client_example_test.go +++ b/discoveryengine/apiv1alpha/serving_config_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/site_search_engine_client.go b/discoveryengine/apiv1alpha/site_search_engine_client.go index 93349d8ce685..98064469b9c8 100755 --- a/discoveryengine/apiv1alpha/site_search_engine_client.go +++ b/discoveryengine/apiv1alpha/site_search_engine_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/site_search_engine_client_example_go123_test.go b/discoveryengine/apiv1alpha/site_search_engine_client_example_go123_test.go index bff74b5acc29..3dcc1bd05863 100644 --- a/discoveryengine/apiv1alpha/site_search_engine_client_example_go123_test.go +++ b/discoveryengine/apiv1alpha/site_search_engine_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/site_search_engine_client_example_test.go b/discoveryengine/apiv1alpha/site_search_engine_client_example_test.go index a5f82b94d92f..fdd1fe6b810c 100644 --- a/discoveryengine/apiv1alpha/site_search_engine_client_example_test.go +++ b/discoveryengine/apiv1alpha/site_search_engine_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/user_event_client.go b/discoveryengine/apiv1alpha/user_event_client.go index db1d277e76a1..ce5b12ab3061 100755 --- a/discoveryengine/apiv1alpha/user_event_client.go +++ b/discoveryengine/apiv1alpha/user_event_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/user_event_client_example_go123_test.go b/discoveryengine/apiv1alpha/user_event_client_example_go123_test.go index 9f41a620562b..54d0ab5d68db 100644 --- a/discoveryengine/apiv1alpha/user_event_client_example_go123_test.go +++ b/discoveryengine/apiv1alpha/user_event_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1alpha/user_event_client_example_test.go b/discoveryengine/apiv1alpha/user_event_client_example_test.go index 8ce11f40bdfe..11180c716592 100644 --- a/discoveryengine/apiv1alpha/user_event_client_example_test.go +++ b/discoveryengine/apiv1alpha/user_event_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/auxiliary.go b/discoveryengine/apiv1beta/auxiliary.go index 90dc9169ec06..9da6d2c86fee 100755 --- a/discoveryengine/apiv1beta/auxiliary.go +++ b/discoveryengine/apiv1beta/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/auxiliary_go123.go b/discoveryengine/apiv1beta/auxiliary_go123.go index 571d6a3d1591..00a6a396e26f 100755 --- a/discoveryengine/apiv1beta/auxiliary_go123.go +++ b/discoveryengine/apiv1beta/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/completion_client.go b/discoveryengine/apiv1beta/completion_client.go index 5fbcc93fa262..e00421efb611 100755 --- a/discoveryengine/apiv1beta/completion_client.go +++ b/discoveryengine/apiv1beta/completion_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/completion_client_example_go123_test.go b/discoveryengine/apiv1beta/completion_client_example_go123_test.go index 41271b8367cf..d5a9194b868c 100644 --- a/discoveryengine/apiv1beta/completion_client_example_go123_test.go +++ b/discoveryengine/apiv1beta/completion_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/completion_client_example_test.go b/discoveryengine/apiv1beta/completion_client_example_test.go index d61513fec14a..a98095a613ef 100644 --- a/discoveryengine/apiv1beta/completion_client_example_test.go +++ b/discoveryengine/apiv1beta/completion_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/control_client.go b/discoveryengine/apiv1beta/control_client.go index 9d7701956d13..27fcd71683d5 100755 --- a/discoveryengine/apiv1beta/control_client.go +++ b/discoveryengine/apiv1beta/control_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/control_client_example_go123_test.go b/discoveryengine/apiv1beta/control_client_example_go123_test.go index af8065c742b7..047c3ec17b2c 100644 --- a/discoveryengine/apiv1beta/control_client_example_go123_test.go +++ b/discoveryengine/apiv1beta/control_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/control_client_example_test.go b/discoveryengine/apiv1beta/control_client_example_test.go index 578896c80abd..239d54b6542e 100644 --- a/discoveryengine/apiv1beta/control_client_example_test.go +++ b/discoveryengine/apiv1beta/control_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/conversational_search_client.go b/discoveryengine/apiv1beta/conversational_search_client.go index f6ec9f3c7acb..d0cfc675586d 100755 --- a/discoveryengine/apiv1beta/conversational_search_client.go +++ b/discoveryengine/apiv1beta/conversational_search_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/conversational_search_client_example_go123_test.go b/discoveryengine/apiv1beta/conversational_search_client_example_go123_test.go index 48b98cdca49c..b388dddb9cca 100644 --- a/discoveryengine/apiv1beta/conversational_search_client_example_go123_test.go +++ b/discoveryengine/apiv1beta/conversational_search_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/conversational_search_client_example_test.go b/discoveryengine/apiv1beta/conversational_search_client_example_test.go index 89ef18091350..e4f2a10361f2 100644 --- a/discoveryengine/apiv1beta/conversational_search_client_example_test.go +++ b/discoveryengine/apiv1beta/conversational_search_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/data_store_client.go b/discoveryengine/apiv1beta/data_store_client.go index d5e872e3bbad..704994592d64 100755 --- a/discoveryengine/apiv1beta/data_store_client.go +++ b/discoveryengine/apiv1beta/data_store_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/data_store_client_example_go123_test.go b/discoveryengine/apiv1beta/data_store_client_example_go123_test.go index b1e766424f9c..e71bb3cd10fe 100644 --- a/discoveryengine/apiv1beta/data_store_client_example_go123_test.go +++ b/discoveryengine/apiv1beta/data_store_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/data_store_client_example_test.go b/discoveryengine/apiv1beta/data_store_client_example_test.go index 60286fdc79b2..9802cccf42f0 100644 --- a/discoveryengine/apiv1beta/data_store_client_example_test.go +++ b/discoveryengine/apiv1beta/data_store_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/doc.go b/discoveryengine/apiv1beta/doc.go index 0f3f3232f8b1..0698c4b9675e 100755 --- a/discoveryengine/apiv1beta/doc.go +++ b/discoveryengine/apiv1beta/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/document_client.go b/discoveryengine/apiv1beta/document_client.go index 8b5f18537bc1..e4c872731930 100755 --- a/discoveryengine/apiv1beta/document_client.go +++ b/discoveryengine/apiv1beta/document_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/document_client_example_go123_test.go b/discoveryengine/apiv1beta/document_client_example_go123_test.go index f457c50f902d..7e44a136bae0 100644 --- a/discoveryengine/apiv1beta/document_client_example_go123_test.go +++ b/discoveryengine/apiv1beta/document_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/document_client_example_test.go b/discoveryengine/apiv1beta/document_client_example_test.go index fe908743c424..4f18243f7a56 100644 --- a/discoveryengine/apiv1beta/document_client_example_test.go +++ b/discoveryengine/apiv1beta/document_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/engine_client.go b/discoveryengine/apiv1beta/engine_client.go index 6995edc49d36..157851dbc56d 100755 --- a/discoveryengine/apiv1beta/engine_client.go +++ b/discoveryengine/apiv1beta/engine_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/engine_client_example_go123_test.go b/discoveryengine/apiv1beta/engine_client_example_go123_test.go index 7b0f25857102..478cfa36bf3f 100644 --- a/discoveryengine/apiv1beta/engine_client_example_go123_test.go +++ b/discoveryengine/apiv1beta/engine_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/engine_client_example_test.go b/discoveryengine/apiv1beta/engine_client_example_test.go index 4b4fc84bc35d..d208130e6612 100644 --- a/discoveryengine/apiv1beta/engine_client_example_test.go +++ b/discoveryengine/apiv1beta/engine_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/evaluation_client.go b/discoveryengine/apiv1beta/evaluation_client.go index 5a340fe8fcc3..32f3cdf771b8 100755 --- a/discoveryengine/apiv1beta/evaluation_client.go +++ b/discoveryengine/apiv1beta/evaluation_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/evaluation_client_example_go123_test.go b/discoveryengine/apiv1beta/evaluation_client_example_go123_test.go index 21bac74386f8..501ab6f7e696 100644 --- a/discoveryengine/apiv1beta/evaluation_client_example_go123_test.go +++ b/discoveryengine/apiv1beta/evaluation_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/evaluation_client_example_test.go b/discoveryengine/apiv1beta/evaluation_client_example_test.go index 084224faecb1..6bdd2e6c4a6c 100644 --- a/discoveryengine/apiv1beta/evaluation_client_example_test.go +++ b/discoveryengine/apiv1beta/evaluation_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/grounded_generation_client.go b/discoveryengine/apiv1beta/grounded_generation_client.go index fea2f946d6c7..a804cd0fa64b 100755 --- a/discoveryengine/apiv1beta/grounded_generation_client.go +++ b/discoveryengine/apiv1beta/grounded_generation_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/grounded_generation_client_example_go123_test.go b/discoveryengine/apiv1beta/grounded_generation_client_example_go123_test.go index 96fb118c9dcb..d4eaad2bb72e 100644 --- a/discoveryengine/apiv1beta/grounded_generation_client_example_go123_test.go +++ b/discoveryengine/apiv1beta/grounded_generation_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/grounded_generation_client_example_test.go b/discoveryengine/apiv1beta/grounded_generation_client_example_test.go index c2c469801e64..90ead0a5ec76 100644 --- a/discoveryengine/apiv1beta/grounded_generation_client_example_test.go +++ b/discoveryengine/apiv1beta/grounded_generation_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/helpers.go b/discoveryengine/apiv1beta/helpers.go index bbd882c8f9de..dd851b082643 100755 --- a/discoveryengine/apiv1beta/helpers.go +++ b/discoveryengine/apiv1beta/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/project_client.go b/discoveryengine/apiv1beta/project_client.go index e8a2d6a95ebc..37ed8d8a91b6 100755 --- a/discoveryengine/apiv1beta/project_client.go +++ b/discoveryengine/apiv1beta/project_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/project_client_example_go123_test.go b/discoveryengine/apiv1beta/project_client_example_go123_test.go index db8645a349e3..b890d4df0b6d 100644 --- a/discoveryengine/apiv1beta/project_client_example_go123_test.go +++ b/discoveryengine/apiv1beta/project_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/project_client_example_test.go b/discoveryengine/apiv1beta/project_client_example_test.go index 987d65cfdc60..1cd0f83a42b3 100644 --- a/discoveryengine/apiv1beta/project_client_example_test.go +++ b/discoveryengine/apiv1beta/project_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/rank_client.go b/discoveryengine/apiv1beta/rank_client.go index 15d2d56a3034..71aa09287836 100755 --- a/discoveryengine/apiv1beta/rank_client.go +++ b/discoveryengine/apiv1beta/rank_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/rank_client_example_go123_test.go b/discoveryengine/apiv1beta/rank_client_example_go123_test.go index 48e4f9441039..4a4b617fe7c2 100644 --- a/discoveryengine/apiv1beta/rank_client_example_go123_test.go +++ b/discoveryengine/apiv1beta/rank_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/rank_client_example_test.go b/discoveryengine/apiv1beta/rank_client_example_test.go index 9345324c0ba7..2da1f923dfa8 100644 --- a/discoveryengine/apiv1beta/rank_client_example_test.go +++ b/discoveryengine/apiv1beta/rank_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/recommendation_client.go b/discoveryengine/apiv1beta/recommendation_client.go index 6294a926b255..b75f0ffead6d 100755 --- a/discoveryengine/apiv1beta/recommendation_client.go +++ b/discoveryengine/apiv1beta/recommendation_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/recommendation_client_example_go123_test.go b/discoveryengine/apiv1beta/recommendation_client_example_go123_test.go index 894241b2877e..e1b702622799 100644 --- a/discoveryengine/apiv1beta/recommendation_client_example_go123_test.go +++ b/discoveryengine/apiv1beta/recommendation_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/recommendation_client_example_test.go b/discoveryengine/apiv1beta/recommendation_client_example_test.go index eec6795dbca0..a1ee1406c9e3 100644 --- a/discoveryengine/apiv1beta/recommendation_client_example_test.go +++ b/discoveryengine/apiv1beta/recommendation_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/sample_query_client.go b/discoveryengine/apiv1beta/sample_query_client.go index ad453f6b89c8..d81f940f9bd3 100755 --- a/discoveryengine/apiv1beta/sample_query_client.go +++ b/discoveryengine/apiv1beta/sample_query_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/sample_query_client_example_go123_test.go b/discoveryengine/apiv1beta/sample_query_client_example_go123_test.go index 8d9ea08d7b20..d889157fe91f 100644 --- a/discoveryengine/apiv1beta/sample_query_client_example_go123_test.go +++ b/discoveryengine/apiv1beta/sample_query_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/sample_query_client_example_test.go b/discoveryengine/apiv1beta/sample_query_client_example_test.go index 1497898b3dfc..6302cbf5ec19 100644 --- a/discoveryengine/apiv1beta/sample_query_client_example_test.go +++ b/discoveryengine/apiv1beta/sample_query_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/sample_query_set_client.go b/discoveryengine/apiv1beta/sample_query_set_client.go index 65682a34a54f..87b7aa577de7 100755 --- a/discoveryengine/apiv1beta/sample_query_set_client.go +++ b/discoveryengine/apiv1beta/sample_query_set_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/sample_query_set_client_example_go123_test.go b/discoveryengine/apiv1beta/sample_query_set_client_example_go123_test.go index 556903880b34..6bc734e326b3 100644 --- a/discoveryengine/apiv1beta/sample_query_set_client_example_go123_test.go +++ b/discoveryengine/apiv1beta/sample_query_set_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/sample_query_set_client_example_test.go b/discoveryengine/apiv1beta/sample_query_set_client_example_test.go index a1c89b32917b..103577254606 100644 --- a/discoveryengine/apiv1beta/sample_query_set_client_example_test.go +++ b/discoveryengine/apiv1beta/sample_query_set_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/schema_client.go b/discoveryengine/apiv1beta/schema_client.go index b159aa62e29a..1a7794c34c15 100755 --- a/discoveryengine/apiv1beta/schema_client.go +++ b/discoveryengine/apiv1beta/schema_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/schema_client_example_go123_test.go b/discoveryengine/apiv1beta/schema_client_example_go123_test.go index 28b8b6f4c076..8537604164bb 100644 --- a/discoveryengine/apiv1beta/schema_client_example_go123_test.go +++ b/discoveryengine/apiv1beta/schema_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/schema_client_example_test.go b/discoveryengine/apiv1beta/schema_client_example_test.go index 4abdf94c67ee..931c45d27a00 100644 --- a/discoveryengine/apiv1beta/schema_client_example_test.go +++ b/discoveryengine/apiv1beta/schema_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/search_client.go b/discoveryengine/apiv1beta/search_client.go index 4d04c196efa7..201c1247013e 100755 --- a/discoveryengine/apiv1beta/search_client.go +++ b/discoveryengine/apiv1beta/search_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/search_client_example_go123_test.go b/discoveryengine/apiv1beta/search_client_example_go123_test.go index f0b2087a7c63..69e749254f0b 100644 --- a/discoveryengine/apiv1beta/search_client_example_go123_test.go +++ b/discoveryengine/apiv1beta/search_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/search_client_example_test.go b/discoveryengine/apiv1beta/search_client_example_test.go index bb6ecba619d3..dfe11b61466d 100644 --- a/discoveryengine/apiv1beta/search_client_example_test.go +++ b/discoveryengine/apiv1beta/search_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/search_tuning_client.go b/discoveryengine/apiv1beta/search_tuning_client.go index 582cfc875207..ccd922a10908 100755 --- a/discoveryengine/apiv1beta/search_tuning_client.go +++ b/discoveryengine/apiv1beta/search_tuning_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/search_tuning_client_example_go123_test.go b/discoveryengine/apiv1beta/search_tuning_client_example_go123_test.go index 4f5d765a886d..cf4d7ba370e4 100644 --- a/discoveryengine/apiv1beta/search_tuning_client_example_go123_test.go +++ b/discoveryengine/apiv1beta/search_tuning_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/search_tuning_client_example_test.go b/discoveryengine/apiv1beta/search_tuning_client_example_test.go index 53b145829c38..b7ab6016e3d2 100644 --- a/discoveryengine/apiv1beta/search_tuning_client_example_test.go +++ b/discoveryengine/apiv1beta/search_tuning_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/serving_config_client.go b/discoveryengine/apiv1beta/serving_config_client.go index edf7934ddbbe..87598799997f 100755 --- a/discoveryengine/apiv1beta/serving_config_client.go +++ b/discoveryengine/apiv1beta/serving_config_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/serving_config_client_example_go123_test.go b/discoveryengine/apiv1beta/serving_config_client_example_go123_test.go index aa23514c11f5..1d601a956268 100644 --- a/discoveryengine/apiv1beta/serving_config_client_example_go123_test.go +++ b/discoveryengine/apiv1beta/serving_config_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/serving_config_client_example_test.go b/discoveryengine/apiv1beta/serving_config_client_example_test.go index 960494283f2e..b21b416db3da 100644 --- a/discoveryengine/apiv1beta/serving_config_client_example_test.go +++ b/discoveryengine/apiv1beta/serving_config_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/site_search_engine_client.go b/discoveryengine/apiv1beta/site_search_engine_client.go index 43d50ddd62be..5583b6d6b821 100755 --- a/discoveryengine/apiv1beta/site_search_engine_client.go +++ b/discoveryengine/apiv1beta/site_search_engine_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/site_search_engine_client_example_go123_test.go b/discoveryengine/apiv1beta/site_search_engine_client_example_go123_test.go index 4c26c1b39b71..d5f6a74ae04c 100644 --- a/discoveryengine/apiv1beta/site_search_engine_client_example_go123_test.go +++ b/discoveryengine/apiv1beta/site_search_engine_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/site_search_engine_client_example_test.go b/discoveryengine/apiv1beta/site_search_engine_client_example_test.go index 64e1e8b8f7df..fa4d83c586de 100644 --- a/discoveryengine/apiv1beta/site_search_engine_client_example_test.go +++ b/discoveryengine/apiv1beta/site_search_engine_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/user_event_client.go b/discoveryengine/apiv1beta/user_event_client.go index b59210e75ead..a49fb9848537 100755 --- a/discoveryengine/apiv1beta/user_event_client.go +++ b/discoveryengine/apiv1beta/user_event_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/user_event_client_example_go123_test.go b/discoveryengine/apiv1beta/user_event_client_example_go123_test.go index 86b4813b2c6d..49d893812667 100644 --- a/discoveryengine/apiv1beta/user_event_client_example_go123_test.go +++ b/discoveryengine/apiv1beta/user_event_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/discoveryengine/apiv1beta/user_event_client_example_test.go b/discoveryengine/apiv1beta/user_event_client_example_test.go index 5ebdf955b803..04e3b7e9cb4c 100644 --- a/discoveryengine/apiv1beta/user_event_client_example_test.go +++ b/discoveryengine/apiv1beta/user_event_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dlp/apiv2/auxiliary.go b/dlp/apiv2/auxiliary.go index b75dd92a15d7..dae25c35428a 100755 --- a/dlp/apiv2/auxiliary.go +++ b/dlp/apiv2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dlp/apiv2/auxiliary_go123.go b/dlp/apiv2/auxiliary_go123.go index d5deb41afeba..c05ea3819f41 100755 --- a/dlp/apiv2/auxiliary_go123.go +++ b/dlp/apiv2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dlp/apiv2/dlp_client.go b/dlp/apiv2/dlp_client.go index 846b07c93e29..e93c9c7ef5bb 100755 --- a/dlp/apiv2/dlp_client.go +++ b/dlp/apiv2/dlp_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dlp/apiv2/dlp_client_example_go123_test.go b/dlp/apiv2/dlp_client_example_go123_test.go index 69af5e3dcd59..bc2165ca3bc7 100644 --- a/dlp/apiv2/dlp_client_example_go123_test.go +++ b/dlp/apiv2/dlp_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dlp/apiv2/dlp_client_example_test.go b/dlp/apiv2/dlp_client_example_test.go index 75407c447921..a3aa445f5acd 100644 --- a/dlp/apiv2/dlp_client_example_test.go +++ b/dlp/apiv2/dlp_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dlp/apiv2/doc.go b/dlp/apiv2/doc.go index c5b9015a7f39..ebb8cbfa6962 100755 --- a/dlp/apiv2/doc.go +++ b/dlp/apiv2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/dlp/apiv2/helpers.go b/dlp/apiv2/helpers.go index 848439a5ff75..6120622bbe2b 100755 --- a/dlp/apiv2/helpers.go +++ b/dlp/apiv2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/documentai/apiv1/auxiliary.go b/documentai/apiv1/auxiliary.go index 8894619c2bf1..ef17e6cbe430 100755 --- a/documentai/apiv1/auxiliary.go +++ b/documentai/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/documentai/apiv1/auxiliary_go123.go b/documentai/apiv1/auxiliary_go123.go index 9711c72e4c32..afa9269cfba6 100755 --- a/documentai/apiv1/auxiliary_go123.go +++ b/documentai/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/documentai/apiv1/doc.go b/documentai/apiv1/doc.go index de8e3199b352..6e863c4bacfa 100755 --- a/documentai/apiv1/doc.go +++ b/documentai/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/documentai/apiv1/document_processor_client.go b/documentai/apiv1/document_processor_client.go index 9de9915c9e0b..939797057752 100755 --- a/documentai/apiv1/document_processor_client.go +++ b/documentai/apiv1/document_processor_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/documentai/apiv1/document_processor_client_example_go123_test.go b/documentai/apiv1/document_processor_client_example_go123_test.go index 89dcfe5774c5..deec34c5c0d7 100644 --- a/documentai/apiv1/document_processor_client_example_go123_test.go +++ b/documentai/apiv1/document_processor_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/documentai/apiv1/document_processor_client_example_test.go b/documentai/apiv1/document_processor_client_example_test.go index 3d061c891a04..87c486548149 100644 --- a/documentai/apiv1/document_processor_client_example_test.go +++ b/documentai/apiv1/document_processor_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/documentai/apiv1/helpers.go b/documentai/apiv1/helpers.go index aaebfd257c26..e8e5ba6a0ce5 100755 --- a/documentai/apiv1/helpers.go +++ b/documentai/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/documentai/apiv1beta3/auxiliary.go b/documentai/apiv1beta3/auxiliary.go index 37d9915625f7..8b84d77cae3b 100755 --- a/documentai/apiv1beta3/auxiliary.go +++ b/documentai/apiv1beta3/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/documentai/apiv1beta3/auxiliary_go123.go b/documentai/apiv1beta3/auxiliary_go123.go index af528a3ade36..7216fb2f623a 100755 --- a/documentai/apiv1beta3/auxiliary_go123.go +++ b/documentai/apiv1beta3/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/documentai/apiv1beta3/doc.go b/documentai/apiv1beta3/doc.go index ef2204d22726..a3a176ec51bd 100755 --- a/documentai/apiv1beta3/doc.go +++ b/documentai/apiv1beta3/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/documentai/apiv1beta3/document_client.go b/documentai/apiv1beta3/document_client.go index 2739a6e38df9..a05f15d0c168 100755 --- a/documentai/apiv1beta3/document_client.go +++ b/documentai/apiv1beta3/document_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/documentai/apiv1beta3/document_client_example_go123_test.go b/documentai/apiv1beta3/document_client_example_go123_test.go index 3eca836c70f4..7f06b3f4cca4 100644 --- a/documentai/apiv1beta3/document_client_example_go123_test.go +++ b/documentai/apiv1beta3/document_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/documentai/apiv1beta3/document_client_example_test.go b/documentai/apiv1beta3/document_client_example_test.go index 9bbc2012e829..fea00b48ff1d 100644 --- a/documentai/apiv1beta3/document_client_example_test.go +++ b/documentai/apiv1beta3/document_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/documentai/apiv1beta3/document_processor_client.go b/documentai/apiv1beta3/document_processor_client.go index b95dd2183159..f69e39b9fc2d 100755 --- a/documentai/apiv1beta3/document_processor_client.go +++ b/documentai/apiv1beta3/document_processor_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/documentai/apiv1beta3/document_processor_client_example_go123_test.go b/documentai/apiv1beta3/document_processor_client_example_go123_test.go index a4cf14ca3bed..54b310275373 100644 --- a/documentai/apiv1beta3/document_processor_client_example_go123_test.go +++ b/documentai/apiv1beta3/document_processor_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/documentai/apiv1beta3/document_processor_client_example_test.go b/documentai/apiv1beta3/document_processor_client_example_test.go index 06f0aee341e8..a2b41e84c52c 100644 --- a/documentai/apiv1beta3/document_processor_client_example_test.go +++ b/documentai/apiv1beta3/document_processor_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/documentai/apiv1beta3/helpers.go b/documentai/apiv1beta3/helpers.go index aaebfd257c26..e8e5ba6a0ce5 100755 --- a/documentai/apiv1beta3/helpers.go +++ b/documentai/apiv1beta3/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/domains/apiv1beta1/auxiliary.go b/domains/apiv1beta1/auxiliary.go index ff29b2fd0978..d481a18dc3c6 100755 --- a/domains/apiv1beta1/auxiliary.go +++ b/domains/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/domains/apiv1beta1/auxiliary_go123.go b/domains/apiv1beta1/auxiliary_go123.go index 021bef185917..980353527af3 100755 --- a/domains/apiv1beta1/auxiliary_go123.go +++ b/domains/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/domains/apiv1beta1/doc.go b/domains/apiv1beta1/doc.go index 08c6aa55a857..3d57d222013f 100755 --- a/domains/apiv1beta1/doc.go +++ b/domains/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/domains/apiv1beta1/domains_client.go b/domains/apiv1beta1/domains_client.go index 0907fbab1a1c..fb122b7b7160 100755 --- a/domains/apiv1beta1/domains_client.go +++ b/domains/apiv1beta1/domains_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/domains/apiv1beta1/domains_client_example_go123_test.go b/domains/apiv1beta1/domains_client_example_go123_test.go index 313adc4f5190..7e50fc859064 100644 --- a/domains/apiv1beta1/domains_client_example_go123_test.go +++ b/domains/apiv1beta1/domains_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/domains/apiv1beta1/domains_client_example_test.go b/domains/apiv1beta1/domains_client_example_test.go index 64e7dbf6cce9..872f6acdb4fc 100644 --- a/domains/apiv1beta1/domains_client_example_test.go +++ b/domains/apiv1beta1/domains_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/domains/apiv1beta1/helpers.go b/domains/apiv1beta1/helpers.go index c09e72e04d1b..d0ea1b9003c1 100755 --- a/domains/apiv1beta1/helpers.go +++ b/domains/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/edgecontainer/apiv1/auxiliary.go b/edgecontainer/apiv1/auxiliary.go index c4e617e078b7..abe6921f166d 100755 --- a/edgecontainer/apiv1/auxiliary.go +++ b/edgecontainer/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/edgecontainer/apiv1/auxiliary_go123.go b/edgecontainer/apiv1/auxiliary_go123.go index 3f2240c6e393..417b6450421d 100755 --- a/edgecontainer/apiv1/auxiliary_go123.go +++ b/edgecontainer/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/edgecontainer/apiv1/doc.go b/edgecontainer/apiv1/doc.go index 538a5255ba5a..4d0255cba7ce 100755 --- a/edgecontainer/apiv1/doc.go +++ b/edgecontainer/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/edgecontainer/apiv1/edge_container_client.go b/edgecontainer/apiv1/edge_container_client.go index 23549f72a2bb..b3d24878a359 100755 --- a/edgecontainer/apiv1/edge_container_client.go +++ b/edgecontainer/apiv1/edge_container_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/edgecontainer/apiv1/edge_container_client_example_go123_test.go b/edgecontainer/apiv1/edge_container_client_example_go123_test.go index 6cadf85dea22..644487f12df9 100644 --- a/edgecontainer/apiv1/edge_container_client_example_go123_test.go +++ b/edgecontainer/apiv1/edge_container_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/edgecontainer/apiv1/edge_container_client_example_test.go b/edgecontainer/apiv1/edge_container_client_example_test.go index f1f91156ae93..ae0d4d702d1d 100644 --- a/edgecontainer/apiv1/edge_container_client_example_test.go +++ b/edgecontainer/apiv1/edge_container_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/edgecontainer/apiv1/helpers.go b/edgecontainer/apiv1/helpers.go index c6612613947b..189076ffb188 100755 --- a/edgecontainer/apiv1/helpers.go +++ b/edgecontainer/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/edgenetwork/apiv1/auxiliary.go b/edgenetwork/apiv1/auxiliary.go index 818c41cf8ccf..2703cdb3953b 100755 --- a/edgenetwork/apiv1/auxiliary.go +++ b/edgenetwork/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/edgenetwork/apiv1/auxiliary_go123.go b/edgenetwork/apiv1/auxiliary_go123.go index f099faeae1df..18b00c2664cd 100755 --- a/edgenetwork/apiv1/auxiliary_go123.go +++ b/edgenetwork/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/edgenetwork/apiv1/doc.go b/edgenetwork/apiv1/doc.go index 7a323861cdc5..cf8c3e7f6023 100755 --- a/edgenetwork/apiv1/doc.go +++ b/edgenetwork/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/edgenetwork/apiv1/edge_network_client.go b/edgenetwork/apiv1/edge_network_client.go index d4f4c1d47bbb..221367ac360b 100755 --- a/edgenetwork/apiv1/edge_network_client.go +++ b/edgenetwork/apiv1/edge_network_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/edgenetwork/apiv1/edge_network_client_example_go123_test.go b/edgenetwork/apiv1/edge_network_client_example_go123_test.go index 27b066d64225..60681e1712d8 100644 --- a/edgenetwork/apiv1/edge_network_client_example_go123_test.go +++ b/edgenetwork/apiv1/edge_network_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/edgenetwork/apiv1/edge_network_client_example_test.go b/edgenetwork/apiv1/edge_network_client_example_test.go index f184b0630c9d..99b8cec9746a 100644 --- a/edgenetwork/apiv1/edge_network_client_example_test.go +++ b/edgenetwork/apiv1/edge_network_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/edgenetwork/apiv1/helpers.go b/edgenetwork/apiv1/helpers.go index 2aff610112a7..ab12cff5c575 100755 --- a/edgenetwork/apiv1/helpers.go +++ b/edgenetwork/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/essentialcontacts/apiv1/auxiliary.go b/essentialcontacts/apiv1/auxiliary.go index 699c1fd1afd2..adcc1c0f7100 100755 --- a/essentialcontacts/apiv1/auxiliary.go +++ b/essentialcontacts/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/essentialcontacts/apiv1/auxiliary_go123.go b/essentialcontacts/apiv1/auxiliary_go123.go index 0002d1ef6040..847e25d8c4d3 100755 --- a/essentialcontacts/apiv1/auxiliary_go123.go +++ b/essentialcontacts/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/essentialcontacts/apiv1/doc.go b/essentialcontacts/apiv1/doc.go index 23f51118a336..32f608e07943 100755 --- a/essentialcontacts/apiv1/doc.go +++ b/essentialcontacts/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/essentialcontacts/apiv1/essential_contacts_client.go b/essentialcontacts/apiv1/essential_contacts_client.go index 07e23db41c0c..a0afb85bfc04 100755 --- a/essentialcontacts/apiv1/essential_contacts_client.go +++ b/essentialcontacts/apiv1/essential_contacts_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/essentialcontacts/apiv1/essential_contacts_client_example_go123_test.go b/essentialcontacts/apiv1/essential_contacts_client_example_go123_test.go index f2b65edd592b..93c6e936e01f 100644 --- a/essentialcontacts/apiv1/essential_contacts_client_example_go123_test.go +++ b/essentialcontacts/apiv1/essential_contacts_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/essentialcontacts/apiv1/essential_contacts_client_example_test.go b/essentialcontacts/apiv1/essential_contacts_client_example_test.go index 6ea6f1554854..b8f7c50914a7 100644 --- a/essentialcontacts/apiv1/essential_contacts_client_example_test.go +++ b/essentialcontacts/apiv1/essential_contacts_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/essentialcontacts/apiv1/helpers.go b/essentialcontacts/apiv1/helpers.go index 28c64b141f31..5e941415fb57 100755 --- a/essentialcontacts/apiv1/helpers.go +++ b/essentialcontacts/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/eventarc/apiv1/auxiliary.go b/eventarc/apiv1/auxiliary.go index 2b6b00ca7380..b9f2dd30c39e 100755 --- a/eventarc/apiv1/auxiliary.go +++ b/eventarc/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/eventarc/apiv1/auxiliary_go123.go b/eventarc/apiv1/auxiliary_go123.go index 6bba17aca733..d3331aece301 100755 --- a/eventarc/apiv1/auxiliary_go123.go +++ b/eventarc/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/eventarc/apiv1/doc.go b/eventarc/apiv1/doc.go index 3c4490720c8a..d6fe07a8b2e3 100755 --- a/eventarc/apiv1/doc.go +++ b/eventarc/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/eventarc/apiv1/eventarc_client.go b/eventarc/apiv1/eventarc_client.go index 8dc428ddd5e9..877baeb06dbf 100755 --- a/eventarc/apiv1/eventarc_client.go +++ b/eventarc/apiv1/eventarc_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/eventarc/apiv1/eventarc_client_example_go123_test.go b/eventarc/apiv1/eventarc_client_example_go123_test.go index 4d0c6792d28f..b3e56af502fc 100644 --- a/eventarc/apiv1/eventarc_client_example_go123_test.go +++ b/eventarc/apiv1/eventarc_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/eventarc/apiv1/eventarc_client_example_test.go b/eventarc/apiv1/eventarc_client_example_test.go index d8ef0c4ce714..879922c4a16c 100644 --- a/eventarc/apiv1/eventarc_client_example_test.go +++ b/eventarc/apiv1/eventarc_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/eventarc/apiv1/helpers.go b/eventarc/apiv1/helpers.go index 9ac5896dd0e1..ffabf0a32ae2 100755 --- a/eventarc/apiv1/helpers.go +++ b/eventarc/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/eventarc/publishing/apiv1/auxiliary.go b/eventarc/publishing/apiv1/auxiliary.go index ac70b750bb10..4e4b95f6e38f 100755 --- a/eventarc/publishing/apiv1/auxiliary.go +++ b/eventarc/publishing/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/eventarc/publishing/apiv1/auxiliary_go123.go b/eventarc/publishing/apiv1/auxiliary_go123.go index 637714a3d8b7..860786b7ba55 100755 --- a/eventarc/publishing/apiv1/auxiliary_go123.go +++ b/eventarc/publishing/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/eventarc/publishing/apiv1/doc.go b/eventarc/publishing/apiv1/doc.go index 47e5e4f64990..cff951cd0c77 100755 --- a/eventarc/publishing/apiv1/doc.go +++ b/eventarc/publishing/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/eventarc/publishing/apiv1/helpers.go b/eventarc/publishing/apiv1/helpers.go index f9a7e34fa804..34306f3bf622 100755 --- a/eventarc/publishing/apiv1/helpers.go +++ b/eventarc/publishing/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/eventarc/publishing/apiv1/publisher_client.go b/eventarc/publishing/apiv1/publisher_client.go index 95e849341c89..45869d031efe 100755 --- a/eventarc/publishing/apiv1/publisher_client.go +++ b/eventarc/publishing/apiv1/publisher_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/eventarc/publishing/apiv1/publisher_client_example_go123_test.go b/eventarc/publishing/apiv1/publisher_client_example_go123_test.go index 4896dd12acdb..66150ab08458 100644 --- a/eventarc/publishing/apiv1/publisher_client_example_go123_test.go +++ b/eventarc/publishing/apiv1/publisher_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/eventarc/publishing/apiv1/publisher_client_example_test.go b/eventarc/publishing/apiv1/publisher_client_example_test.go index eb24cdb447ec..988e3f1a4225 100644 --- a/eventarc/publishing/apiv1/publisher_client_example_test.go +++ b/eventarc/publishing/apiv1/publisher_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/filestore/apiv1/auxiliary.go b/filestore/apiv1/auxiliary.go index 3d1720af58b0..a30c5396c2b3 100755 --- a/filestore/apiv1/auxiliary.go +++ b/filestore/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/filestore/apiv1/auxiliary_go123.go b/filestore/apiv1/auxiliary_go123.go index da2a357a4149..681df0d6e8f7 100755 --- a/filestore/apiv1/auxiliary_go123.go +++ b/filestore/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/filestore/apiv1/cloud_filestore_manager_client.go b/filestore/apiv1/cloud_filestore_manager_client.go index 33fceaa00dea..c26d2632adb1 100755 --- a/filestore/apiv1/cloud_filestore_manager_client.go +++ b/filestore/apiv1/cloud_filestore_manager_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/filestore/apiv1/cloud_filestore_manager_client_example_go123_test.go b/filestore/apiv1/cloud_filestore_manager_client_example_go123_test.go index 11770fc8d0fb..2ba14f338d6d 100644 --- a/filestore/apiv1/cloud_filestore_manager_client_example_go123_test.go +++ b/filestore/apiv1/cloud_filestore_manager_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/filestore/apiv1/cloud_filestore_manager_client_example_test.go b/filestore/apiv1/cloud_filestore_manager_client_example_test.go index 19fdf4465938..5801a514c637 100644 --- a/filestore/apiv1/cloud_filestore_manager_client_example_test.go +++ b/filestore/apiv1/cloud_filestore_manager_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/filestore/apiv1/doc.go b/filestore/apiv1/doc.go index 6ed3067a3fe1..93a02761ecdd 100755 --- a/filestore/apiv1/doc.go +++ b/filestore/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/filestore/apiv1/helpers.go b/filestore/apiv1/helpers.go index f1ac66a79826..0d1b8383e2d4 100755 --- a/filestore/apiv1/helpers.go +++ b/filestore/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/firestore/apiv1/admin/auxiliary.go b/firestore/apiv1/admin/auxiliary.go index 19693e0567eb..79ced7b1ed19 100755 --- a/firestore/apiv1/admin/auxiliary.go +++ b/firestore/apiv1/admin/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/firestore/apiv1/admin/auxiliary_go123.go b/firestore/apiv1/admin/auxiliary_go123.go index d0210c6ec429..8f06c7667461 100755 --- a/firestore/apiv1/admin/auxiliary_go123.go +++ b/firestore/apiv1/admin/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/firestore/apiv1/admin/doc.go b/firestore/apiv1/admin/doc.go index ab464fceac44..871fdc561475 100755 --- a/firestore/apiv1/admin/doc.go +++ b/firestore/apiv1/admin/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/firestore/apiv1/admin/firestore_admin_client.go b/firestore/apiv1/admin/firestore_admin_client.go index 9c0731216f71..78c64e69c994 100755 --- a/firestore/apiv1/admin/firestore_admin_client.go +++ b/firestore/apiv1/admin/firestore_admin_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/firestore/apiv1/admin/firestore_admin_client_example_go123_test.go b/firestore/apiv1/admin/firestore_admin_client_example_go123_test.go index 3f402579e2f4..4efe8adf28e3 100644 --- a/firestore/apiv1/admin/firestore_admin_client_example_go123_test.go +++ b/firestore/apiv1/admin/firestore_admin_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/firestore/apiv1/admin/firestore_admin_client_example_test.go b/firestore/apiv1/admin/firestore_admin_client_example_test.go index a64061bfb8b3..d63cf622bd69 100644 --- a/firestore/apiv1/admin/firestore_admin_client_example_test.go +++ b/firestore/apiv1/admin/firestore_admin_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/firestore/apiv1/admin/helpers.go b/firestore/apiv1/admin/helpers.go index 8a2cc0b024b7..c93ebfb4464f 100755 --- a/firestore/apiv1/admin/helpers.go +++ b/firestore/apiv1/admin/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/firestore/apiv1/auxiliary.go b/firestore/apiv1/auxiliary.go index 4db7d070562b..e0ed132331b4 100755 --- a/firestore/apiv1/auxiliary.go +++ b/firestore/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/firestore/apiv1/auxiliary_go123.go b/firestore/apiv1/auxiliary_go123.go index 9b9a20e0ceee..cd9fca0278b4 100755 --- a/firestore/apiv1/auxiliary_go123.go +++ b/firestore/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/firestore/apiv1/doc.go b/firestore/apiv1/doc.go index a32a78ae8320..eb775d02157c 100755 --- a/firestore/apiv1/doc.go +++ b/firestore/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/firestore/apiv1/firestore_client.go b/firestore/apiv1/firestore_client.go index 551ba8ecec25..56e614d4fe9c 100755 --- a/firestore/apiv1/firestore_client.go +++ b/firestore/apiv1/firestore_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/firestore/apiv1/firestore_client_example_go123_test.go b/firestore/apiv1/firestore_client_example_go123_test.go index 024a4e555e01..4ab60cc06502 100644 --- a/firestore/apiv1/firestore_client_example_go123_test.go +++ b/firestore/apiv1/firestore_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/firestore/apiv1/firestore_client_example_test.go b/firestore/apiv1/firestore_client_example_test.go index 09bc13756af5..fb32d06fd545 100644 --- a/firestore/apiv1/firestore_client_example_test.go +++ b/firestore/apiv1/firestore_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/firestore/apiv1/helpers.go b/firestore/apiv1/helpers.go index 41291e1880c9..0d1c4245e106 100755 --- a/firestore/apiv1/helpers.go +++ b/firestore/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/functions/apiv1/auxiliary.go b/functions/apiv1/auxiliary.go index 9e0b85b73c9e..2710163504b4 100755 --- a/functions/apiv1/auxiliary.go +++ b/functions/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/functions/apiv1/auxiliary_go123.go b/functions/apiv1/auxiliary_go123.go index 60918aa9d9e0..5af524678cb7 100755 --- a/functions/apiv1/auxiliary_go123.go +++ b/functions/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/functions/apiv1/cloud_functions_client.go b/functions/apiv1/cloud_functions_client.go index 980587eb44ef..16d8aab8247a 100755 --- a/functions/apiv1/cloud_functions_client.go +++ b/functions/apiv1/cloud_functions_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/functions/apiv1/cloud_functions_client_example_go123_test.go b/functions/apiv1/cloud_functions_client_example_go123_test.go index c512535af9bb..5a06c5dcc123 100644 --- a/functions/apiv1/cloud_functions_client_example_go123_test.go +++ b/functions/apiv1/cloud_functions_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/functions/apiv1/cloud_functions_client_example_test.go b/functions/apiv1/cloud_functions_client_example_test.go index fabb9d8d471a..0e24033d21ad 100644 --- a/functions/apiv1/cloud_functions_client_example_test.go +++ b/functions/apiv1/cloud_functions_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/functions/apiv1/doc.go b/functions/apiv1/doc.go index 094e55880923..e2cfc85bb3f9 100755 --- a/functions/apiv1/doc.go +++ b/functions/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/functions/apiv1/helpers.go b/functions/apiv1/helpers.go index 55a53082ff9f..ed96bd814d47 100755 --- a/functions/apiv1/helpers.go +++ b/functions/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/functions/apiv2/auxiliary.go b/functions/apiv2/auxiliary.go index 68dc5df6f01a..3a577e0eb12e 100755 --- a/functions/apiv2/auxiliary.go +++ b/functions/apiv2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/functions/apiv2/auxiliary_go123.go b/functions/apiv2/auxiliary_go123.go index 2712e6d4f441..1477f85a733a 100755 --- a/functions/apiv2/auxiliary_go123.go +++ b/functions/apiv2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/functions/apiv2/doc.go b/functions/apiv2/doc.go index bc1678bc0095..2bfe03d1cc0c 100755 --- a/functions/apiv2/doc.go +++ b/functions/apiv2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/functions/apiv2/function_client.go b/functions/apiv2/function_client.go index 74d73fae6366..7ec6ba73f6fd 100755 --- a/functions/apiv2/function_client.go +++ b/functions/apiv2/function_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/functions/apiv2/function_client_example_go123_test.go b/functions/apiv2/function_client_example_go123_test.go index dd0c66f4d5ad..507551bbb9e3 100644 --- a/functions/apiv2/function_client_example_go123_test.go +++ b/functions/apiv2/function_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/functions/apiv2/function_client_example_test.go b/functions/apiv2/function_client_example_test.go index 73ed23e7b29f..647154b0f1e3 100644 --- a/functions/apiv2/function_client_example_test.go +++ b/functions/apiv2/function_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/functions/apiv2/helpers.go b/functions/apiv2/helpers.go index 55a53082ff9f..ed96bd814d47 100755 --- a/functions/apiv2/helpers.go +++ b/functions/apiv2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/functions/apiv2beta/auxiliary.go b/functions/apiv2beta/auxiliary.go index 75e8c1c60f79..83bec6ad52f5 100755 --- a/functions/apiv2beta/auxiliary.go +++ b/functions/apiv2beta/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/functions/apiv2beta/auxiliary_go123.go b/functions/apiv2beta/auxiliary_go123.go index 75647caebf1c..ac96b75774b5 100755 --- a/functions/apiv2beta/auxiliary_go123.go +++ b/functions/apiv2beta/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/functions/apiv2beta/doc.go b/functions/apiv2beta/doc.go index 98c608ebad75..13039c3851f8 100755 --- a/functions/apiv2beta/doc.go +++ b/functions/apiv2beta/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/functions/apiv2beta/function_client.go b/functions/apiv2beta/function_client.go index 76cb69274e07..634442bc9b89 100755 --- a/functions/apiv2beta/function_client.go +++ b/functions/apiv2beta/function_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/functions/apiv2beta/function_client_example_go123_test.go b/functions/apiv2beta/function_client_example_go123_test.go index 42e12ee43a8a..f81c1f0949cb 100644 --- a/functions/apiv2beta/function_client_example_go123_test.go +++ b/functions/apiv2beta/function_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/functions/apiv2beta/function_client_example_test.go b/functions/apiv2beta/function_client_example_test.go index e0e0fb766555..2933e5910d2f 100644 --- a/functions/apiv2beta/function_client_example_test.go +++ b/functions/apiv2beta/function_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/functions/apiv2beta/helpers.go b/functions/apiv2beta/helpers.go index 55a53082ff9f..ed96bd814d47 100755 --- a/functions/apiv2beta/helpers.go +++ b/functions/apiv2beta/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkebackup/apiv1/auxiliary.go b/gkebackup/apiv1/auxiliary.go index 64401440ab41..9e3eeb5a955e 100755 --- a/gkebackup/apiv1/auxiliary.go +++ b/gkebackup/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkebackup/apiv1/auxiliary_go123.go b/gkebackup/apiv1/auxiliary_go123.go index aeb23b5b9756..85136d9fea08 100755 --- a/gkebackup/apiv1/auxiliary_go123.go +++ b/gkebackup/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkebackup/apiv1/backup_forgke_client.go b/gkebackup/apiv1/backup_forgke_client.go index f9e31837bb24..ad5ce09f8570 100755 --- a/gkebackup/apiv1/backup_forgke_client.go +++ b/gkebackup/apiv1/backup_forgke_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkebackup/apiv1/backup_forgke_client_example_go123_test.go b/gkebackup/apiv1/backup_forgke_client_example_go123_test.go index a37a15d15af2..16d10154420e 100644 --- a/gkebackup/apiv1/backup_forgke_client_example_go123_test.go +++ b/gkebackup/apiv1/backup_forgke_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkebackup/apiv1/backup_forgke_client_example_test.go b/gkebackup/apiv1/backup_forgke_client_example_test.go index b6112fd3c4dd..ad7f145f3f92 100644 --- a/gkebackup/apiv1/backup_forgke_client_example_test.go +++ b/gkebackup/apiv1/backup_forgke_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkebackup/apiv1/doc.go b/gkebackup/apiv1/doc.go index 3a32fa7b6c98..5440c18ec736 100755 --- a/gkebackup/apiv1/doc.go +++ b/gkebackup/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkebackup/apiv1/helpers.go b/gkebackup/apiv1/helpers.go index faa3baea5e93..700bb39abd1f 100755 --- a/gkebackup/apiv1/helpers.go +++ b/gkebackup/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkeconnect/gateway/apiv1/auxiliary.go b/gkeconnect/gateway/apiv1/auxiliary.go index 8bc2df7434ff..32e273ff370b 100755 --- a/gkeconnect/gateway/apiv1/auxiliary.go +++ b/gkeconnect/gateway/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkeconnect/gateway/apiv1/auxiliary_go123.go b/gkeconnect/gateway/apiv1/auxiliary_go123.go index 632d1dc91a0c..60d5605db74b 100755 --- a/gkeconnect/gateway/apiv1/auxiliary_go123.go +++ b/gkeconnect/gateway/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkeconnect/gateway/apiv1/doc.go b/gkeconnect/gateway/apiv1/doc.go index d190e8cb5d3b..3e08582f1bbb 100755 --- a/gkeconnect/gateway/apiv1/doc.go +++ b/gkeconnect/gateway/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkeconnect/gateway/apiv1/gateway_control_client.go b/gkeconnect/gateway/apiv1/gateway_control_client.go index d19e7f1c09b8..c303f352ad5f 100755 --- a/gkeconnect/gateway/apiv1/gateway_control_client.go +++ b/gkeconnect/gateway/apiv1/gateway_control_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkeconnect/gateway/apiv1/gateway_control_client_example_go123_test.go b/gkeconnect/gateway/apiv1/gateway_control_client_example_go123_test.go index 3f8b087ce165..c336c4fab4a9 100644 --- a/gkeconnect/gateway/apiv1/gateway_control_client_example_go123_test.go +++ b/gkeconnect/gateway/apiv1/gateway_control_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkeconnect/gateway/apiv1/gateway_control_client_example_test.go b/gkeconnect/gateway/apiv1/gateway_control_client_example_test.go index 5cb6853decfb..4049c1dab12a 100644 --- a/gkeconnect/gateway/apiv1/gateway_control_client_example_test.go +++ b/gkeconnect/gateway/apiv1/gateway_control_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkeconnect/gateway/apiv1/helpers.go b/gkeconnect/gateway/apiv1/helpers.go index 0731698f1f59..4a6d8bc92224 100755 --- a/gkeconnect/gateway/apiv1/helpers.go +++ b/gkeconnect/gateway/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkeconnect/gateway/apiv1beta1/auxiliary.go b/gkeconnect/gateway/apiv1beta1/auxiliary.go index 8bc2df7434ff..32e273ff370b 100755 --- a/gkeconnect/gateway/apiv1beta1/auxiliary.go +++ b/gkeconnect/gateway/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkeconnect/gateway/apiv1beta1/auxiliary_go123.go b/gkeconnect/gateway/apiv1beta1/auxiliary_go123.go index 632d1dc91a0c..60d5605db74b 100755 --- a/gkeconnect/gateway/apiv1beta1/auxiliary_go123.go +++ b/gkeconnect/gateway/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkeconnect/gateway/apiv1beta1/doc.go b/gkeconnect/gateway/apiv1beta1/doc.go index 65957fcf9ef8..12a3c39ed3f0 100755 --- a/gkeconnect/gateway/apiv1beta1/doc.go +++ b/gkeconnect/gateway/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkeconnect/gateway/apiv1beta1/gateway_control_client.go b/gkeconnect/gateway/apiv1beta1/gateway_control_client.go index 181cea21ba38..a3801eee83eb 100755 --- a/gkeconnect/gateway/apiv1beta1/gateway_control_client.go +++ b/gkeconnect/gateway/apiv1beta1/gateway_control_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkeconnect/gateway/apiv1beta1/gateway_control_client_example_go123_test.go b/gkeconnect/gateway/apiv1beta1/gateway_control_client_example_go123_test.go index 3f8b087ce165..c336c4fab4a9 100644 --- a/gkeconnect/gateway/apiv1beta1/gateway_control_client_example_go123_test.go +++ b/gkeconnect/gateway/apiv1beta1/gateway_control_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkeconnect/gateway/apiv1beta1/gateway_control_client_example_test.go b/gkeconnect/gateway/apiv1beta1/gateway_control_client_example_test.go index 0a08044f2ff6..c93feaa392b7 100644 --- a/gkeconnect/gateway/apiv1beta1/gateway_control_client_example_test.go +++ b/gkeconnect/gateway/apiv1beta1/gateway_control_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkeconnect/gateway/apiv1beta1/helpers.go b/gkeconnect/gateway/apiv1beta1/helpers.go index 0731698f1f59..4a6d8bc92224 100755 --- a/gkeconnect/gateway/apiv1beta1/helpers.go +++ b/gkeconnect/gateway/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkehub/apiv1beta1/auxiliary.go b/gkehub/apiv1beta1/auxiliary.go index e95f6bb76bd0..2f662501b207 100755 --- a/gkehub/apiv1beta1/auxiliary.go +++ b/gkehub/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkehub/apiv1beta1/auxiliary_go123.go b/gkehub/apiv1beta1/auxiliary_go123.go index c7abe31ad3a9..e3392d1bf37b 100755 --- a/gkehub/apiv1beta1/auxiliary_go123.go +++ b/gkehub/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkehub/apiv1beta1/doc.go b/gkehub/apiv1beta1/doc.go index bd3d4d9d0c81..f6594cd668e5 100755 --- a/gkehub/apiv1beta1/doc.go +++ b/gkehub/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkehub/apiv1beta1/gke_hub_membership_client.go b/gkehub/apiv1beta1/gke_hub_membership_client.go index 264432e8eb0a..b400f3f9021e 100755 --- a/gkehub/apiv1beta1/gke_hub_membership_client.go +++ b/gkehub/apiv1beta1/gke_hub_membership_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkehub/apiv1beta1/gke_hub_membership_client_example_go123_test.go b/gkehub/apiv1beta1/gke_hub_membership_client_example_go123_test.go index 2026fd3880d8..3ddd93fcc6e1 100644 --- a/gkehub/apiv1beta1/gke_hub_membership_client_example_go123_test.go +++ b/gkehub/apiv1beta1/gke_hub_membership_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkehub/apiv1beta1/gke_hub_membership_client_example_test.go b/gkehub/apiv1beta1/gke_hub_membership_client_example_test.go index f415939f5b01..04bfd216a988 100644 --- a/gkehub/apiv1beta1/gke_hub_membership_client_example_test.go +++ b/gkehub/apiv1beta1/gke_hub_membership_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkehub/apiv1beta1/helpers.go b/gkehub/apiv1beta1/helpers.go index 0ebacbddb202..ff7d9664dbb1 100755 --- a/gkehub/apiv1beta1/helpers.go +++ b/gkehub/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkemulticloud/apiv1/attached_clusters_client.go b/gkemulticloud/apiv1/attached_clusters_client.go index bed34028f491..8bfc6e26a705 100755 --- a/gkemulticloud/apiv1/attached_clusters_client.go +++ b/gkemulticloud/apiv1/attached_clusters_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkemulticloud/apiv1/attached_clusters_client_example_go123_test.go b/gkemulticloud/apiv1/attached_clusters_client_example_go123_test.go index 924f841d70b1..65ccb3593f91 100644 --- a/gkemulticloud/apiv1/attached_clusters_client_example_go123_test.go +++ b/gkemulticloud/apiv1/attached_clusters_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkemulticloud/apiv1/attached_clusters_client_example_test.go b/gkemulticloud/apiv1/attached_clusters_client_example_test.go index bcd76ada8be0..335c3a6e2938 100644 --- a/gkemulticloud/apiv1/attached_clusters_client_example_test.go +++ b/gkemulticloud/apiv1/attached_clusters_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkemulticloud/apiv1/auxiliary.go b/gkemulticloud/apiv1/auxiliary.go index 073673e5df6c..09790ee54df4 100755 --- a/gkemulticloud/apiv1/auxiliary.go +++ b/gkemulticloud/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkemulticloud/apiv1/auxiliary_go123.go b/gkemulticloud/apiv1/auxiliary_go123.go index d98559580556..127fe5b72d79 100755 --- a/gkemulticloud/apiv1/auxiliary_go123.go +++ b/gkemulticloud/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkemulticloud/apiv1/aws_clusters_client.go b/gkemulticloud/apiv1/aws_clusters_client.go index f0c605e536bf..aca8c01243d0 100755 --- a/gkemulticloud/apiv1/aws_clusters_client.go +++ b/gkemulticloud/apiv1/aws_clusters_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkemulticloud/apiv1/aws_clusters_client_example_go123_test.go b/gkemulticloud/apiv1/aws_clusters_client_example_go123_test.go index 22f651d53050..27b5be142514 100644 --- a/gkemulticloud/apiv1/aws_clusters_client_example_go123_test.go +++ b/gkemulticloud/apiv1/aws_clusters_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkemulticloud/apiv1/aws_clusters_client_example_test.go b/gkemulticloud/apiv1/aws_clusters_client_example_test.go index a0cd312f9547..45efd82c1bf1 100644 --- a/gkemulticloud/apiv1/aws_clusters_client_example_test.go +++ b/gkemulticloud/apiv1/aws_clusters_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkemulticloud/apiv1/azure_clusters_client.go b/gkemulticloud/apiv1/azure_clusters_client.go index 8b35979c4e03..cb022d08aac4 100755 --- a/gkemulticloud/apiv1/azure_clusters_client.go +++ b/gkemulticloud/apiv1/azure_clusters_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkemulticloud/apiv1/azure_clusters_client_example_go123_test.go b/gkemulticloud/apiv1/azure_clusters_client_example_go123_test.go index fbbcc581b7b0..59321c2ba248 100644 --- a/gkemulticloud/apiv1/azure_clusters_client_example_go123_test.go +++ b/gkemulticloud/apiv1/azure_clusters_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkemulticloud/apiv1/azure_clusters_client_example_test.go b/gkemulticloud/apiv1/azure_clusters_client_example_test.go index 89be1bc13da9..daf31b1ebccd 100644 --- a/gkemulticloud/apiv1/azure_clusters_client_example_test.go +++ b/gkemulticloud/apiv1/azure_clusters_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkemulticloud/apiv1/doc.go b/gkemulticloud/apiv1/doc.go index 2d96adb5f9d5..14feab91f0af 100755 --- a/gkemulticloud/apiv1/doc.go +++ b/gkemulticloud/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gkemulticloud/apiv1/helpers.go b/gkemulticloud/apiv1/helpers.go index e85d99999509..7dd93395312e 100755 --- a/gkemulticloud/apiv1/helpers.go +++ b/gkemulticloud/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gsuiteaddons/apiv1/auxiliary.go b/gsuiteaddons/apiv1/auxiliary.go index 5b2c2bf5caae..b8c2d12c53ca 100755 --- a/gsuiteaddons/apiv1/auxiliary.go +++ b/gsuiteaddons/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gsuiteaddons/apiv1/auxiliary_go123.go b/gsuiteaddons/apiv1/auxiliary_go123.go index ed5234c2bd60..e14de255d4cb 100755 --- a/gsuiteaddons/apiv1/auxiliary_go123.go +++ b/gsuiteaddons/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gsuiteaddons/apiv1/doc.go b/gsuiteaddons/apiv1/doc.go index de335dcd52e3..6464adbbb8d6 100755 --- a/gsuiteaddons/apiv1/doc.go +++ b/gsuiteaddons/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gsuiteaddons/apiv1/g_suite_add_ons_client.go b/gsuiteaddons/apiv1/g_suite_add_ons_client.go index bbcc7254ea9e..e3ee3dae04fd 100755 --- a/gsuiteaddons/apiv1/g_suite_add_ons_client.go +++ b/gsuiteaddons/apiv1/g_suite_add_ons_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gsuiteaddons/apiv1/g_suite_add_ons_client_example_go123_test.go b/gsuiteaddons/apiv1/g_suite_add_ons_client_example_go123_test.go index 288186d593f2..0f0ad1d4c92c 100644 --- a/gsuiteaddons/apiv1/g_suite_add_ons_client_example_go123_test.go +++ b/gsuiteaddons/apiv1/g_suite_add_ons_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gsuiteaddons/apiv1/g_suite_add_ons_client_example_test.go b/gsuiteaddons/apiv1/g_suite_add_ons_client_example_test.go index ea5a84b4ef3d..23bb8aa03011 100644 --- a/gsuiteaddons/apiv1/g_suite_add_ons_client_example_test.go +++ b/gsuiteaddons/apiv1/g_suite_add_ons_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/gsuiteaddons/apiv1/helpers.go b/gsuiteaddons/apiv1/helpers.go index 671d538519f6..0885072667c6 100755 --- a/gsuiteaddons/apiv1/helpers.go +++ b/gsuiteaddons/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iam/apiv1/auxiliary.go b/iam/apiv1/auxiliary.go index d09ad9188791..5c6bd22896e5 100755 --- a/iam/apiv1/auxiliary.go +++ b/iam/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iam/apiv1/auxiliary_go123.go b/iam/apiv1/auxiliary_go123.go index 2ef3c5939acf..35d710187283 100755 --- a/iam/apiv1/auxiliary_go123.go +++ b/iam/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iam/apiv1/doc.go b/iam/apiv1/doc.go index d0fdc6a134e2..3966fd7af4e0 100755 --- a/iam/apiv1/doc.go +++ b/iam/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iam/apiv1/helpers.go b/iam/apiv1/helpers.go index ae4996c87f6a..90e485e35f28 100755 --- a/iam/apiv1/helpers.go +++ b/iam/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iam/apiv1/iam_policy_client.go b/iam/apiv1/iam_policy_client.go index ab730e0416ce..ec01db791d88 100755 --- a/iam/apiv1/iam_policy_client.go +++ b/iam/apiv1/iam_policy_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iam/apiv1/iam_policy_client_example_go123_test.go b/iam/apiv1/iam_policy_client_example_go123_test.go index a5c65571017c..67c7bdc4b2ae 100644 --- a/iam/apiv1/iam_policy_client_example_go123_test.go +++ b/iam/apiv1/iam_policy_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iam/apiv1/iam_policy_client_example_test.go b/iam/apiv1/iam_policy_client_example_test.go index 7a2e941d4c69..9eba0f9caf3d 100644 --- a/iam/apiv1/iam_policy_client_example_test.go +++ b/iam/apiv1/iam_policy_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iam/apiv2/auxiliary.go b/iam/apiv2/auxiliary.go index 33008a9d407a..ba19b2abfb6d 100755 --- a/iam/apiv2/auxiliary.go +++ b/iam/apiv2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iam/apiv2/auxiliary_go123.go b/iam/apiv2/auxiliary_go123.go index 7ad98abb0a45..1d6eedbc2a08 100755 --- a/iam/apiv2/auxiliary_go123.go +++ b/iam/apiv2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iam/apiv2/doc.go b/iam/apiv2/doc.go index 38d246d5cf97..7061f1189688 100755 --- a/iam/apiv2/doc.go +++ b/iam/apiv2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iam/apiv2/helpers.go b/iam/apiv2/helpers.go index 8e5b695d26b3..675bd88c94bf 100755 --- a/iam/apiv2/helpers.go +++ b/iam/apiv2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iam/apiv2/policies_client.go b/iam/apiv2/policies_client.go index ca6378be7d31..acba065e0d9b 100755 --- a/iam/apiv2/policies_client.go +++ b/iam/apiv2/policies_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iam/apiv2/policies_client_example_go123_test.go b/iam/apiv2/policies_client_example_go123_test.go index e241ac72db5f..c28ebe1f8156 100644 --- a/iam/apiv2/policies_client_example_go123_test.go +++ b/iam/apiv2/policies_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iam/apiv2/policies_client_example_test.go b/iam/apiv2/policies_client_example_test.go index e1f5f80e1aa9..e32260a92914 100644 --- a/iam/apiv2/policies_client_example_test.go +++ b/iam/apiv2/policies_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iam/credentials/apiv1/auxiliary.go b/iam/credentials/apiv1/auxiliary.go index 2f759a2bb64f..012aa010a807 100755 --- a/iam/credentials/apiv1/auxiliary.go +++ b/iam/credentials/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iam/credentials/apiv1/auxiliary_go123.go b/iam/credentials/apiv1/auxiliary_go123.go index 159da92cbecc..a7aace7cdfa9 100755 --- a/iam/credentials/apiv1/auxiliary_go123.go +++ b/iam/credentials/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iam/credentials/apiv1/doc.go b/iam/credentials/apiv1/doc.go index ade37465c029..435e4578ddb5 100755 --- a/iam/credentials/apiv1/doc.go +++ b/iam/credentials/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iam/credentials/apiv1/helpers.go b/iam/credentials/apiv1/helpers.go index 1540a334f110..338f7c038394 100755 --- a/iam/credentials/apiv1/helpers.go +++ b/iam/credentials/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iam/credentials/apiv1/iam_credentials_client.go b/iam/credentials/apiv1/iam_credentials_client.go index 9f22feea39db..36dd5a3c346e 100755 --- a/iam/credentials/apiv1/iam_credentials_client.go +++ b/iam/credentials/apiv1/iam_credentials_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iam/credentials/apiv1/iam_credentials_client_example_go123_test.go b/iam/credentials/apiv1/iam_credentials_client_example_go123_test.go index 3d0e76a51d77..55ec6be7810c 100644 --- a/iam/credentials/apiv1/iam_credentials_client_example_go123_test.go +++ b/iam/credentials/apiv1/iam_credentials_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iam/credentials/apiv1/iam_credentials_client_example_test.go b/iam/credentials/apiv1/iam_credentials_client_example_test.go index 0b6947053349..d2bc70f4692b 100644 --- a/iam/credentials/apiv1/iam_credentials_client_example_test.go +++ b/iam/credentials/apiv1/iam_credentials_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iap/apiv1/auxiliary.go b/iap/apiv1/auxiliary.go index ffcb66a0d66e..0d7f3bca8c35 100755 --- a/iap/apiv1/auxiliary.go +++ b/iap/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iap/apiv1/auxiliary_go123.go b/iap/apiv1/auxiliary_go123.go index 102295618b00..5a3f7b89f105 100755 --- a/iap/apiv1/auxiliary_go123.go +++ b/iap/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iap/apiv1/doc.go b/iap/apiv1/doc.go index 0bc9e070021f..f136a4bb7817 100755 --- a/iap/apiv1/doc.go +++ b/iap/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iap/apiv1/helpers.go b/iap/apiv1/helpers.go index 66183d17075d..96c26de6e4d8 100755 --- a/iap/apiv1/helpers.go +++ b/iap/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iap/apiv1/identity_aware_proxy_admin_client.go b/iap/apiv1/identity_aware_proxy_admin_client.go index 94eb75581c3d..221d9170f9ca 100755 --- a/iap/apiv1/identity_aware_proxy_admin_client.go +++ b/iap/apiv1/identity_aware_proxy_admin_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iap/apiv1/identity_aware_proxy_admin_client_example_go123_test.go b/iap/apiv1/identity_aware_proxy_admin_client_example_go123_test.go index 732e67605361..ce31f28b2ccb 100644 --- a/iap/apiv1/identity_aware_proxy_admin_client_example_go123_test.go +++ b/iap/apiv1/identity_aware_proxy_admin_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iap/apiv1/identity_aware_proxy_admin_client_example_test.go b/iap/apiv1/identity_aware_proxy_admin_client_example_test.go index b5596172355c..642c0f64139a 100644 --- a/iap/apiv1/identity_aware_proxy_admin_client_example_test.go +++ b/iap/apiv1/identity_aware_proxy_admin_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iap/apiv1/identity_aware_proxyo_auth_client.go b/iap/apiv1/identity_aware_proxyo_auth_client.go index 0329df916901..e2e265e9e41e 100755 --- a/iap/apiv1/identity_aware_proxyo_auth_client.go +++ b/iap/apiv1/identity_aware_proxyo_auth_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iap/apiv1/identity_aware_proxyo_auth_client_example_go123_test.go b/iap/apiv1/identity_aware_proxyo_auth_client_example_go123_test.go index 7d491dedd14b..7d56ce840383 100644 --- a/iap/apiv1/identity_aware_proxyo_auth_client_example_go123_test.go +++ b/iap/apiv1/identity_aware_proxyo_auth_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iap/apiv1/identity_aware_proxyo_auth_client_example_test.go b/iap/apiv1/identity_aware_proxyo_auth_client_example_test.go index 53048d8f78b8..3ba54a0bc8f6 100644 --- a/iap/apiv1/identity_aware_proxyo_auth_client_example_test.go +++ b/iap/apiv1/identity_aware_proxyo_auth_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/identitytoolkit/apiv2/account_management_client.go b/identitytoolkit/apiv2/account_management_client.go index 035427703a79..23b931a71914 100755 --- a/identitytoolkit/apiv2/account_management_client.go +++ b/identitytoolkit/apiv2/account_management_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/identitytoolkit/apiv2/account_management_client_example_go123_test.go b/identitytoolkit/apiv2/account_management_client_example_go123_test.go index f7bd2eaebd09..452a8df7ecc3 100644 --- a/identitytoolkit/apiv2/account_management_client_example_go123_test.go +++ b/identitytoolkit/apiv2/account_management_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/identitytoolkit/apiv2/account_management_client_example_test.go b/identitytoolkit/apiv2/account_management_client_example_test.go index 7a08c38217c4..d3670f63a23a 100644 --- a/identitytoolkit/apiv2/account_management_client_example_test.go +++ b/identitytoolkit/apiv2/account_management_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/identitytoolkit/apiv2/authentication_client.go b/identitytoolkit/apiv2/authentication_client.go index 914fd8c63cc4..13cb0f153541 100755 --- a/identitytoolkit/apiv2/authentication_client.go +++ b/identitytoolkit/apiv2/authentication_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/identitytoolkit/apiv2/authentication_client_example_go123_test.go b/identitytoolkit/apiv2/authentication_client_example_go123_test.go index f7bd2eaebd09..452a8df7ecc3 100644 --- a/identitytoolkit/apiv2/authentication_client_example_go123_test.go +++ b/identitytoolkit/apiv2/authentication_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/identitytoolkit/apiv2/authentication_client_example_test.go b/identitytoolkit/apiv2/authentication_client_example_test.go index 9a1176d7c1ab..b39e0c1fdf85 100644 --- a/identitytoolkit/apiv2/authentication_client_example_test.go +++ b/identitytoolkit/apiv2/authentication_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/identitytoolkit/apiv2/auxiliary.go b/identitytoolkit/apiv2/auxiliary.go index 7be391a1bb33..3a4828f19335 100755 --- a/identitytoolkit/apiv2/auxiliary.go +++ b/identitytoolkit/apiv2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/identitytoolkit/apiv2/auxiliary_go123.go b/identitytoolkit/apiv2/auxiliary_go123.go index 2b771f6df0fa..e2b622fc57dc 100755 --- a/identitytoolkit/apiv2/auxiliary_go123.go +++ b/identitytoolkit/apiv2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/identitytoolkit/apiv2/doc.go b/identitytoolkit/apiv2/doc.go index 9229d138d3f4..827ff0c2c566 100755 --- a/identitytoolkit/apiv2/doc.go +++ b/identitytoolkit/apiv2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/identitytoolkit/apiv2/helpers.go b/identitytoolkit/apiv2/helpers.go index 6f1ba65b02e1..0690098053bc 100755 --- a/identitytoolkit/apiv2/helpers.go +++ b/identitytoolkit/apiv2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ids/apiv1/auxiliary.go b/ids/apiv1/auxiliary.go index dc31f3248d70..fc28145ef644 100755 --- a/ids/apiv1/auxiliary.go +++ b/ids/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ids/apiv1/auxiliary_go123.go b/ids/apiv1/auxiliary_go123.go index 8f8f162abc17..e20e41e5ffe2 100755 --- a/ids/apiv1/auxiliary_go123.go +++ b/ids/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ids/apiv1/doc.go b/ids/apiv1/doc.go index 1ee397f18baa..18f93db0cb8a 100755 --- a/ids/apiv1/doc.go +++ b/ids/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ids/apiv1/helpers.go b/ids/apiv1/helpers.go index bbfe79467c69..553647b98d0d 100755 --- a/ids/apiv1/helpers.go +++ b/ids/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ids/apiv1/ids_client.go b/ids/apiv1/ids_client.go index 9c4c738349eb..94f533265882 100755 --- a/ids/apiv1/ids_client.go +++ b/ids/apiv1/ids_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ids/apiv1/ids_client_example_go123_test.go b/ids/apiv1/ids_client_example_go123_test.go index 61532227991d..602d0544841d 100644 --- a/ids/apiv1/ids_client_example_go123_test.go +++ b/ids/apiv1/ids_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/ids/apiv1/ids_client_example_test.go b/ids/apiv1/ids_client_example_test.go index 7adc9a5947d1..005133f29510 100644 --- a/ids/apiv1/ids_client_example_test.go +++ b/ids/apiv1/ids_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accessapproval/apiv1/Client/ApproveApprovalRequest/main.go b/internal/generated/snippets/accessapproval/apiv1/Client/ApproveApprovalRequest/main.go index 17e36eea00ff..d17ac798c7cc 100644 --- a/internal/generated/snippets/accessapproval/apiv1/Client/ApproveApprovalRequest/main.go +++ b/internal/generated/snippets/accessapproval/apiv1/Client/ApproveApprovalRequest/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accessapproval/apiv1/Client/DeleteAccessApprovalSettings/main.go b/internal/generated/snippets/accessapproval/apiv1/Client/DeleteAccessApprovalSettings/main.go index c01e8c76bd67..8f7cbb9d83e3 100644 --- a/internal/generated/snippets/accessapproval/apiv1/Client/DeleteAccessApprovalSettings/main.go +++ b/internal/generated/snippets/accessapproval/apiv1/Client/DeleteAccessApprovalSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accessapproval/apiv1/Client/DismissApprovalRequest/main.go b/internal/generated/snippets/accessapproval/apiv1/Client/DismissApprovalRequest/main.go index ab7cdeda221c..1d97343b9560 100644 --- a/internal/generated/snippets/accessapproval/apiv1/Client/DismissApprovalRequest/main.go +++ b/internal/generated/snippets/accessapproval/apiv1/Client/DismissApprovalRequest/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accessapproval/apiv1/Client/GetAccessApprovalServiceAccount/main.go b/internal/generated/snippets/accessapproval/apiv1/Client/GetAccessApprovalServiceAccount/main.go index b52b77e340c7..3cf4588e2bb4 100644 --- a/internal/generated/snippets/accessapproval/apiv1/Client/GetAccessApprovalServiceAccount/main.go +++ b/internal/generated/snippets/accessapproval/apiv1/Client/GetAccessApprovalServiceAccount/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accessapproval/apiv1/Client/GetAccessApprovalSettings/main.go b/internal/generated/snippets/accessapproval/apiv1/Client/GetAccessApprovalSettings/main.go index 579e3eb5ebc3..fdddde053790 100644 --- a/internal/generated/snippets/accessapproval/apiv1/Client/GetAccessApprovalSettings/main.go +++ b/internal/generated/snippets/accessapproval/apiv1/Client/GetAccessApprovalSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accessapproval/apiv1/Client/GetApprovalRequest/main.go b/internal/generated/snippets/accessapproval/apiv1/Client/GetApprovalRequest/main.go index e8bbc085d76a..4f9ec89a8c34 100644 --- a/internal/generated/snippets/accessapproval/apiv1/Client/GetApprovalRequest/main.go +++ b/internal/generated/snippets/accessapproval/apiv1/Client/GetApprovalRequest/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accessapproval/apiv1/Client/InvalidateApprovalRequest/main.go b/internal/generated/snippets/accessapproval/apiv1/Client/InvalidateApprovalRequest/main.go index dea4e8a07b91..1860163c227b 100644 --- a/internal/generated/snippets/accessapproval/apiv1/Client/InvalidateApprovalRequest/main.go +++ b/internal/generated/snippets/accessapproval/apiv1/Client/InvalidateApprovalRequest/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accessapproval/apiv1/Client/ListApprovalRequests/main.go b/internal/generated/snippets/accessapproval/apiv1/Client/ListApprovalRequests/main.go index 6dafd8fa14df..a84b7f91387d 100644 --- a/internal/generated/snippets/accessapproval/apiv1/Client/ListApprovalRequests/main.go +++ b/internal/generated/snippets/accessapproval/apiv1/Client/ListApprovalRequests/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accessapproval/apiv1/Client/UpdateAccessApprovalSettings/main.go b/internal/generated/snippets/accessapproval/apiv1/Client/UpdateAccessApprovalSettings/main.go index 7c23cb052431..065002fc52cb 100644 --- a/internal/generated/snippets/accessapproval/apiv1/Client/UpdateAccessApprovalSettings/main.go +++ b/internal/generated/snippets/accessapproval/apiv1/Client/UpdateAccessApprovalSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accesscontextmanager/apiv1/Client/CommitServicePerimeters/main.go b/internal/generated/snippets/accesscontextmanager/apiv1/Client/CommitServicePerimeters/main.go index 84bfe647ea9f..0b02b406dace 100644 --- a/internal/generated/snippets/accesscontextmanager/apiv1/Client/CommitServicePerimeters/main.go +++ b/internal/generated/snippets/accesscontextmanager/apiv1/Client/CommitServicePerimeters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accesscontextmanager/apiv1/Client/CreateAccessLevel/main.go b/internal/generated/snippets/accesscontextmanager/apiv1/Client/CreateAccessLevel/main.go index 5bb386768fff..f76eede14bad 100644 --- a/internal/generated/snippets/accesscontextmanager/apiv1/Client/CreateAccessLevel/main.go +++ b/internal/generated/snippets/accesscontextmanager/apiv1/Client/CreateAccessLevel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accesscontextmanager/apiv1/Client/CreateAccessPolicy/main.go b/internal/generated/snippets/accesscontextmanager/apiv1/Client/CreateAccessPolicy/main.go index 3dfd22940e80..70334d6c0dfc 100644 --- a/internal/generated/snippets/accesscontextmanager/apiv1/Client/CreateAccessPolicy/main.go +++ b/internal/generated/snippets/accesscontextmanager/apiv1/Client/CreateAccessPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accesscontextmanager/apiv1/Client/CreateGcpUserAccessBinding/main.go b/internal/generated/snippets/accesscontextmanager/apiv1/Client/CreateGcpUserAccessBinding/main.go index 1763ca5140e3..23429f878d99 100644 --- a/internal/generated/snippets/accesscontextmanager/apiv1/Client/CreateGcpUserAccessBinding/main.go +++ b/internal/generated/snippets/accesscontextmanager/apiv1/Client/CreateGcpUserAccessBinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accesscontextmanager/apiv1/Client/CreateServicePerimeter/main.go b/internal/generated/snippets/accesscontextmanager/apiv1/Client/CreateServicePerimeter/main.go index e19b670b90db..285d2879165e 100644 --- a/internal/generated/snippets/accesscontextmanager/apiv1/Client/CreateServicePerimeter/main.go +++ b/internal/generated/snippets/accesscontextmanager/apiv1/Client/CreateServicePerimeter/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accesscontextmanager/apiv1/Client/DeleteAccessLevel/main.go b/internal/generated/snippets/accesscontextmanager/apiv1/Client/DeleteAccessLevel/main.go index ac6456a0b26f..60518b1f2694 100644 --- a/internal/generated/snippets/accesscontextmanager/apiv1/Client/DeleteAccessLevel/main.go +++ b/internal/generated/snippets/accesscontextmanager/apiv1/Client/DeleteAccessLevel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accesscontextmanager/apiv1/Client/DeleteAccessPolicy/main.go b/internal/generated/snippets/accesscontextmanager/apiv1/Client/DeleteAccessPolicy/main.go index 8cb5edc721fd..1476b4018da7 100644 --- a/internal/generated/snippets/accesscontextmanager/apiv1/Client/DeleteAccessPolicy/main.go +++ b/internal/generated/snippets/accesscontextmanager/apiv1/Client/DeleteAccessPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accesscontextmanager/apiv1/Client/DeleteGcpUserAccessBinding/main.go b/internal/generated/snippets/accesscontextmanager/apiv1/Client/DeleteGcpUserAccessBinding/main.go index 8ccb0bb37e3d..453e5e8a5a22 100644 --- a/internal/generated/snippets/accesscontextmanager/apiv1/Client/DeleteGcpUserAccessBinding/main.go +++ b/internal/generated/snippets/accesscontextmanager/apiv1/Client/DeleteGcpUserAccessBinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accesscontextmanager/apiv1/Client/DeleteServicePerimeter/main.go b/internal/generated/snippets/accesscontextmanager/apiv1/Client/DeleteServicePerimeter/main.go index 3d15da0cd509..7984ea6a3272 100644 --- a/internal/generated/snippets/accesscontextmanager/apiv1/Client/DeleteServicePerimeter/main.go +++ b/internal/generated/snippets/accesscontextmanager/apiv1/Client/DeleteServicePerimeter/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accesscontextmanager/apiv1/Client/GetAccessLevel/main.go b/internal/generated/snippets/accesscontextmanager/apiv1/Client/GetAccessLevel/main.go index db5756880cde..f0339fb90df0 100644 --- a/internal/generated/snippets/accesscontextmanager/apiv1/Client/GetAccessLevel/main.go +++ b/internal/generated/snippets/accesscontextmanager/apiv1/Client/GetAccessLevel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accesscontextmanager/apiv1/Client/GetAccessPolicy/main.go b/internal/generated/snippets/accesscontextmanager/apiv1/Client/GetAccessPolicy/main.go index 0fa43581185e..6847b965becf 100644 --- a/internal/generated/snippets/accesscontextmanager/apiv1/Client/GetAccessPolicy/main.go +++ b/internal/generated/snippets/accesscontextmanager/apiv1/Client/GetAccessPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accesscontextmanager/apiv1/Client/GetGcpUserAccessBinding/main.go b/internal/generated/snippets/accesscontextmanager/apiv1/Client/GetGcpUserAccessBinding/main.go index 23ca77dbbcc9..6f5207b95aea 100644 --- a/internal/generated/snippets/accesscontextmanager/apiv1/Client/GetGcpUserAccessBinding/main.go +++ b/internal/generated/snippets/accesscontextmanager/apiv1/Client/GetGcpUserAccessBinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accesscontextmanager/apiv1/Client/GetIamPolicy/main.go b/internal/generated/snippets/accesscontextmanager/apiv1/Client/GetIamPolicy/main.go index 47ff9e3a23d9..53df042ee61a 100644 --- a/internal/generated/snippets/accesscontextmanager/apiv1/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/accesscontextmanager/apiv1/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accesscontextmanager/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/accesscontextmanager/apiv1/Client/GetOperation/main.go index bb15e189ddc0..581a17be44bb 100644 --- a/internal/generated/snippets/accesscontextmanager/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/accesscontextmanager/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accesscontextmanager/apiv1/Client/GetServicePerimeter/main.go b/internal/generated/snippets/accesscontextmanager/apiv1/Client/GetServicePerimeter/main.go index 36cb32d08356..b66421f18771 100644 --- a/internal/generated/snippets/accesscontextmanager/apiv1/Client/GetServicePerimeter/main.go +++ b/internal/generated/snippets/accesscontextmanager/apiv1/Client/GetServicePerimeter/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accesscontextmanager/apiv1/Client/ListAccessLevels/main.go b/internal/generated/snippets/accesscontextmanager/apiv1/Client/ListAccessLevels/main.go index 1ba42afa4744..6a3ff86a7a09 100644 --- a/internal/generated/snippets/accesscontextmanager/apiv1/Client/ListAccessLevels/main.go +++ b/internal/generated/snippets/accesscontextmanager/apiv1/Client/ListAccessLevels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accesscontextmanager/apiv1/Client/ListAccessPolicies/main.go b/internal/generated/snippets/accesscontextmanager/apiv1/Client/ListAccessPolicies/main.go index f47dcc30ac96..4ca851bd70e4 100644 --- a/internal/generated/snippets/accesscontextmanager/apiv1/Client/ListAccessPolicies/main.go +++ b/internal/generated/snippets/accesscontextmanager/apiv1/Client/ListAccessPolicies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accesscontextmanager/apiv1/Client/ListGcpUserAccessBindings/main.go b/internal/generated/snippets/accesscontextmanager/apiv1/Client/ListGcpUserAccessBindings/main.go index b103f4f0c69b..46d3805afe3f 100644 --- a/internal/generated/snippets/accesscontextmanager/apiv1/Client/ListGcpUserAccessBindings/main.go +++ b/internal/generated/snippets/accesscontextmanager/apiv1/Client/ListGcpUserAccessBindings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accesscontextmanager/apiv1/Client/ListServicePerimeters/main.go b/internal/generated/snippets/accesscontextmanager/apiv1/Client/ListServicePerimeters/main.go index d3c9c82101d1..b994f744c335 100644 --- a/internal/generated/snippets/accesscontextmanager/apiv1/Client/ListServicePerimeters/main.go +++ b/internal/generated/snippets/accesscontextmanager/apiv1/Client/ListServicePerimeters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accesscontextmanager/apiv1/Client/ReplaceAccessLevels/main.go b/internal/generated/snippets/accesscontextmanager/apiv1/Client/ReplaceAccessLevels/main.go index dccc76448c7b..aee7d2fb7734 100644 --- a/internal/generated/snippets/accesscontextmanager/apiv1/Client/ReplaceAccessLevels/main.go +++ b/internal/generated/snippets/accesscontextmanager/apiv1/Client/ReplaceAccessLevels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accesscontextmanager/apiv1/Client/ReplaceServicePerimeters/main.go b/internal/generated/snippets/accesscontextmanager/apiv1/Client/ReplaceServicePerimeters/main.go index 9663e1938431..44a06b66ac34 100644 --- a/internal/generated/snippets/accesscontextmanager/apiv1/Client/ReplaceServicePerimeters/main.go +++ b/internal/generated/snippets/accesscontextmanager/apiv1/Client/ReplaceServicePerimeters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accesscontextmanager/apiv1/Client/SetIamPolicy/main.go b/internal/generated/snippets/accesscontextmanager/apiv1/Client/SetIamPolicy/main.go index 3ca65e904c8d..cdd0c1834a3d 100644 --- a/internal/generated/snippets/accesscontextmanager/apiv1/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/accesscontextmanager/apiv1/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accesscontextmanager/apiv1/Client/TestIamPermissions/main.go b/internal/generated/snippets/accesscontextmanager/apiv1/Client/TestIamPermissions/main.go index c33b08e96322..22f57f0edfc0 100644 --- a/internal/generated/snippets/accesscontextmanager/apiv1/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/accesscontextmanager/apiv1/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accesscontextmanager/apiv1/Client/UpdateAccessLevel/main.go b/internal/generated/snippets/accesscontextmanager/apiv1/Client/UpdateAccessLevel/main.go index 63e4c538834b..3dbdb7dd6041 100644 --- a/internal/generated/snippets/accesscontextmanager/apiv1/Client/UpdateAccessLevel/main.go +++ b/internal/generated/snippets/accesscontextmanager/apiv1/Client/UpdateAccessLevel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accesscontextmanager/apiv1/Client/UpdateAccessPolicy/main.go b/internal/generated/snippets/accesscontextmanager/apiv1/Client/UpdateAccessPolicy/main.go index 04f2363883e3..15ecf52c5c27 100644 --- a/internal/generated/snippets/accesscontextmanager/apiv1/Client/UpdateAccessPolicy/main.go +++ b/internal/generated/snippets/accesscontextmanager/apiv1/Client/UpdateAccessPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accesscontextmanager/apiv1/Client/UpdateGcpUserAccessBinding/main.go b/internal/generated/snippets/accesscontextmanager/apiv1/Client/UpdateGcpUserAccessBinding/main.go index 6c19b8a610d3..7f1796d75383 100644 --- a/internal/generated/snippets/accesscontextmanager/apiv1/Client/UpdateGcpUserAccessBinding/main.go +++ b/internal/generated/snippets/accesscontextmanager/apiv1/Client/UpdateGcpUserAccessBinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/accesscontextmanager/apiv1/Client/UpdateServicePerimeter/main.go b/internal/generated/snippets/accesscontextmanager/apiv1/Client/UpdateServicePerimeter/main.go index 475f4cc5ecd9..86d0c93b7f1d 100644 --- a/internal/generated/snippets/accesscontextmanager/apiv1/Client/UpdateServicePerimeter/main.go +++ b/internal/generated/snippets/accesscontextmanager/apiv1/Client/UpdateServicePerimeter/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/advisorynotifications/apiv1/Client/GetNotification/main.go b/internal/generated/snippets/advisorynotifications/apiv1/Client/GetNotification/main.go index ee8377830531..5530e5b3d1c2 100644 --- a/internal/generated/snippets/advisorynotifications/apiv1/Client/GetNotification/main.go +++ b/internal/generated/snippets/advisorynotifications/apiv1/Client/GetNotification/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/advisorynotifications/apiv1/Client/GetSettings/main.go b/internal/generated/snippets/advisorynotifications/apiv1/Client/GetSettings/main.go index f7386c03e2b0..63638e903e51 100644 --- a/internal/generated/snippets/advisorynotifications/apiv1/Client/GetSettings/main.go +++ b/internal/generated/snippets/advisorynotifications/apiv1/Client/GetSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/advisorynotifications/apiv1/Client/ListNotifications/main.go b/internal/generated/snippets/advisorynotifications/apiv1/Client/ListNotifications/main.go index 70651a673c44..52ea1e639201 100644 --- a/internal/generated/snippets/advisorynotifications/apiv1/Client/ListNotifications/main.go +++ b/internal/generated/snippets/advisorynotifications/apiv1/Client/ListNotifications/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/advisorynotifications/apiv1/Client/UpdateSettings/main.go b/internal/generated/snippets/advisorynotifications/apiv1/Client/UpdateSettings/main.go index 6612aba450f9..e28cf4575f36 100644 --- a/internal/generated/snippets/advisorynotifications/apiv1/Client/UpdateSettings/main.go +++ b/internal/generated/snippets/advisorynotifications/apiv1/Client/UpdateSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/advisorynotifications/apiv1/snippet_metadata.google.cloud.advisorynotifications.v1.json b/internal/generated/snippets/advisorynotifications/apiv1/snippet_metadata.google.cloud.advisorynotifications.v1.json index 8c755095398e..e0a4177e255b 100644 --- a/internal/generated/snippets/advisorynotifications/apiv1/snippet_metadata.google.cloud.advisorynotifications.v1.json +++ b/internal/generated/snippets/advisorynotifications/apiv1/snippet_metadata.google.cloud.advisorynotifications.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/advisorynotifications/apiv1", - "version": "1.5.2", + "version": "1.5.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1/GenerativeClient/BatchEmbedContents/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1/GenerativeClient/BatchEmbedContents/main.go index 986e00827cd6..5b97d8738c15 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1/GenerativeClient/BatchEmbedContents/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1/GenerativeClient/BatchEmbedContents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1/GenerativeClient/CancelOperation/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1/GenerativeClient/CancelOperation/main.go index c0f4f9e857cb..946666b3418d 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1/GenerativeClient/CancelOperation/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1/GenerativeClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1/GenerativeClient/CountTokens/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1/GenerativeClient/CountTokens/main.go index 02693375f925..6d7a415cd13b 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1/GenerativeClient/CountTokens/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1/GenerativeClient/CountTokens/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1/GenerativeClient/EmbedContent/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1/GenerativeClient/EmbedContent/main.go index c4b6ef8bdd59..64dc3a114b27 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1/GenerativeClient/EmbedContent/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1/GenerativeClient/EmbedContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1/GenerativeClient/GenerateContent/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1/GenerativeClient/GenerateContent/main.go index a2e1da9e8735..2cd9365ffda7 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1/GenerativeClient/GenerateContent/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1/GenerativeClient/GenerateContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1/GenerativeClient/GetOperation/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1/GenerativeClient/GetOperation/main.go index 45c942e12ea4..50ad50ebe365 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1/GenerativeClient/GetOperation/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1/GenerativeClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1/GenerativeClient/ListOperations/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1/GenerativeClient/ListOperations/main.go index 094e137cb3fd..9186d5647944 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1/GenerativeClient/ListOperations/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1/GenerativeClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1/ModelClient/CancelOperation/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1/ModelClient/CancelOperation/main.go index 4fe1d864ea71..f2ae5e185ffa 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1/ModelClient/CancelOperation/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1/ModelClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1/ModelClient/GetModel/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1/ModelClient/GetModel/main.go index c820a410885d..cdc43714ac50 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1/ModelClient/GetModel/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1/ModelClient/GetModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1/ModelClient/GetOperation/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1/ModelClient/GetOperation/main.go index 725b36fff42f..c3131adeb096 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1/ModelClient/GetOperation/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1/ModelClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1/ModelClient/ListModels/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1/ModelClient/ListModels/main.go index 2839b5b4b63f..a8e8fa2159fb 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1/ModelClient/ListModels/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1/ModelClient/ListModels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1/ModelClient/ListOperations/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1/ModelClient/ListOperations/main.go index 4a2d920478fb..5a76bfcc1351 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1/ModelClient/ListOperations/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1/ModelClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/CacheClient/CreateCachedContent/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/CacheClient/CreateCachedContent/main.go index fb642b64bf03..ee5f0bd96f9c 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/CacheClient/CreateCachedContent/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/CacheClient/CreateCachedContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/CacheClient/DeleteCachedContent/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/CacheClient/DeleteCachedContent/main.go index 7bab2210f5cb..4763fb1fef0d 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/CacheClient/DeleteCachedContent/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/CacheClient/DeleteCachedContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/CacheClient/GetCachedContent/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/CacheClient/GetCachedContent/main.go index f1428265c685..7a59bdd9e5a6 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/CacheClient/GetCachedContent/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/CacheClient/GetCachedContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/CacheClient/GetOperation/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/CacheClient/GetOperation/main.go index fa4449bd8a2f..59bf0f332312 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/CacheClient/GetOperation/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/CacheClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/CacheClient/ListCachedContents/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/CacheClient/ListCachedContents/main.go index 5e111fd3f8d3..db6347a395b0 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/CacheClient/ListCachedContents/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/CacheClient/ListCachedContents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/CacheClient/ListOperations/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/CacheClient/ListOperations/main.go index 64c083002f81..2295cd168437 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/CacheClient/ListOperations/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/CacheClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/CacheClient/UpdateCachedContent/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/CacheClient/UpdateCachedContent/main.go index 8a758fdcd64b..50997d875188 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/CacheClient/UpdateCachedContent/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/CacheClient/UpdateCachedContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/DiscussClient/CountMessageTokens/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/DiscussClient/CountMessageTokens/main.go index e3b0f10132d5..1a399b605a46 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/DiscussClient/CountMessageTokens/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/DiscussClient/CountMessageTokens/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/DiscussClient/GenerateMessage/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/DiscussClient/GenerateMessage/main.go index 53aaf69527c6..26a3a9fbdbd5 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/DiscussClient/GenerateMessage/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/DiscussClient/GenerateMessage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/DiscussClient/GetOperation/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/DiscussClient/GetOperation/main.go index 4c704b46b3a7..a2a3d7579ab6 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/DiscussClient/GetOperation/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/DiscussClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/DiscussClient/ListOperations/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/DiscussClient/ListOperations/main.go index 4140cc2dfe0f..5d7da92fe3bd 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/DiscussClient/ListOperations/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/DiscussClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/FileClient/CreateFile/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/FileClient/CreateFile/main.go index 3a1a6e9020d5..2207e567a9bb 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/FileClient/CreateFile/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/FileClient/CreateFile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/FileClient/DeleteFile/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/FileClient/DeleteFile/main.go index bbcf80017928..a6a09ee89b24 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/FileClient/DeleteFile/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/FileClient/DeleteFile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/FileClient/GetFile/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/FileClient/GetFile/main.go index 0a58246e29a9..3280305058f6 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/FileClient/GetFile/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/FileClient/GetFile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/FileClient/GetOperation/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/FileClient/GetOperation/main.go index bd65da2071f4..f58ad3f44bd0 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/FileClient/GetOperation/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/FileClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/FileClient/ListFiles/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/FileClient/ListFiles/main.go index 7c66d7008eb2..b5905ee1f214 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/FileClient/ListFiles/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/FileClient/ListFiles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/FileClient/ListOperations/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/FileClient/ListOperations/main.go index 1cd8f4bba63e..aa576d15b941 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/FileClient/ListOperations/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/FileClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/GenerativeClient/BatchEmbedContents/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/GenerativeClient/BatchEmbedContents/main.go index fe856c5bad4a..6d958c56aa11 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/GenerativeClient/BatchEmbedContents/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/GenerativeClient/BatchEmbedContents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/GenerativeClient/CountTokens/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/GenerativeClient/CountTokens/main.go index f7ff818f8406..6601f24c8a40 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/GenerativeClient/CountTokens/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/GenerativeClient/CountTokens/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/GenerativeClient/EmbedContent/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/GenerativeClient/EmbedContent/main.go index d85ace5c64f5..8bbe9812f9b7 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/GenerativeClient/EmbedContent/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/GenerativeClient/EmbedContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/GenerativeClient/GenerateAnswer/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/GenerativeClient/GenerateAnswer/main.go index 579500c48bba..ff952c064fdf 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/GenerativeClient/GenerateAnswer/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/GenerativeClient/GenerateAnswer/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/GenerativeClient/GenerateContent/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/GenerativeClient/GenerateContent/main.go index e657d0480995..eb7c9b441651 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/GenerativeClient/GenerateContent/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/GenerativeClient/GenerateContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/GenerativeClient/GetOperation/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/GenerativeClient/GetOperation/main.go index 03d9f589b3f8..0716b3d63e6b 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/GenerativeClient/GetOperation/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/GenerativeClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/GenerativeClient/ListOperations/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/GenerativeClient/ListOperations/main.go index 89c319719323..8cf44820f785 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/GenerativeClient/ListOperations/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/GenerativeClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/CreateTunedModel/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/CreateTunedModel/main.go index 6ad11c44127a..6bf89e093ebe 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/CreateTunedModel/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/CreateTunedModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/DeleteTunedModel/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/DeleteTunedModel/main.go index 8b36ca622693..c441358cd41b 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/DeleteTunedModel/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/DeleteTunedModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/GetModel/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/GetModel/main.go index aecdcb09759b..4033b9920dce 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/GetModel/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/GetModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/GetOperation/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/GetOperation/main.go index cbbeee539079..2515d608f277 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/GetOperation/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/GetTunedModel/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/GetTunedModel/main.go index 0e1e48e6178d..4365ae12f210 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/GetTunedModel/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/GetTunedModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/ListModels/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/ListModels/main.go index ee6f28117c95..1c563b1512f9 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/ListModels/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/ListModels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/ListOperations/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/ListOperations/main.go index 814dbf80d46f..c33b932d5d0e 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/ListOperations/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/ListTunedModels/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/ListTunedModels/main.go index 14aac79f2850..1cbba1210eb2 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/ListTunedModels/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/ListTunedModels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/UpdateTunedModel/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/UpdateTunedModel/main.go index affd42c66e8c..4a2935164611 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/UpdateTunedModel/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/ModelClient/UpdateTunedModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/CreatePermission/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/CreatePermission/main.go index 54316ccbb4b4..77146ad7216b 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/CreatePermission/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/CreatePermission/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/DeletePermission/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/DeletePermission/main.go index 4c88e6328aad..558e18cdb572 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/DeletePermission/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/DeletePermission/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/GetOperation/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/GetOperation/main.go index dace60651bb6..ddcf777cd66c 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/GetOperation/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/GetPermission/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/GetPermission/main.go index c3923084fad1..f8bfbd0209c3 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/GetPermission/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/GetPermission/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/ListOperations/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/ListOperations/main.go index da093861d300..d305ced37d2b 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/ListOperations/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/ListPermissions/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/ListPermissions/main.go index bab5afe2a1f9..1ca5ce1c11a7 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/ListPermissions/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/ListPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/TransferOwnership/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/TransferOwnership/main.go index 89a5d738b5b3..635997046b68 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/TransferOwnership/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/TransferOwnership/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/UpdatePermission/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/UpdatePermission/main.go index 0d8952f6fe17..1a5d7c2b9790 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/UpdatePermission/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/PermissionClient/UpdatePermission/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/PredictionClient/GetOperation/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/PredictionClient/GetOperation/main.go index b2008927f076..711b6202cb99 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/PredictionClient/GetOperation/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/PredictionClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/PredictionClient/ListOperations/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/PredictionClient/ListOperations/main.go index c444ad3ab59c..a974d1518676 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/PredictionClient/ListOperations/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/PredictionClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/PredictionClient/Predict/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/PredictionClient/Predict/main.go index 7ada2fd85886..1ae9e2851b5f 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/PredictionClient/Predict/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/PredictionClient/Predict/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/BatchCreateChunks/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/BatchCreateChunks/main.go index e755edd36600..010c8fbb1f70 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/BatchCreateChunks/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/BatchCreateChunks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/BatchDeleteChunks/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/BatchDeleteChunks/main.go index eb91c07d8693..c47a3205bd64 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/BatchDeleteChunks/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/BatchDeleteChunks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/BatchUpdateChunks/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/BatchUpdateChunks/main.go index 23b296c2b991..6d3c18581bb8 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/BatchUpdateChunks/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/BatchUpdateChunks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/CreateChunk/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/CreateChunk/main.go index 9fde00bd80d1..2e28ca8dbefe 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/CreateChunk/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/CreateChunk/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/CreateCorpus/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/CreateCorpus/main.go index 6bf625c62033..579f9adb80ad 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/CreateCorpus/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/CreateCorpus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/CreateDocument/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/CreateDocument/main.go index 1dbdb3b1399c..ec9eab993c27 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/CreateDocument/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/CreateDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/DeleteChunk/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/DeleteChunk/main.go index 437e9a96a46c..8c195ab5fde2 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/DeleteChunk/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/DeleteChunk/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/DeleteCorpus/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/DeleteCorpus/main.go index b35c6f2f2e4b..ac8437de3281 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/DeleteCorpus/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/DeleteCorpus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/DeleteDocument/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/DeleteDocument/main.go index c2a31cdcb7f3..58bd8aeb434d 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/DeleteDocument/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/DeleteDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/GetChunk/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/GetChunk/main.go index 8e006b393e0a..73c5f02977b2 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/GetChunk/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/GetChunk/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/GetCorpus/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/GetCorpus/main.go index f847b174dbe1..b2fd4fa0a985 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/GetCorpus/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/GetCorpus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/GetDocument/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/GetDocument/main.go index 929e7bb5efa6..3131b6f82002 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/GetDocument/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/GetDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/GetOperation/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/GetOperation/main.go index 12dfc92eccba..e5442bf3adb2 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/GetOperation/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/ListChunks/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/ListChunks/main.go index 70b9744d4d7f..966446a0682f 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/ListChunks/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/ListChunks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/ListCorpora/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/ListCorpora/main.go index aa306730d1d9..5838bae128fb 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/ListCorpora/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/ListCorpora/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/ListDocuments/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/ListDocuments/main.go index c9c150145191..8d22f4b167a8 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/ListDocuments/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/ListDocuments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/ListOperations/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/ListOperations/main.go index f0cfd3870486..77a13f53e7ad 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/ListOperations/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/QueryCorpus/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/QueryCorpus/main.go index bc9e08ce7346..79c015892f71 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/QueryCorpus/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/QueryCorpus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/QueryDocument/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/QueryDocument/main.go index 7a6340a4e313..d89eb2117c2f 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/QueryDocument/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/QueryDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/UpdateChunk/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/UpdateChunk/main.go index 31b86bc9fc12..156f03bf8ba8 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/UpdateChunk/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/UpdateChunk/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/UpdateCorpus/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/UpdateCorpus/main.go index eba3c2410120..372f2a7daf35 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/UpdateCorpus/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/UpdateCorpus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/UpdateDocument/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/UpdateDocument/main.go index f487c8f71d10..3c48c1a62135 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/UpdateDocument/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/RetrieverClient/UpdateDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/TextClient/BatchEmbedText/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/TextClient/BatchEmbedText/main.go index 542970b25f0b..9b6a7453e43c 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/TextClient/BatchEmbedText/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/TextClient/BatchEmbedText/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/TextClient/CountTextTokens/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/TextClient/CountTextTokens/main.go index 14cbbd7806a1..a925829d69fd 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/TextClient/CountTextTokens/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/TextClient/CountTextTokens/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/TextClient/EmbedText/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/TextClient/EmbedText/main.go index cc42d697cd05..6b7fc86d22d0 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/TextClient/EmbedText/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/TextClient/EmbedText/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/TextClient/GenerateText/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/TextClient/GenerateText/main.go index 177294f457c4..cc8ce386e493 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/TextClient/GenerateText/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/TextClient/GenerateText/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/TextClient/GetOperation/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/TextClient/GetOperation/main.go index 8a83b2c1ce78..4e66dc070c03 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/TextClient/GetOperation/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/TextClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta/TextClient/ListOperations/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta/TextClient/ListOperations/main.go index e5e51df7600e..a55cdb96323a 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta/TextClient/ListOperations/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta/TextClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta2/DiscussClient/CountMessageTokens/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta2/DiscussClient/CountMessageTokens/main.go index af2e475bf6c4..1d0fafd032b7 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta2/DiscussClient/CountMessageTokens/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta2/DiscussClient/CountMessageTokens/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta2/DiscussClient/GenerateMessage/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta2/DiscussClient/GenerateMessage/main.go index e79b14a1172f..3b6be737cfd9 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta2/DiscussClient/GenerateMessage/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta2/DiscussClient/GenerateMessage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta2/ModelClient/GetModel/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta2/ModelClient/GetModel/main.go index f0ea3e5dca59..7f5f1819f7cf 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta2/ModelClient/GetModel/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta2/ModelClient/GetModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta2/ModelClient/ListModels/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta2/ModelClient/ListModels/main.go index a5518e33b7eb..967e31f36276 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta2/ModelClient/ListModels/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta2/ModelClient/ListModels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta2/TextClient/EmbedText/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta2/TextClient/EmbedText/main.go index fe687d020c8a..52f70393cbab 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta2/TextClient/EmbedText/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta2/TextClient/EmbedText/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ai/generativelanguage/apiv1beta2/TextClient/GenerateText/main.go b/internal/generated/snippets/ai/generativelanguage/apiv1beta2/TextClient/GenerateText/main.go index 24f034dfd704..487919bc562e 100644 --- a/internal/generated/snippets/ai/generativelanguage/apiv1beta2/TextClient/GenerateText/main.go +++ b/internal/generated/snippets/ai/generativelanguage/apiv1beta2/TextClient/GenerateText/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/CancelOperation/main.go index d9cca67ffcdd..fc8016e142d8 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/CreateDataset/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/CreateDataset/main.go index 8790b672416d..6af72d9dfc3e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/CreateDataset/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/CreateDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/CreateDatasetVersion/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/CreateDatasetVersion/main.go index 44fd4b650baf..e6b4f680a385 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/CreateDatasetVersion/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/CreateDatasetVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/DeleteDataset/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/DeleteDataset/main.go index ab77d8f39ed1..a007f1a6d2da 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/DeleteDataset/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/DeleteDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/DeleteDatasetVersion/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/DeleteDatasetVersion/main.go index 85e410ed9cbb..32468cf6c125 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/DeleteDatasetVersion/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/DeleteDatasetVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/DeleteOperation/main.go index 7714f8e920ce..ee326e33031b 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/DeleteSavedQuery/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/DeleteSavedQuery/main.go index 1bf6d2006eaa..23f4cb48c33b 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/DeleteSavedQuery/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/DeleteSavedQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ExportData/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ExportData/main.go index cdb851a73bca..d7724000b47d 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ExportData/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ExportData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/GetAnnotationSpec/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/GetAnnotationSpec/main.go index 7a4a7d542a1b..4750cb2e755b 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/GetAnnotationSpec/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/GetAnnotationSpec/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/GetDataset/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/GetDataset/main.go index 28ec219ff3d4..56aaceb5b306 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/GetDataset/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/GetDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/GetDatasetVersion/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/GetDatasetVersion/main.go index aae005deb2f7..b288ba8e93b7 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/GetDatasetVersion/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/GetDatasetVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/GetIamPolicy/main.go index c8d863f7d01d..2a438dc8654a 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/GetLocation/main.go index 6469769d7504..3e3e3b7f0f7a 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/GetOperation/main.go index 896065735df9..f1ed48fc509e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ImportData/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ImportData/main.go index a56f93a865ec..72922c079d87 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ImportData/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ImportData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ListAnnotations/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ListAnnotations/main.go index bc6670971120..512e9e09e06e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ListAnnotations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ListAnnotations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ListDataItems/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ListDataItems/main.go index 635ba74d6003..138467df5568 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ListDataItems/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ListDataItems/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ListDatasetVersions/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ListDatasetVersions/main.go index 9355fdb1fec6..2af264d7f6c3 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ListDatasetVersions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ListDatasetVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ListDatasets/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ListDatasets/main.go index b650425cb41c..6c06d7344870 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ListDatasets/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ListDatasets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ListLocations/main.go index 79b615270980..d217bf9d6378 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ListOperations/main.go index 22bedd5bb718..328fb5675253 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ListSavedQueries/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ListSavedQueries/main.go index 951fc1f54a6f..8da088f3e55c 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ListSavedQueries/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/ListSavedQueries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/RestoreDatasetVersion/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/RestoreDatasetVersion/main.go index 7a8c57d198f8..85361a0271b5 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/RestoreDatasetVersion/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/RestoreDatasetVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/SearchDataItems/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/SearchDataItems/main.go index c6f3cd4091b6..ec31d7fea0d3 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/SearchDataItems/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/SearchDataItems/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/SetIamPolicy/main.go index 39dd656add59..b6c36b94b2af 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/TestIamPermissions/main.go index cd4f604c8856..1323e8a0086e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/UpdateDataset/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/UpdateDataset/main.go index e0cf14555ddd..9323961ffe9a 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/UpdateDataset/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/UpdateDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/UpdateDatasetVersion/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/UpdateDatasetVersion/main.go index d5d6503a05f9..dfeb078429c7 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/UpdateDatasetVersion/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/UpdateDatasetVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/WaitOperation/main.go index aebbb0681fda..7f8991997059 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DatasetClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DatasetClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/CancelOperation/main.go index f843511c6112..0632222188f8 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/CreateDeploymentResourcePool/main.go b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/CreateDeploymentResourcePool/main.go index fd99e88e2f46..6d930ee32ea1 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/CreateDeploymentResourcePool/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/CreateDeploymentResourcePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/DeleteDeploymentResourcePool/main.go b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/DeleteDeploymentResourcePool/main.go index a4c7aa0fec0f..7a04ff14fdb6 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/DeleteDeploymentResourcePool/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/DeleteDeploymentResourcePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/DeleteOperation/main.go index 7e2afb93106c..b5894af776b8 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/GetDeploymentResourcePool/main.go b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/GetDeploymentResourcePool/main.go index 6ce94449bc68..661c1373e081 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/GetDeploymentResourcePool/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/GetDeploymentResourcePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/GetIamPolicy/main.go index fb64961f36ac..e7f3676c3a75 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/GetLocation/main.go index e9d57b897631..350a6302e2e9 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/GetOperation/main.go index b1c3d24c1284..0b74531bb3d5 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/ListDeploymentResourcePools/main.go b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/ListDeploymentResourcePools/main.go index 789765835e12..218cc5207d79 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/ListDeploymentResourcePools/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/ListDeploymentResourcePools/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/ListLocations/main.go index 15c2a557f0ce..8e17606bb703 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/ListOperations/main.go index 41a7f7e7e034..971b96357834 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/QueryDeployedModels/main.go b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/QueryDeployedModels/main.go index ab78f30c0b96..e256de68c475 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/QueryDeployedModels/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/QueryDeployedModels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/SetIamPolicy/main.go index 2d8e9f5bde1b..8e494ae429e2 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/TestIamPermissions/main.go index 79b95392bce6..c03d170c97de 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/UpdateDeploymentResourcePool/main.go b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/UpdateDeploymentResourcePool/main.go index ee3b2d06228e..934ead807d32 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/UpdateDeploymentResourcePool/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/UpdateDeploymentResourcePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/WaitOperation/main.go index 461b5361b24c..a5d6fe12c463 100644 --- a/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/DeploymentResourcePoolClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/CancelOperation/main.go index 81cdcf473b2f..384894b3f032 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/CreateEndpoint/main.go b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/CreateEndpoint/main.go index b218cf780f99..dab73334a681 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/CreateEndpoint/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/CreateEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/DeleteEndpoint/main.go b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/DeleteEndpoint/main.go index 31d3a625e94f..13178fdf385c 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/DeleteEndpoint/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/DeleteEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/DeleteOperation/main.go index 8d73a8f7d77d..e3cc8e7e6bf3 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/DeployModel/main.go b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/DeployModel/main.go index f1389d17d7ff..90c2760b271b 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/DeployModel/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/DeployModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/GetEndpoint/main.go b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/GetEndpoint/main.go index 0dcddadadfc3..83b1fb69d0dd 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/GetEndpoint/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/GetEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/GetIamPolicy/main.go index 7afac66015d3..bc33b5cfc1ed 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/GetLocation/main.go index 84528e4f673d..e78dd12bee41 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/GetOperation/main.go index 65cb862bdcbb..25342363506d 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/ListEndpoints/main.go b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/ListEndpoints/main.go index 6496fff178e6..0ec517eac320 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/ListEndpoints/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/ListEndpoints/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/ListLocations/main.go index 1be902ad80f5..ae263344efd2 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/ListOperations/main.go index 803f4f0ac505..7a7e091836e6 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/MutateDeployedModel/main.go b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/MutateDeployedModel/main.go index 783ba0dea8cb..dab896501975 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/MutateDeployedModel/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/MutateDeployedModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/SetIamPolicy/main.go index a7f91d814a25..b7089309d29c 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/TestIamPermissions/main.go index 0d8f437ff8db..75bac56c6d22 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/UndeployModel/main.go b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/UndeployModel/main.go index 39374bed2062..cb8fbb52a07a 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/UndeployModel/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/UndeployModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/UpdateEndpoint/main.go b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/UpdateEndpoint/main.go index 9d8730bf8f13..1e997fff462d 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/UpdateEndpoint/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/UpdateEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/UpdateEndpointLongRunning/main.go b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/UpdateEndpointLongRunning/main.go index f4104aca7ca3..73869ffec341 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/UpdateEndpointLongRunning/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/UpdateEndpointLongRunning/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/WaitOperation/main.go index 8cfe047e84d7..d718a9ff60b9 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EndpointClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EndpointClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/CancelOperation/main.go index 34a53456193d..dd02bacb9cf0 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/DeleteOperation/main.go index c8dd6af3474c..514f8a325cc6 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/EvaluateInstances/main.go b/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/EvaluateInstances/main.go index 9235839006db..6fb3eb2facb8 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/EvaluateInstances/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/EvaluateInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/GetIamPolicy/main.go index 8ad2e04880c0..0fd20a0c0ca3 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/GetLocation/main.go index 8ccc5c03892d..d7baf02c4f79 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/GetOperation/main.go index 136a8ea85ede..03cd13336c3c 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/ListLocations/main.go index 2d8a474dccea..3366470705f5 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/ListOperations/main.go index bc4f0b1a88b4..b1ef4100e470 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/SetIamPolicy/main.go index ddb48463cdca..950cbf63563e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/TestIamPermissions/main.go index 5ec76f2ab0bb..c9aa34ab062d 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/WaitOperation/main.go index f75e5eb8ca85..1bfdd1f0b0b2 100644 --- a/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/EvaluationClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/CancelOperation/main.go index 0c06edb30cc7..a0fcf02bef12 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/CreateFeatureOnlineStore/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/CreateFeatureOnlineStore/main.go index 3de65a892e81..d1e7c8480c1b 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/CreateFeatureOnlineStore/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/CreateFeatureOnlineStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/CreateFeatureView/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/CreateFeatureView/main.go index 15d34e63bafd..7d5ca71535e9 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/CreateFeatureView/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/CreateFeatureView/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/DeleteFeatureOnlineStore/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/DeleteFeatureOnlineStore/main.go index 0143c5d2da44..969a14a5ee6f 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/DeleteFeatureOnlineStore/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/DeleteFeatureOnlineStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/DeleteFeatureView/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/DeleteFeatureView/main.go index 795debb5922f..982eb467ff7d 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/DeleteFeatureView/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/DeleteFeatureView/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/DeleteOperation/main.go index 635ee6fbb0b2..81bc4a202aad 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/GetFeatureOnlineStore/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/GetFeatureOnlineStore/main.go index 754c65798149..6ded1663202d 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/GetFeatureOnlineStore/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/GetFeatureOnlineStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/GetFeatureView/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/GetFeatureView/main.go index b14c505a0201..0fcb19c50ff6 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/GetFeatureView/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/GetFeatureView/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/GetFeatureViewSync/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/GetFeatureViewSync/main.go index 8cabc5242fa2..7fa635aef0f8 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/GetFeatureViewSync/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/GetFeatureViewSync/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/GetIamPolicy/main.go index 360995b5801d..fc6f802e565e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/GetLocation/main.go index fac723b10196..8d22d3d17e4e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/GetOperation/main.go index 79f5691be1d8..459d3c58afd0 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/ListFeatureOnlineStores/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/ListFeatureOnlineStores/main.go index cd2f5cee8e48..ef2e8af04858 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/ListFeatureOnlineStores/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/ListFeatureOnlineStores/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/ListFeatureViewSyncs/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/ListFeatureViewSyncs/main.go index c288c75703bb..799f43a7a117 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/ListFeatureViewSyncs/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/ListFeatureViewSyncs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/ListFeatureViews/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/ListFeatureViews/main.go index 3e50124a2dd8..2c815b19cda0 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/ListFeatureViews/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/ListFeatureViews/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/ListLocations/main.go index 87afb1108495..b5275e805be5 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/ListOperations/main.go index 86bb547f79f3..0b312a695c74 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/SetIamPolicy/main.go index 0283fb7a0270..9c28c13443d0 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/SyncFeatureView/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/SyncFeatureView/main.go index 955ee4c1fc75..30ea788616f5 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/SyncFeatureView/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/SyncFeatureView/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/TestIamPermissions/main.go index bfe917de1338..8e7c6033f164 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/UpdateFeatureOnlineStore/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/UpdateFeatureOnlineStore/main.go index 0283966642c2..18032e8a42e4 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/UpdateFeatureOnlineStore/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/UpdateFeatureOnlineStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/UpdateFeatureView/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/UpdateFeatureView/main.go index 43c97ab4d2d5..9abfcd3f5e41 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/UpdateFeatureView/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/UpdateFeatureView/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/WaitOperation/main.go index 7cb68df09e9d..15b412cbe139 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreAdminClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/CancelOperation/main.go index 047e3af03324..36ee15a21f15 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/DeleteOperation/main.go index 11d1715dd3af..5d30f0e2f2e8 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/FetchFeatureValues/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/FetchFeatureValues/main.go index f6d227353288..71a5cf4059fb 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/FetchFeatureValues/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/FetchFeatureValues/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/GetIamPolicy/main.go index 5352ec8570b2..7b01f5f770da 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/GetLocation/main.go index 5dc7b14c8cd7..4f16f895e7a9 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/GetOperation/main.go index 24aa949f9439..19060fd89681 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/ListLocations/main.go index db622c3386f6..da7434498fee 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/ListOperations/main.go index 7152bb28d35d..bdc8df720933 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/SearchNearestEntities/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/SearchNearestEntities/main.go index fe6d124c2e44..84d99d051bab 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/SearchNearestEntities/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/SearchNearestEntities/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/SetIamPolicy/main.go index 54eb3b41a37b..31c053e45a57 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/TestIamPermissions/main.go index 2320490ceae8..8b88d74c2ea8 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/WaitOperation/main.go index 2bd7912cd89e..6f4c2baf6734 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureOnlineStoreClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/BatchCreateFeatures/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/BatchCreateFeatures/main.go index 6e88212869e9..40510409dfad 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/BatchCreateFeatures/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/BatchCreateFeatures/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/CancelOperation/main.go index 6e09589a72a1..72dfbcba0ce4 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/CreateFeature/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/CreateFeature/main.go index 4cf5c1532f64..27bc1b01214b 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/CreateFeature/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/CreateFeature/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/CreateFeatureGroup/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/CreateFeatureGroup/main.go index a6a4782b82da..db019b2ffc78 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/CreateFeatureGroup/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/CreateFeatureGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/DeleteFeature/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/DeleteFeature/main.go index 96fc99538dbe..916a128008a9 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/DeleteFeature/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/DeleteFeature/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/DeleteFeatureGroup/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/DeleteFeatureGroup/main.go index 6a9a6fb3aecc..6a54233caa8d 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/DeleteFeatureGroup/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/DeleteFeatureGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/DeleteOperation/main.go index 1209b9e2a732..75630cb5645d 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/GetFeature/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/GetFeature/main.go index 0515c26095fd..b2cac47c9fee 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/GetFeature/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/GetFeature/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/GetFeatureGroup/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/GetFeatureGroup/main.go index df9b7255fc1b..a92f40141f14 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/GetFeatureGroup/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/GetFeatureGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/GetIamPolicy/main.go index 30415a42ba0f..c0a094be37b0 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/GetLocation/main.go index 0a8e77d9006a..14d28a877b1e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/GetOperation/main.go index 97a2df5293cd..d1fba47e9c11 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/ListFeatureGroups/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/ListFeatureGroups/main.go index 2882d4d952a2..8dc6592324bc 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/ListFeatureGroups/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/ListFeatureGroups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/ListFeatures/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/ListFeatures/main.go index 1526c46e429b..1093504147e9 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/ListFeatures/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/ListFeatures/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/ListLocations/main.go index 9bc4a9b848dd..3818b9023828 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/ListOperations/main.go index 192fe87b8be7..310beee2d71f 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/SetIamPolicy/main.go index 4d0b70540881..c113a8047dce 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/TestIamPermissions/main.go index e1180dbcfddd..fd26ab27715b 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/UpdateFeature/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/UpdateFeature/main.go index fc18c7628728..b226b5fd25e6 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/UpdateFeature/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/UpdateFeature/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/UpdateFeatureGroup/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/UpdateFeatureGroup/main.go index 59391b604684..744780e18da0 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/UpdateFeatureGroup/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/UpdateFeatureGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/WaitOperation/main.go index 2ed98d7f0e1c..00d2bed472b9 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeatureRegistryClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/BatchCreateFeatures/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/BatchCreateFeatures/main.go index 69833f1457bb..4b8959d01757 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/BatchCreateFeatures/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/BatchCreateFeatures/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/BatchReadFeatureValues/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/BatchReadFeatureValues/main.go index 680226132354..b3630e0e2a90 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/BatchReadFeatureValues/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/BatchReadFeatureValues/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/CancelOperation/main.go index c99f48b29072..351bfac2b186 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/CreateEntityType/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/CreateEntityType/main.go index 8464371ee7fa..43c39d747105 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/CreateEntityType/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/CreateEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/CreateFeature/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/CreateFeature/main.go index 3fae7c487aa0..46925873ad70 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/CreateFeature/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/CreateFeature/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/CreateFeaturestore/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/CreateFeaturestore/main.go index 2967eb31ef84..6af1e4e76487 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/CreateFeaturestore/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/CreateFeaturestore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/DeleteEntityType/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/DeleteEntityType/main.go index 7994ea43f1e5..1d2d66b0425e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/DeleteEntityType/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/DeleteEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/DeleteFeature/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/DeleteFeature/main.go index 91a2bb4f4f9a..a6d1c4d22bab 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/DeleteFeature/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/DeleteFeature/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/DeleteFeatureValues/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/DeleteFeatureValues/main.go index 9b066c746feb..97767d3616e5 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/DeleteFeatureValues/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/DeleteFeatureValues/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/DeleteFeaturestore/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/DeleteFeaturestore/main.go index 702c3ae73ab7..6b75e21fcebd 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/DeleteFeaturestore/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/DeleteFeaturestore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/DeleteOperation/main.go index 4544eb8945d6..29af87260900 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/ExportFeatureValues/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/ExportFeatureValues/main.go index 58316539fbf8..f23ac1b5325b 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/ExportFeatureValues/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/ExportFeatureValues/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/GetEntityType/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/GetEntityType/main.go index eb6f76bfa3be..14a470dba948 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/GetEntityType/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/GetEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/GetFeature/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/GetFeature/main.go index ba7c986da656..ef7f0678c27f 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/GetFeature/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/GetFeature/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/GetFeaturestore/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/GetFeaturestore/main.go index 6f5afb205750..3e1a49314673 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/GetFeaturestore/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/GetFeaturestore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/GetIamPolicy/main.go index 4010122c7609..e9c8820ff2c6 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/GetLocation/main.go index d7dda1e4afe9..18260cd5747e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/GetOperation/main.go index afe4943e43da..6581cdf639a9 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/ImportFeatureValues/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/ImportFeatureValues/main.go index 658de58e2d00..13b2f7f6bbac 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/ImportFeatureValues/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/ImportFeatureValues/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/ListEntityTypes/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/ListEntityTypes/main.go index 60a00864f154..b1bfcada95ce 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/ListEntityTypes/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/ListEntityTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/ListFeatures/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/ListFeatures/main.go index 74ce525ff074..6ce7b20748bd 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/ListFeatures/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/ListFeatures/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/ListFeaturestores/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/ListFeaturestores/main.go index 92638e8374c3..4c68cf334f65 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/ListFeaturestores/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/ListFeaturestores/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/ListLocations/main.go index 6683d4e3417b..946fedf486dd 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/ListOperations/main.go index 2df70bb5d847..a09f39189428 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/SearchFeatures/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/SearchFeatures/main.go index c5518333a79a..c6576a5dfdab 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/SearchFeatures/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/SearchFeatures/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/SetIamPolicy/main.go index 5b5c4748a5d1..b38154ccb03c 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/TestIamPermissions/main.go index 29fd7510bac5..d6cd4112b58b 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/UpdateEntityType/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/UpdateEntityType/main.go index 0ad8bd4abc11..e826d8b87fa6 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/UpdateEntityType/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/UpdateEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/UpdateFeature/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/UpdateFeature/main.go index f0debdce6510..6dd657eeea26 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/UpdateFeature/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/UpdateFeature/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/UpdateFeaturestore/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/UpdateFeaturestore/main.go index 93fc4ae3ee97..277419fe266a 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/UpdateFeaturestore/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/UpdateFeaturestore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/WaitOperation/main.go index 65f05f11daf8..c93e0de24735 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/CancelOperation/main.go index b8ccd3d71f5b..943c89aa5cba 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/DeleteOperation/main.go index ed398d36cd09..1fb4df2bbbec 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/GetIamPolicy/main.go index b2b0b246f06e..0cbb26abb680 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/GetLocation/main.go index fe4043ac6807..4bafa6d007cb 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/GetOperation/main.go index b78254174cc4..4f86beb2b753 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/ListLocations/main.go index 3fb7719cf9de..9f9566a3a9d8 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/ListOperations/main.go index 217e3b4413ad..54d815cffd64 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/ReadFeatureValues/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/ReadFeatureValues/main.go index 37840b441f36..d3a72b503777 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/ReadFeatureValues/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/ReadFeatureValues/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/SetIamPolicy/main.go index 50c5140ce88b..1831f197b1bf 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/TestIamPermissions/main.go index 0337b6ff571e..d4f13f11305a 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/WaitOperation/main.go index 8fac4a3db3af..136d432bd247 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/WriteFeatureValues/main.go b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/WriteFeatureValues/main.go index 7851f8412484..bce6166403c0 100644 --- a/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/WriteFeatureValues/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/FeaturestoreOnlineServingClient/WriteFeatureValues/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/CancelOperation/main.go index bef31605a8e2..ae340e2d6191 100644 --- a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/CancelTuningJob/main.go b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/CancelTuningJob/main.go index 4a74c5fcc104..c1680479968e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/CancelTuningJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/CancelTuningJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/CreateTuningJob/main.go b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/CreateTuningJob/main.go index 6800ccbb7fb6..85dfbfadcf6e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/CreateTuningJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/CreateTuningJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/DeleteOperation/main.go index 144accd9ab0a..6d9243215a1d 100644 --- a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/GetIamPolicy/main.go index 4184614bb8a5..498c330e4abe 100644 --- a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/GetLocation/main.go index a66f2459f479..c503ca372598 100644 --- a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/GetOperation/main.go index d2ce43f60872..228235bf4890 100644 --- a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/GetTuningJob/main.go b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/GetTuningJob/main.go index 314f31b42827..12ee6d34e4e8 100644 --- a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/GetTuningJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/GetTuningJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/ListLocations/main.go index 12ce63d0cf9c..5378adaeff72 100644 --- a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/ListOperations/main.go index 67b0f79efbbe..7e3b0884bb7e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/ListTuningJobs/main.go b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/ListTuningJobs/main.go index 848e17104aa2..5a2b62970394 100644 --- a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/ListTuningJobs/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/ListTuningJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/RebaseTunedModel/main.go b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/RebaseTunedModel/main.go index 070dee65df18..ed473d82f4d5 100644 --- a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/RebaseTunedModel/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/RebaseTunedModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/SetIamPolicy/main.go index a6305a457499..441c87cf93dd 100644 --- a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/TestIamPermissions/main.go index ad7b98b877d8..40a754bc460b 100644 --- a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/WaitOperation/main.go index 52a3e6254c8a..9dfe52363448 100644 --- a/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/GenAiTuningClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexClient/CancelOperation/main.go index e76f1c101644..3e7be54e0c7b 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexClient/CreateIndex/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexClient/CreateIndex/main.go index ed475619a0db..c0ccfbb8614e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexClient/CreateIndex/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexClient/CreateIndex/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexClient/DeleteIndex/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexClient/DeleteIndex/main.go index 0e2257aeb740..3bb545a93bce 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexClient/DeleteIndex/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexClient/DeleteIndex/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexClient/DeleteOperation/main.go index b735160bec88..70dd1e1819f4 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexClient/GetIamPolicy/main.go index 1f87c72ca35a..d74bfe60f683 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexClient/GetIndex/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexClient/GetIndex/main.go index 72911837d0e4..c57548d8d0f7 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexClient/GetIndex/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexClient/GetIndex/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexClient/GetLocation/main.go index 596a6a01220a..173fa3d3b1e4 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexClient/GetOperation/main.go index 182132b2244f..f9bb8a32d1b8 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexClient/ListIndexes/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexClient/ListIndexes/main.go index 53033ebad451..64a988b12768 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexClient/ListIndexes/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexClient/ListIndexes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexClient/ListLocations/main.go index 00320cd0b092..503b25b40d6d 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexClient/ListOperations/main.go index 783cd0455471..bc579ab4113e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexClient/RemoveDatapoints/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexClient/RemoveDatapoints/main.go index 9266aae94480..de28512bfe63 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexClient/RemoveDatapoints/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexClient/RemoveDatapoints/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexClient/SetIamPolicy/main.go index 0b1a99884d4c..b95bbe395843 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexClient/TestIamPermissions/main.go index f06174825b16..23e02667d83d 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexClient/UpdateIndex/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexClient/UpdateIndex/main.go index 496584ce2409..1d54153cb493 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexClient/UpdateIndex/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexClient/UpdateIndex/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexClient/UpsertDatapoints/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexClient/UpsertDatapoints/main.go index 2cf8371238fe..7caa453822ef 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexClient/UpsertDatapoints/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexClient/UpsertDatapoints/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexClient/WaitOperation/main.go index ff465866c349..b14a9a45ba03 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/CancelOperation/main.go index 87faee5db902..4b5c4756334f 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/CreateIndexEndpoint/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/CreateIndexEndpoint/main.go index bd22573adda1..3fba570739dc 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/CreateIndexEndpoint/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/CreateIndexEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/DeleteIndexEndpoint/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/DeleteIndexEndpoint/main.go index 0c8e21d4d762..7c18b0aee801 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/DeleteIndexEndpoint/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/DeleteIndexEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/DeleteOperation/main.go index 8580760f768b..d8f935a75609 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/DeployIndex/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/DeployIndex/main.go index 5539df2d5cbe..40833b305dd1 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/DeployIndex/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/DeployIndex/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/GetIamPolicy/main.go index c9bc5d777c90..619902696520 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/GetIndexEndpoint/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/GetIndexEndpoint/main.go index df11af2e915e..474f817aaf48 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/GetIndexEndpoint/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/GetIndexEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/GetLocation/main.go index 8c5337f6be56..c615869fffbc 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/GetOperation/main.go index 2567b76169bd..b3042a24fbbe 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/ListIndexEndpoints/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/ListIndexEndpoints/main.go index a49b079fdf85..69ffca561d92 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/ListIndexEndpoints/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/ListIndexEndpoints/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/ListLocations/main.go index e8fc7b7897d5..5be5e1cf9740 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/ListOperations/main.go index 8ac8e0863118..2580e3aa9071 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/MutateDeployedIndex/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/MutateDeployedIndex/main.go index c0842153ac1b..343a86dcd8ce 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/MutateDeployedIndex/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/MutateDeployedIndex/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/SetIamPolicy/main.go index b5cccbca88fc..622c3b2f95cd 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/TestIamPermissions/main.go index 47f40f22b2c6..ac3abef5e30b 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/UndeployIndex/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/UndeployIndex/main.go index aae5788fc0fc..bd159ae79a77 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/UndeployIndex/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/UndeployIndex/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/UpdateIndexEndpoint/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/UpdateIndexEndpoint/main.go index 75f99ee4689a..4631ae0c8241 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/UpdateIndexEndpoint/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/UpdateIndexEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/WaitOperation/main.go index 76a3bec07bda..3614ee130204 100644 --- a/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/IndexEndpointClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/CancelBatchPredictionJob/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/CancelBatchPredictionJob/main.go index 9ce4ef105900..18c3a0756a96 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/CancelBatchPredictionJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/CancelBatchPredictionJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/CancelCustomJob/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/CancelCustomJob/main.go index c9dbcb995ddc..fa662255536f 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/CancelCustomJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/CancelCustomJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/CancelDataLabelingJob/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/CancelDataLabelingJob/main.go index e2c447d9e201..bceb40b38679 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/CancelDataLabelingJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/CancelDataLabelingJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/CancelHyperparameterTuningJob/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/CancelHyperparameterTuningJob/main.go index 7acbb98d7ed8..17487002f1aa 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/CancelHyperparameterTuningJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/CancelHyperparameterTuningJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/CancelNasJob/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/CancelNasJob/main.go index f3b2e2a402f4..d1967683af7a 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/CancelNasJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/CancelNasJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/CancelOperation/main.go index 78f7b7510bbc..c7cd1037d1cf 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/CreateBatchPredictionJob/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/CreateBatchPredictionJob/main.go index 75867f784cec..ec558ca82a40 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/CreateBatchPredictionJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/CreateBatchPredictionJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/CreateCustomJob/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/CreateCustomJob/main.go index c352980c25eb..7d2f234b8f61 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/CreateCustomJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/CreateCustomJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/CreateDataLabelingJob/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/CreateDataLabelingJob/main.go index 756b59b59e60..10d314861b95 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/CreateDataLabelingJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/CreateDataLabelingJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/CreateHyperparameterTuningJob/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/CreateHyperparameterTuningJob/main.go index 4fa755173143..68c86708bc55 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/CreateHyperparameterTuningJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/CreateHyperparameterTuningJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/CreateModelDeploymentMonitoringJob/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/CreateModelDeploymentMonitoringJob/main.go index 1938553ed8c3..a986837de1b1 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/CreateModelDeploymentMonitoringJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/CreateModelDeploymentMonitoringJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/CreateNasJob/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/CreateNasJob/main.go index 901791195ac2..287dd2005e10 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/CreateNasJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/CreateNasJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/DeleteBatchPredictionJob/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/DeleteBatchPredictionJob/main.go index ee1e9906527a..45d4c752ef3e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/DeleteBatchPredictionJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/DeleteBatchPredictionJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/DeleteCustomJob/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/DeleteCustomJob/main.go index e61490c8c63d..b6d5ba280829 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/DeleteCustomJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/DeleteCustomJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/DeleteDataLabelingJob/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/DeleteDataLabelingJob/main.go index 55ea227f7bc8..05a58d20fd4b 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/DeleteDataLabelingJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/DeleteDataLabelingJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/DeleteHyperparameterTuningJob/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/DeleteHyperparameterTuningJob/main.go index a5edf606c5ba..097d0b9af25a 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/DeleteHyperparameterTuningJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/DeleteHyperparameterTuningJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/DeleteModelDeploymentMonitoringJob/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/DeleteModelDeploymentMonitoringJob/main.go index ce4d1b4d057b..82107a6e4e14 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/DeleteModelDeploymentMonitoringJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/DeleteModelDeploymentMonitoringJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/DeleteNasJob/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/DeleteNasJob/main.go index d9e957c50adb..21ee9a4f72e6 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/DeleteNasJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/DeleteNasJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/DeleteOperation/main.go index 1e017a3bf259..7a46872f827d 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/GetBatchPredictionJob/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/GetBatchPredictionJob/main.go index 6d8686f360e5..c7e378892406 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/GetBatchPredictionJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/GetBatchPredictionJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/GetCustomJob/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/GetCustomJob/main.go index 0a6ed90b1f75..29f266cbcb69 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/GetCustomJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/GetCustomJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/GetDataLabelingJob/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/GetDataLabelingJob/main.go index ecb86e43f4dd..df82b3b6f931 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/GetDataLabelingJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/GetDataLabelingJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/GetHyperparameterTuningJob/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/GetHyperparameterTuningJob/main.go index 2937fe3890be..613ecdb4d727 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/GetHyperparameterTuningJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/GetHyperparameterTuningJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/GetIamPolicy/main.go index 0b3a77fec9bd..84dff38a3db0 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/GetLocation/main.go index fe113454508d..efb5f49b6321 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/GetModelDeploymentMonitoringJob/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/GetModelDeploymentMonitoringJob/main.go index 2bed7bcd3720..0c5c303346df 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/GetModelDeploymentMonitoringJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/GetModelDeploymentMonitoringJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/GetNasJob/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/GetNasJob/main.go index f67d48874737..92bd47c3b040 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/GetNasJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/GetNasJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/GetNasTrialDetail/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/GetNasTrialDetail/main.go index 1a76d5bc9a38..87c486a10909 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/GetNasTrialDetail/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/GetNasTrialDetail/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/GetOperation/main.go index 236a1e562f34..1c20cf4b586e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/ListBatchPredictionJobs/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/ListBatchPredictionJobs/main.go index fd0c0f07646c..a7487407e9c5 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/ListBatchPredictionJobs/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/ListBatchPredictionJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/ListCustomJobs/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/ListCustomJobs/main.go index 733849809b87..2903760fc477 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/ListCustomJobs/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/ListCustomJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/ListDataLabelingJobs/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/ListDataLabelingJobs/main.go index bc7b9a6b7dc4..4874a61bf81a 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/ListDataLabelingJobs/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/ListDataLabelingJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/ListHyperparameterTuningJobs/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/ListHyperparameterTuningJobs/main.go index 8e2041415f59..caffc3cd9f9f 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/ListHyperparameterTuningJobs/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/ListHyperparameterTuningJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/ListLocations/main.go index 96d627d588ad..f9c86d092bba 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/ListModelDeploymentMonitoringJobs/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/ListModelDeploymentMonitoringJobs/main.go index f03501ee526a..87bef1e80e74 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/ListModelDeploymentMonitoringJobs/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/ListModelDeploymentMonitoringJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/ListNasJobs/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/ListNasJobs/main.go index dc05f4709cb6..1fa0b2b2d64a 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/ListNasJobs/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/ListNasJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/ListNasTrialDetails/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/ListNasTrialDetails/main.go index f7dd7855d5d5..004165842ca7 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/ListNasTrialDetails/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/ListNasTrialDetails/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/ListOperations/main.go index e88e0f3f016b..f353f338b25e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/PauseModelDeploymentMonitoringJob/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/PauseModelDeploymentMonitoringJob/main.go index b36488213a71..2ecc46f7ecc1 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/PauseModelDeploymentMonitoringJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/PauseModelDeploymentMonitoringJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/ResumeModelDeploymentMonitoringJob/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/ResumeModelDeploymentMonitoringJob/main.go index 11ef1257c10c..04b1ceaaf7cf 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/ResumeModelDeploymentMonitoringJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/ResumeModelDeploymentMonitoringJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/SearchModelDeploymentMonitoringStatsAnomalies/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/SearchModelDeploymentMonitoringStatsAnomalies/main.go index df6f040d2701..2950205cab81 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/SearchModelDeploymentMonitoringStatsAnomalies/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/SearchModelDeploymentMonitoringStatsAnomalies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/SetIamPolicy/main.go index 8cab35cbe992..be3b6a965510 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/TestIamPermissions/main.go index 075531ca2ec2..7b4f7b596309 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/UpdateModelDeploymentMonitoringJob/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/UpdateModelDeploymentMonitoringJob/main.go index 9b9de3f67b5f..a2dfbe1e484a 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/UpdateModelDeploymentMonitoringJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/UpdateModelDeploymentMonitoringJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/JobClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/JobClient/WaitOperation/main.go index fa7bec4731e7..e20ad1a0f2a9 100644 --- a/internal/generated/snippets/aiplatform/apiv1/JobClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/JobClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/CancelOperation/main.go index c37d5c7f7e3b..e089e804ba1c 100644 --- a/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/ComputeTokens/main.go b/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/ComputeTokens/main.go index 4ab3831d8593..5b017bf64c77 100644 --- a/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/ComputeTokens/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/ComputeTokens/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/CountTokens/main.go b/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/CountTokens/main.go index c0163e714325..e2fbdcf66fb5 100644 --- a/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/CountTokens/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/CountTokens/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/DeleteOperation/main.go index 2aed9c03903d..5b41eab24922 100644 --- a/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/GetIamPolicy/main.go index f6a63c77ce5f..31071e001645 100644 --- a/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/GetLocation/main.go index 0588f804e022..3e18187f8ebe 100644 --- a/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/GetOperation/main.go index 869b6f4d65d4..2a6dc314b490 100644 --- a/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/ListLocations/main.go index b233709e42c8..920de38b46fa 100644 --- a/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/ListOperations/main.go index 73be8441b645..416960cf96a3 100644 --- a/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/SetIamPolicy/main.go index 0b520e1d2c07..e186a35dda79 100644 --- a/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/TestIamPermissions/main.go index 39151890e96a..b7affe47500f 100644 --- a/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/WaitOperation/main.go index ddb711692aa6..ef13d2c1ba43 100644 --- a/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/LlmUtilityClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MatchClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/MatchClient/CancelOperation/main.go index 6b7ad72b4e89..aedef52b396c 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MatchClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MatchClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MatchClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/MatchClient/DeleteOperation/main.go index 7400d3fd4981..f4111ef1e7a5 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MatchClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MatchClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MatchClient/FindNeighbors/main.go b/internal/generated/snippets/aiplatform/apiv1/MatchClient/FindNeighbors/main.go index 515dac914494..0dc219234a9d 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MatchClient/FindNeighbors/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MatchClient/FindNeighbors/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MatchClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/MatchClient/GetIamPolicy/main.go index 87e575dd0de0..894f382a0dc5 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MatchClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MatchClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MatchClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/MatchClient/GetLocation/main.go index 25a72adccaf6..6aae838efe68 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MatchClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MatchClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MatchClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/MatchClient/GetOperation/main.go index 62c68faac7a6..f400984e3633 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MatchClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MatchClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MatchClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/MatchClient/ListLocations/main.go index d35c22c7d084..3739afd864d8 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MatchClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MatchClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MatchClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/MatchClient/ListOperations/main.go index abfed9480bc3..68d35fd68ed0 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MatchClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MatchClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MatchClient/ReadIndexDatapoints/main.go b/internal/generated/snippets/aiplatform/apiv1/MatchClient/ReadIndexDatapoints/main.go index 9b841712f43d..cea83cd01dc1 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MatchClient/ReadIndexDatapoints/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MatchClient/ReadIndexDatapoints/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MatchClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/MatchClient/SetIamPolicy/main.go index 90a0069577c9..5ea7c7a19833 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MatchClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MatchClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MatchClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/MatchClient/TestIamPermissions/main.go index 541239eb18d9..387feb66dc4c 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MatchClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MatchClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MatchClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/MatchClient/WaitOperation/main.go index c41c65d8ae18..bf6dd98d2902 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MatchClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MatchClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/AddContextArtifactsAndExecutions/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/AddContextArtifactsAndExecutions/main.go index e0f30f0c6456..d77e41968b64 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/AddContextArtifactsAndExecutions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/AddContextArtifactsAndExecutions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/AddContextChildren/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/AddContextChildren/main.go index 8cd8433f41cd..4adeaec83bdb 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/AddContextChildren/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/AddContextChildren/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/AddExecutionEvents/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/AddExecutionEvents/main.go index 896e0e1ca8c9..810d6428c8a2 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/AddExecutionEvents/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/AddExecutionEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/CancelOperation/main.go index 83fc1ff71263..0f8d12e819f0 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/CreateArtifact/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/CreateArtifact/main.go index 0cff0c1a533d..636f7e8074f1 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/CreateArtifact/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/CreateArtifact/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/CreateContext/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/CreateContext/main.go index 616b4d42e0e8..395fd2ba4e5d 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/CreateContext/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/CreateContext/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/CreateExecution/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/CreateExecution/main.go index c1185128d950..267941af0844 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/CreateExecution/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/CreateExecution/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/CreateMetadataSchema/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/CreateMetadataSchema/main.go index a6038dda465c..6ff53e5ebfce 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/CreateMetadataSchema/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/CreateMetadataSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/CreateMetadataStore/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/CreateMetadataStore/main.go index 453d552419e0..137e3f133800 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/CreateMetadataStore/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/CreateMetadataStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/DeleteArtifact/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/DeleteArtifact/main.go index 5c1aa55ab3b4..038802d11a27 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/DeleteArtifact/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/DeleteArtifact/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/DeleteContext/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/DeleteContext/main.go index 97875a0ff3a5..ec4d3e8375fd 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/DeleteContext/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/DeleteContext/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/DeleteExecution/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/DeleteExecution/main.go index 92d6d29b6dfb..0e442c3fb218 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/DeleteExecution/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/DeleteExecution/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/DeleteMetadataStore/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/DeleteMetadataStore/main.go index de18b18f06fa..140a122ac95e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/DeleteMetadataStore/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/DeleteMetadataStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/DeleteOperation/main.go index 7f9663531154..60ad665db1e0 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetArtifact/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetArtifact/main.go index 19a11736e2dd..cd93dc8243ee 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetArtifact/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetArtifact/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetContext/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetContext/main.go index 97c5bd3cd571..fd84052a0eca 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetContext/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetContext/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetExecution/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetExecution/main.go index 0fc8fd835106..e8ddcac64195 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetExecution/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetExecution/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetIamPolicy/main.go index f4d3120fb78a..d4d0702a64a3 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetLocation/main.go index 47afb36fc891..324ad478cea1 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetMetadataSchema/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetMetadataSchema/main.go index 79d4f90a7322..16eb2a711efe 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetMetadataSchema/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetMetadataSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetMetadataStore/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetMetadataStore/main.go index b8940afa4664..efa0918e374f 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetMetadataStore/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetMetadataStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetOperation/main.go index f5f92c9d9677..9133a871d26c 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/ListArtifacts/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/ListArtifacts/main.go index 382736b9ca82..454cd32ee4bf 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/ListArtifacts/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/ListArtifacts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/ListContexts/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/ListContexts/main.go index 8922e23304ef..0a1e1a87c9e4 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/ListContexts/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/ListContexts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/ListExecutions/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/ListExecutions/main.go index 1dfe85d93333..82c489ab75a6 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/ListExecutions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/ListExecutions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/ListLocations/main.go index 3574fc6944e0..39583db4b81d 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/ListMetadataSchemas/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/ListMetadataSchemas/main.go index fb2687902709..646dbbaf7fc6 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/ListMetadataSchemas/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/ListMetadataSchemas/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/ListMetadataStores/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/ListMetadataStores/main.go index fa7da19dd222..b7634db16161 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/ListMetadataStores/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/ListMetadataStores/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/ListOperations/main.go index 0ed64689510e..2c387b09dec8 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/PurgeArtifacts/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/PurgeArtifacts/main.go index 293a2e5f7765..17686cf0c2ad 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/PurgeArtifacts/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/PurgeArtifacts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/PurgeContexts/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/PurgeContexts/main.go index f174abc4963b..ed3e694d3cbe 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/PurgeContexts/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/PurgeContexts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/PurgeExecutions/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/PurgeExecutions/main.go index 1e60ec85dc5f..1b906b85ee81 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/PurgeExecutions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/PurgeExecutions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/QueryArtifactLineageSubgraph/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/QueryArtifactLineageSubgraph/main.go index a67103f0783c..bbbd4c59f890 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/QueryArtifactLineageSubgraph/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/QueryArtifactLineageSubgraph/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/QueryContextLineageSubgraph/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/QueryContextLineageSubgraph/main.go index 3653d1e121fe..aa84fd3dace8 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/QueryContextLineageSubgraph/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/QueryContextLineageSubgraph/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/QueryExecutionInputsAndOutputs/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/QueryExecutionInputsAndOutputs/main.go index 1ed4fc561e00..79e1a9079803 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/QueryExecutionInputsAndOutputs/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/QueryExecutionInputsAndOutputs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/RemoveContextChildren/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/RemoveContextChildren/main.go index c302d0dd0275..5b94dbf86e92 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/RemoveContextChildren/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/RemoveContextChildren/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/SetIamPolicy/main.go index 476afc716276..e3cc122f2ed0 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/TestIamPermissions/main.go index 66842226ffaf..aec8b85de369 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/UpdateArtifact/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/UpdateArtifact/main.go index 271b5686877d..dd145cc035e6 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/UpdateArtifact/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/UpdateArtifact/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/UpdateContext/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/UpdateContext/main.go index 45edd0362f83..9883012e4f48 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/UpdateContext/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/UpdateContext/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/UpdateExecution/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/UpdateExecution/main.go index 7bf884a6abf3..9ef32ba5afca 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/UpdateExecution/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/UpdateExecution/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/WaitOperation/main.go index dc214f1db2f3..e39f4eb9ec70 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MetadataClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MetadataClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MigrationClient/BatchMigrateResources/main.go b/internal/generated/snippets/aiplatform/apiv1/MigrationClient/BatchMigrateResources/main.go index f58a3c05b47a..d9ab36bbebdd 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MigrationClient/BatchMigrateResources/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MigrationClient/BatchMigrateResources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MigrationClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/MigrationClient/CancelOperation/main.go index a8cd3c6d9e67..99b582728184 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MigrationClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MigrationClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MigrationClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/MigrationClient/DeleteOperation/main.go index b978963b4089..6ac0c3059f45 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MigrationClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MigrationClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MigrationClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/MigrationClient/GetIamPolicy/main.go index fdd34af18dcb..9f7b39944b20 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MigrationClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MigrationClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MigrationClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/MigrationClient/GetLocation/main.go index 7dedc7486f66..d629bb30de62 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MigrationClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MigrationClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MigrationClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/MigrationClient/GetOperation/main.go index b3c9fc805171..caa1f1b0343d 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MigrationClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MigrationClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MigrationClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/MigrationClient/ListLocations/main.go index 03b944f36151..bf7902a363cb 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MigrationClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MigrationClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MigrationClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/MigrationClient/ListOperations/main.go index a763a1832f39..7a32205619bb 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MigrationClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MigrationClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MigrationClient/SearchMigratableResources/main.go b/internal/generated/snippets/aiplatform/apiv1/MigrationClient/SearchMigratableResources/main.go index f6c8a38ec3df..9bcfe5a58626 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MigrationClient/SearchMigratableResources/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MigrationClient/SearchMigratableResources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MigrationClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/MigrationClient/SetIamPolicy/main.go index 6aff65abeb53..b850e157a293 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MigrationClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MigrationClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MigrationClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/MigrationClient/TestIamPermissions/main.go index 7ec4958ecef5..4688cecb41f2 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MigrationClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MigrationClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/MigrationClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/MigrationClient/WaitOperation/main.go index 8d08645ec88a..47c408eec442 100644 --- a/internal/generated/snippets/aiplatform/apiv1/MigrationClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/MigrationClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelClient/BatchImportEvaluatedAnnotations/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelClient/BatchImportEvaluatedAnnotations/main.go index c9db15773b96..e74fc08c6c73 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelClient/BatchImportEvaluatedAnnotations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelClient/BatchImportEvaluatedAnnotations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelClient/BatchImportModelEvaluationSlices/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelClient/BatchImportModelEvaluationSlices/main.go index c4724a33a359..686b785ef7ca 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelClient/BatchImportModelEvaluationSlices/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelClient/BatchImportModelEvaluationSlices/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelClient/CancelOperation/main.go index e5f4c52a0b10..83f2d632ea05 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelClient/CopyModel/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelClient/CopyModel/main.go index 9a77d70fb2ce..7baf43aa0e3c 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelClient/CopyModel/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelClient/CopyModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelClient/DeleteModel/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelClient/DeleteModel/main.go index 016e33e6249a..9ee8068e4360 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelClient/DeleteModel/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelClient/DeleteModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelClient/DeleteModelVersion/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelClient/DeleteModelVersion/main.go index f0dfa9d9c04b..360ba2c9ecfb 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelClient/DeleteModelVersion/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelClient/DeleteModelVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelClient/DeleteOperation/main.go index 29cd68bc372d..f7be6ef6322d 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelClient/ExportModel/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelClient/ExportModel/main.go index 262e08d457f7..f09459051576 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelClient/ExportModel/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelClient/ExportModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelClient/GetIamPolicy/main.go index 50e420b7ac9b..28d2431621e7 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelClient/GetLocation/main.go index 2ec86fd88d05..b9c9c9d4f758 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelClient/GetModel/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelClient/GetModel/main.go index 9da3ff753005..ebe476d6c8f2 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelClient/GetModel/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelClient/GetModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelClient/GetModelEvaluation/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelClient/GetModelEvaluation/main.go index 6e2f3ce5b6a7..88eaccdc4d41 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelClient/GetModelEvaluation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelClient/GetModelEvaluation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelClient/GetModelEvaluationSlice/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelClient/GetModelEvaluationSlice/main.go index 4f485553c273..be852a530a20 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelClient/GetModelEvaluationSlice/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelClient/GetModelEvaluationSlice/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelClient/GetOperation/main.go index 5e2b61295ec4..209162f692e6 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelClient/ImportModelEvaluation/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelClient/ImportModelEvaluation/main.go index e9a5c03e6b9a..eb927672cceb 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelClient/ImportModelEvaluation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelClient/ImportModelEvaluation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelClient/ListLocations/main.go index 2a6f08af0cff..012d1b728618 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelClient/ListModelEvaluationSlices/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelClient/ListModelEvaluationSlices/main.go index 80611b8f8d27..1ecab13b0cb1 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelClient/ListModelEvaluationSlices/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelClient/ListModelEvaluationSlices/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelClient/ListModelEvaluations/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelClient/ListModelEvaluations/main.go index decd629a307a..7041a2a68bd0 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelClient/ListModelEvaluations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelClient/ListModelEvaluations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelClient/ListModelVersions/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelClient/ListModelVersions/main.go index 95659d54ffd0..46e15873f100 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelClient/ListModelVersions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelClient/ListModelVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelClient/ListModels/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelClient/ListModels/main.go index 6c91f7aa0b54..db0ff934d5d0 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelClient/ListModels/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelClient/ListModels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelClient/ListOperations/main.go index 89124e998ef1..0347480d9112 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelClient/MergeVersionAliases/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelClient/MergeVersionAliases/main.go index ab3fa4aa84b6..15d4c4e5f8d3 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelClient/MergeVersionAliases/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelClient/MergeVersionAliases/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelClient/SetIamPolicy/main.go index 6082c6169483..da10733c92e5 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelClient/TestIamPermissions/main.go index e3b028e67a80..a0fc02db441a 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelClient/UpdateExplanationDataset/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelClient/UpdateExplanationDataset/main.go index 4a3d2d5f5b81..d8303095ea86 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelClient/UpdateExplanationDataset/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelClient/UpdateExplanationDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelClient/UpdateModel/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelClient/UpdateModel/main.go index d20e479aae7e..1809222676e7 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelClient/UpdateModel/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelClient/UpdateModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelClient/UploadModel/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelClient/UploadModel/main.go index bb8557516f27..adeb6446883a 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelClient/UploadModel/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelClient/UploadModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelClient/WaitOperation/main.go index 8b897b671ee6..d586a6a1c908 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/CancelOperation/main.go index 586a4fdcadaa..81e06e3bb003 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/DeleteOperation/main.go index ef55c72624ec..a76e746f2673 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/GetIamPolicy/main.go index b8ba2bbd3f22..6ee1528c60ed 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/GetLocation/main.go index 1119f3bceab0..771a398924c3 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/GetOperation/main.go index 789f37d09359..86990677559d 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/GetPublisherModel/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/GetPublisherModel/main.go index 9060fb7c6c84..7e6254a3d061 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/GetPublisherModel/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/GetPublisherModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/ListLocations/main.go index 8a7fe1a53a7c..49bfa700c2d9 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/ListOperations/main.go index 2038a9dc7f64..73cf1c3b7f82 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/SetIamPolicy/main.go index 1cba27d30a8e..8aa9d083079f 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/TestIamPermissions/main.go index af091c5037c2..369484369939 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/WaitOperation/main.go index 96c155984a01..4336f8eac171 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ModelGardenClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/AssignNotebookRuntime/main.go b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/AssignNotebookRuntime/main.go index a5b24eb05d47..523539e860f2 100644 --- a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/AssignNotebookRuntime/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/AssignNotebookRuntime/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/CancelOperation/main.go index fb43bb0d6e86..0c9181ac2e3f 100644 --- a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/CreateNotebookExecutionJob/main.go b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/CreateNotebookExecutionJob/main.go index a3feac7a0911..618c58471f78 100644 --- a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/CreateNotebookExecutionJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/CreateNotebookExecutionJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/CreateNotebookRuntimeTemplate/main.go b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/CreateNotebookRuntimeTemplate/main.go index d05e562d6d0c..e2fdd8fc1b9a 100644 --- a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/CreateNotebookRuntimeTemplate/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/CreateNotebookRuntimeTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/DeleteNotebookExecutionJob/main.go b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/DeleteNotebookExecutionJob/main.go index 08b4316c5936..812604bacc50 100644 --- a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/DeleteNotebookExecutionJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/DeleteNotebookExecutionJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/DeleteNotebookRuntime/main.go b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/DeleteNotebookRuntime/main.go index ca748e2ea7cc..57c6e85cdc0b 100644 --- a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/DeleteNotebookRuntime/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/DeleteNotebookRuntime/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/DeleteNotebookRuntimeTemplate/main.go b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/DeleteNotebookRuntimeTemplate/main.go index 67e75526c6ae..5812d04d2f22 100644 --- a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/DeleteNotebookRuntimeTemplate/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/DeleteNotebookRuntimeTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/DeleteOperation/main.go index 6399cbd5fbd2..100f8cc12e3c 100644 --- a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/GetIamPolicy/main.go index 9f8cb5f0ccd0..d3c1e12bbaa9 100644 --- a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/GetLocation/main.go index 69bfc2239ae1..ffe600118564 100644 --- a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/GetNotebookExecutionJob/main.go b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/GetNotebookExecutionJob/main.go index 54246b5fa2a6..9004db76642f 100644 --- a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/GetNotebookExecutionJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/GetNotebookExecutionJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/GetNotebookRuntime/main.go b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/GetNotebookRuntime/main.go index e02da6e6b589..57657f88530f 100644 --- a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/GetNotebookRuntime/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/GetNotebookRuntime/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/GetNotebookRuntimeTemplate/main.go b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/GetNotebookRuntimeTemplate/main.go index fccfc9224f31..71e809c4368c 100644 --- a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/GetNotebookRuntimeTemplate/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/GetNotebookRuntimeTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/GetOperation/main.go index d0cbc3bac1fa..88fa0ae64b66 100644 --- a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/ListLocations/main.go index b052fef79228..7368fda177fd 100644 --- a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/ListNotebookExecutionJobs/main.go b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/ListNotebookExecutionJobs/main.go index b4a77838861c..ff20e7c69db1 100644 --- a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/ListNotebookExecutionJobs/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/ListNotebookExecutionJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/ListNotebookRuntimeTemplates/main.go b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/ListNotebookRuntimeTemplates/main.go index e1741ed56f57..c815fe23e0df 100644 --- a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/ListNotebookRuntimeTemplates/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/ListNotebookRuntimeTemplates/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/ListNotebookRuntimes/main.go b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/ListNotebookRuntimes/main.go index 2f8e229a275d..fbe9ca87d66d 100644 --- a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/ListNotebookRuntimes/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/ListNotebookRuntimes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/ListOperations/main.go index b7527b0f35d5..fe1c75b88b97 100644 --- a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/SetIamPolicy/main.go index e4725e23e0f8..10d5f0ca0588 100644 --- a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/StartNotebookRuntime/main.go b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/StartNotebookRuntime/main.go index f5640f89c4a2..6174e3a75766 100644 --- a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/StartNotebookRuntime/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/StartNotebookRuntime/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/StopNotebookRuntime/main.go b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/StopNotebookRuntime/main.go index a280cb363320..b003720dec17 100644 --- a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/StopNotebookRuntime/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/StopNotebookRuntime/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/TestIamPermissions/main.go index 04f37830bff6..177f97d5f700 100644 --- a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/UpdateNotebookRuntimeTemplate/main.go b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/UpdateNotebookRuntimeTemplate/main.go index e81d38f90197..4c34d24540e1 100644 --- a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/UpdateNotebookRuntimeTemplate/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/UpdateNotebookRuntimeTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/UpgradeNotebookRuntime/main.go b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/UpgradeNotebookRuntime/main.go index 9277e67fe59f..6669491a5ec8 100644 --- a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/UpgradeNotebookRuntime/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/UpgradeNotebookRuntime/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/WaitOperation/main.go index b0414c769b9c..e0331533741a 100644 --- a/internal/generated/snippets/aiplatform/apiv1/NotebookClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/NotebookClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/CancelOperation/main.go index dc4581ee227d..9e27748e7bed 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/CreatePersistentResource/main.go b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/CreatePersistentResource/main.go index 06aa342b3495..15c1cb949d01 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/CreatePersistentResource/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/CreatePersistentResource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/DeleteOperation/main.go index e298da0be500..e65c095c9ea6 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/DeletePersistentResource/main.go b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/DeletePersistentResource/main.go index a2a17b3e4d07..e2301b15b363 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/DeletePersistentResource/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/DeletePersistentResource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/GetIamPolicy/main.go index b9fa4e76daf1..4bb091876b7e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/GetLocation/main.go index a3c2c3fab5d4..bde858acd461 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/GetOperation/main.go index ce1f085195fc..ca219735370f 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/GetPersistentResource/main.go b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/GetPersistentResource/main.go index 11ba96c25c74..7ef6ccf81ae4 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/GetPersistentResource/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/GetPersistentResource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/ListLocations/main.go index 1bedc9f3cdd2..0767c88bab17 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/ListOperations/main.go index abdd0123e5c8..ed74873ea1f3 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/ListPersistentResources/main.go b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/ListPersistentResources/main.go index cf1f3b665f6f..fda2420dc910 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/ListPersistentResources/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/ListPersistentResources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/RebootPersistentResource/main.go b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/RebootPersistentResource/main.go index be978140a919..8fa9f522896f 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/RebootPersistentResource/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/RebootPersistentResource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/SetIamPolicy/main.go index 6e77a47c217d..f3efc27a620c 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/TestIamPermissions/main.go index cb54d80cc913..bd99271d106e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/UpdatePersistentResource/main.go b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/UpdatePersistentResource/main.go index 9e9a2f9e7a94..f89109566a71 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/UpdatePersistentResource/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/UpdatePersistentResource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/WaitOperation/main.go index bbca16c813ce..57f03162409f 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PersistentResourceClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/BatchCancelPipelineJobs/main.go b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/BatchCancelPipelineJobs/main.go index 3cf0f3c2e976..fd659d17efaa 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/BatchCancelPipelineJobs/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/BatchCancelPipelineJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/BatchDeletePipelineJobs/main.go b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/BatchDeletePipelineJobs/main.go index 4d9302db1fa4..55ca05171da4 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/BatchDeletePipelineJobs/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/BatchDeletePipelineJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/CancelOperation/main.go index 6be24d27aa0d..0e37eba2f112 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/CancelPipelineJob/main.go b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/CancelPipelineJob/main.go index 122aa7d7571c..018c0883a248 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/CancelPipelineJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/CancelPipelineJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/CancelTrainingPipeline/main.go b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/CancelTrainingPipeline/main.go index 9fdd46328157..2f388af93030 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/CancelTrainingPipeline/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/CancelTrainingPipeline/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/CreatePipelineJob/main.go b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/CreatePipelineJob/main.go index 2d95d78fd04b..0236c401596f 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/CreatePipelineJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/CreatePipelineJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/CreateTrainingPipeline/main.go b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/CreateTrainingPipeline/main.go index 367faf22a638..b117f04fe930 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/CreateTrainingPipeline/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/CreateTrainingPipeline/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/DeleteOperation/main.go index db24b7c193bc..86e777ff5443 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/DeletePipelineJob/main.go b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/DeletePipelineJob/main.go index fcf85be73b32..adb56a505e8d 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/DeletePipelineJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/DeletePipelineJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/DeleteTrainingPipeline/main.go b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/DeleteTrainingPipeline/main.go index 8f68bccb46a4..a1e42d20e5ae 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/DeleteTrainingPipeline/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/DeleteTrainingPipeline/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/GetIamPolicy/main.go index eaa7ee338258..ade129546abf 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/GetLocation/main.go index 0ae8795de33f..3f32edc9e1e4 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/GetOperation/main.go index 34173f250f5e..6424a0d590d6 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/GetPipelineJob/main.go b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/GetPipelineJob/main.go index a5548b3c04dd..6cfefb822580 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/GetPipelineJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/GetPipelineJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/GetTrainingPipeline/main.go b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/GetTrainingPipeline/main.go index 4282897d3d2a..16a43c7088d7 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/GetTrainingPipeline/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/GetTrainingPipeline/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/ListLocations/main.go index b31f96738988..4ee1f3e4debf 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/ListOperations/main.go index 79ea4d34ac03..9f34286f62fe 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/ListPipelineJobs/main.go b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/ListPipelineJobs/main.go index 7e1a05524ce8..f481f0255c0b 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/ListPipelineJobs/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/ListPipelineJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/ListTrainingPipelines/main.go b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/ListTrainingPipelines/main.go index fd7981a4bf24..61b04edc4ee4 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/ListTrainingPipelines/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/ListTrainingPipelines/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/SetIamPolicy/main.go index 5a5c0c3f8dd9..5dcb2106fa3d 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/TestIamPermissions/main.go index 4bf9f47d7fbf..0eb58cf86c24 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/WaitOperation/main.go index a6d7d60dc594..346978bdfd5e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PipelineClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PipelineClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/CancelOperation/main.go index 2e7eb50c7c03..b465ac0aadb0 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/DeleteOperation/main.go index 5e327cad4523..44974b0caf34 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/DirectPredict/main.go b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/DirectPredict/main.go index 4d4c3432bfd6..fe088473ee32 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/DirectPredict/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/DirectPredict/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/DirectRawPredict/main.go b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/DirectRawPredict/main.go index 7d118b785586..df1ef7d1629f 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/DirectRawPredict/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/DirectRawPredict/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/Explain/main.go b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/Explain/main.go index 5416d746ba94..e83599ece178 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/Explain/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/Explain/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/GenerateContent/main.go b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/GenerateContent/main.go index f4af1456cebd..fbdf07152546 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/GenerateContent/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/GenerateContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/GetIamPolicy/main.go index f5d279b7f35f..6bbd8602fb50 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/GetLocation/main.go index 53e0962eb870..fbe4ecb3255a 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/GetOperation/main.go index 212d121e95e3..ac9e6af32610 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/ListLocations/main.go index aaf8bd7077f0..f30f752b69c1 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/ListOperations/main.go index d648ed906f71..c45273883ac7 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/Predict/main.go b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/Predict/main.go index e2593ebcf298..05480119c078 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/Predict/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/Predict/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/RawPredict/main.go b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/RawPredict/main.go index 95fcd77eec3c..a72e2c6638c7 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/RawPredict/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/RawPredict/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/SetIamPolicy/main.go index dd78fe54264c..ba926da8779f 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/StreamDirectPredict/main.go b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/StreamDirectPredict/main.go index 8692bd534150..f8e6f85226a1 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/StreamDirectPredict/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/StreamDirectPredict/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/StreamDirectRawPredict/main.go b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/StreamDirectRawPredict/main.go index fdbd6a57f192..184a3cf0560c 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/StreamDirectRawPredict/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/StreamDirectRawPredict/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/StreamingPredict/main.go b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/StreamingPredict/main.go index 526984ad6684..a5ee457955b1 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/StreamingPredict/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/StreamingPredict/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/StreamingRawPredict/main.go b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/StreamingRawPredict/main.go index 882f42a5a7db..67e86292a255 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/StreamingRawPredict/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/StreamingRawPredict/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/TestIamPermissions/main.go index e840c75f4258..7c5e33adac87 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/WaitOperation/main.go index e03818d80145..14fbaba15db3 100644 --- a/internal/generated/snippets/aiplatform/apiv1/PredictionClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/PredictionClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/CancelOperation/main.go index 9bb373908793..67e38337bb5d 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/CreateSchedule/main.go b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/CreateSchedule/main.go index 3d0ea8615782..b533600f4196 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/CreateSchedule/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/CreateSchedule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/DeleteOperation/main.go index 22859efe9a0d..8a0f29e77722 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/DeleteSchedule/main.go b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/DeleteSchedule/main.go index e681f4d39a9c..f3c4c760aa49 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/DeleteSchedule/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/DeleteSchedule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/GetIamPolicy/main.go index fe232f99fc10..69961da229d1 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/GetLocation/main.go index d5a2154c3ebe..0576b4816e1b 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/GetOperation/main.go index 25b85b6ed075..a172fa2f175f 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/GetSchedule/main.go b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/GetSchedule/main.go index 486f4714af18..38ab76a0461f 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/GetSchedule/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/GetSchedule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/ListLocations/main.go index 23ec58df1a5f..7d047a5f5bab 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/ListOperations/main.go index e434b2158016..41629e3d4f57 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/ListSchedules/main.go b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/ListSchedules/main.go index 38229a7160c3..37e450ef0afa 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/ListSchedules/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/ListSchedules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/PauseSchedule/main.go b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/PauseSchedule/main.go index fd42704324ec..b0dbd5cd2b2e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/PauseSchedule/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/PauseSchedule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/ResumeSchedule/main.go b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/ResumeSchedule/main.go index 321fc63d3059..acd50c3353c0 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/ResumeSchedule/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/ResumeSchedule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/SetIamPolicy/main.go index 9753330a433b..1e4876418726 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/TestIamPermissions/main.go index 814bd1d8d197..f4d029be8bd5 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/UpdateSchedule/main.go b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/UpdateSchedule/main.go index adf10e789f04..792f3e04a819 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/UpdateSchedule/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/UpdateSchedule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/WaitOperation/main.go index bdcca82425bd..a91de73fcdae 100644 --- a/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/ScheduleClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/CancelOperation/main.go index 039486bee3eb..cffb172d86da 100644 --- a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/CreateSpecialistPool/main.go b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/CreateSpecialistPool/main.go index 1052ed385859..965523794898 100644 --- a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/CreateSpecialistPool/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/CreateSpecialistPool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/DeleteOperation/main.go index 6c7873a9d4a6..1b6529c33c4d 100644 --- a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/DeleteSpecialistPool/main.go b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/DeleteSpecialistPool/main.go index 0522459f5ef8..44375772c014 100644 --- a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/DeleteSpecialistPool/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/DeleteSpecialistPool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/GetIamPolicy/main.go index 4e132028b4f2..df9b2ce4ea21 100644 --- a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/GetLocation/main.go index 6ebbbec7ccbf..d1cb5c394992 100644 --- a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/GetOperation/main.go index f7ba637a54e4..7f8c1730d87e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/GetSpecialistPool/main.go b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/GetSpecialistPool/main.go index d6f92db7392f..bc6f9d629728 100644 --- a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/GetSpecialistPool/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/GetSpecialistPool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/ListLocations/main.go index bdf097925240..b445ca92e731 100644 --- a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/ListOperations/main.go index b1b6cb757f73..9603b12dcdf6 100644 --- a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/ListSpecialistPools/main.go b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/ListSpecialistPools/main.go index 2440cbd17c5a..436b1d23b818 100644 --- a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/ListSpecialistPools/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/ListSpecialistPools/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/SetIamPolicy/main.go index 0156f4e914e0..2f2bee5c2818 100644 --- a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/TestIamPermissions/main.go index 47b2fc0fbf62..7f0842ad90ab 100644 --- a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/UpdateSpecialistPool/main.go b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/UpdateSpecialistPool/main.go index fcb0c9e72cac..e13f38ff2bd5 100644 --- a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/UpdateSpecialistPool/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/UpdateSpecialistPool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/WaitOperation/main.go index a410d3f53139..cfb79305a40c 100644 --- a/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/SpecialistPoolClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/BatchCreateTensorboardRuns/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/BatchCreateTensorboardRuns/main.go index 52fbc816fde7..e559e2c339aa 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/BatchCreateTensorboardRuns/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/BatchCreateTensorboardRuns/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/BatchCreateTensorboardTimeSeries/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/BatchCreateTensorboardTimeSeries/main.go index 94f4663d1d65..b91c368808f9 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/BatchCreateTensorboardTimeSeries/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/BatchCreateTensorboardTimeSeries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/BatchReadTensorboardTimeSeriesData/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/BatchReadTensorboardTimeSeriesData/main.go index 29da515001d8..8ba5bb0621c4 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/BatchReadTensorboardTimeSeriesData/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/BatchReadTensorboardTimeSeriesData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/CancelOperation/main.go index 1868ad04b51d..7ae1e52f87ef 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/CreateTensorboard/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/CreateTensorboard/main.go index 08d271ee6757..7cecda3c5272 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/CreateTensorboard/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/CreateTensorboard/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/CreateTensorboardExperiment/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/CreateTensorboardExperiment/main.go index bd8993418ee3..f68226aeb4ed 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/CreateTensorboardExperiment/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/CreateTensorboardExperiment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/CreateTensorboardRun/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/CreateTensorboardRun/main.go index 1722262ef360..81060ac1b28e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/CreateTensorboardRun/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/CreateTensorboardRun/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/CreateTensorboardTimeSeries/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/CreateTensorboardTimeSeries/main.go index 0e82241fa621..6e325c85eb43 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/CreateTensorboardTimeSeries/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/CreateTensorboardTimeSeries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/DeleteOperation/main.go index 854891485516..dd2a08f0ef06 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/DeleteTensorboard/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/DeleteTensorboard/main.go index 473d2bcac867..0c5c4edf3cd2 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/DeleteTensorboard/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/DeleteTensorboard/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/DeleteTensorboardExperiment/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/DeleteTensorboardExperiment/main.go index 7418f441f96c..701c75c1db4d 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/DeleteTensorboardExperiment/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/DeleteTensorboardExperiment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/DeleteTensorboardRun/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/DeleteTensorboardRun/main.go index 6eb2af254ae8..20d4275a4d0e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/DeleteTensorboardRun/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/DeleteTensorboardRun/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/DeleteTensorboardTimeSeries/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/DeleteTensorboardTimeSeries/main.go index f3f8fdb713c4..1c9e73c451fa 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/DeleteTensorboardTimeSeries/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/DeleteTensorboardTimeSeries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ExportTensorboardTimeSeriesData/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ExportTensorboardTimeSeriesData/main.go index 005aa122b029..deafa1ffa1a9 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ExportTensorboardTimeSeriesData/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ExportTensorboardTimeSeriesData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/GetIamPolicy/main.go index 07c6920acb80..a75c3cf3a2ea 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/GetLocation/main.go index 934e0deeb149..bbcf4a84fa18 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/GetOperation/main.go index 6ff35c70252c..db00e5a8f768 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/GetTensorboard/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/GetTensorboard/main.go index 223e79476780..0beb528663ee 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/GetTensorboard/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/GetTensorboard/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/GetTensorboardExperiment/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/GetTensorboardExperiment/main.go index 69c3f6d67f2f..6c67008d23a5 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/GetTensorboardExperiment/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/GetTensorboardExperiment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/GetTensorboardRun/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/GetTensorboardRun/main.go index 142a5c732742..08de1639dced 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/GetTensorboardRun/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/GetTensorboardRun/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/GetTensorboardTimeSeries/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/GetTensorboardTimeSeries/main.go index a973ad56e3c1..a0bfe09cf242 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/GetTensorboardTimeSeries/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/GetTensorboardTimeSeries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ListLocations/main.go index d726cdb70689..e7facc0aaec9 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ListOperations/main.go index f0eed65996c2..002af9944277 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ListTensorboardExperiments/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ListTensorboardExperiments/main.go index b3110e6ae9a2..7ef0e300f084 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ListTensorboardExperiments/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ListTensorboardExperiments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ListTensorboardRuns/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ListTensorboardRuns/main.go index f3156da40f38..369831d59b39 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ListTensorboardRuns/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ListTensorboardRuns/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ListTensorboardTimeSeries/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ListTensorboardTimeSeries/main.go index 40f5429f365c..17baff58d3af 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ListTensorboardTimeSeries/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ListTensorboardTimeSeries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ListTensorboards/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ListTensorboards/main.go index cc138b30b6e9..b3e2ef7866a8 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ListTensorboards/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ListTensorboards/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ReadTensorboardSize/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ReadTensorboardSize/main.go index b08eb262f233..9903b4669268 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ReadTensorboardSize/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ReadTensorboardSize/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ReadTensorboardTimeSeriesData/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ReadTensorboardTimeSeriesData/main.go index 2789f8c0b711..41cc089c838b 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ReadTensorboardTimeSeriesData/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ReadTensorboardTimeSeriesData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ReadTensorboardUsage/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ReadTensorboardUsage/main.go index d860c27370b6..50be1aa1893a 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ReadTensorboardUsage/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/ReadTensorboardUsage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/SetIamPolicy/main.go index a9a0cc6a158f..b516b458ca8a 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/TestIamPermissions/main.go index e74144412d91..1ba593226d9a 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/UpdateTensorboard/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/UpdateTensorboard/main.go index 9c772779a8fc..40b1f89f6c53 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/UpdateTensorboard/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/UpdateTensorboard/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/UpdateTensorboardExperiment/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/UpdateTensorboardExperiment/main.go index 6d15d0c736e3..5c518c00fba8 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/UpdateTensorboardExperiment/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/UpdateTensorboardExperiment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/UpdateTensorboardRun/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/UpdateTensorboardRun/main.go index b2d41c431344..bf4f4317f9be 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/UpdateTensorboardRun/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/UpdateTensorboardRun/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/UpdateTensorboardTimeSeries/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/UpdateTensorboardTimeSeries/main.go index 1954ae517050..02b2b6b8d9d1 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/UpdateTensorboardTimeSeries/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/UpdateTensorboardTimeSeries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/WaitOperation/main.go index f17a443332e3..354bcc9e96de 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/WriteTensorboardExperimentData/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/WriteTensorboardExperimentData/main.go index b5b55ae3b28b..3e6c1a408d9c 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/WriteTensorboardExperimentData/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/WriteTensorboardExperimentData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/WriteTensorboardRunData/main.go b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/WriteTensorboardRunData/main.go index e4dff942e03b..caece1b968bc 100644 --- a/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/WriteTensorboardRunData/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/TensorboardClient/WriteTensorboardRunData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/AugmentPrompt/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/AugmentPrompt/main.go index b4030f7976f7..817a83382534 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/AugmentPrompt/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/AugmentPrompt/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/CancelOperation/main.go index 1854ae3baed8..80e0797b23a4 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/CorroborateContent/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/CorroborateContent/main.go index 9c4940f2bbe5..bcfa97e587e5 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/CorroborateContent/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/CorroborateContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/DeleteOperation/main.go index 4f011cd5644f..76ea3ff185ff 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/GetIamPolicy/main.go index fce914cd5b28..48550fadb38d 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/GetLocation/main.go index b518d868f043..c117cc16d27e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/GetOperation/main.go index 8b34e358f970..de1864a29128 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/ListLocations/main.go index 1da3d5d961a5..4961425f48e3 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/ListOperations/main.go index 90afdb4d722a..5209697cd7da 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/RetrieveContexts/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/RetrieveContexts/main.go index a1cd2d3422af..6117d5fffa69 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/RetrieveContexts/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/RetrieveContexts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/SetIamPolicy/main.go index dd637894bc08..2a0f0a6d27ae 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/TestIamPermissions/main.go index 169d3d45af71..bdb6fed0cba2 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/WaitOperation/main.go index 84184a84392d..a319f412d38b 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/CancelOperation/main.go index c1e23b023af7..97bff611a803 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/CreateRagCorpus/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/CreateRagCorpus/main.go index 8a12d6982c1a..778ead4ff53b 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/CreateRagCorpus/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/CreateRagCorpus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/DeleteOperation/main.go index 19c01e28ae57..55e9e5daee6a 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/DeleteRagCorpus/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/DeleteRagCorpus/main.go index 0dfe5c7f8053..771bb382b21b 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/DeleteRagCorpus/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/DeleteRagCorpus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/DeleteRagFile/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/DeleteRagFile/main.go index d35200f452e7..9f7278628a1c 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/DeleteRagFile/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/DeleteRagFile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/GetIamPolicy/main.go index d69529331f5c..211c55b938cf 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/GetLocation/main.go index 55aa28bea313..fefc4c2a689f 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/GetOperation/main.go index 71628bd966b3..4d331cf5fcfb 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/GetRagCorpus/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/GetRagCorpus/main.go index ea9f77a3f8b5..b22c932fe6f6 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/GetRagCorpus/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/GetRagCorpus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/GetRagFile/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/GetRagFile/main.go index 0e928ab35782..909476e2b07e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/GetRagFile/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/GetRagFile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/ImportRagFiles/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/ImportRagFiles/main.go index 2d596476c3a9..2c7b7d03b22d 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/ImportRagFiles/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/ImportRagFiles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/ListLocations/main.go index 4ef7037250e1..46dcc56394ea 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/ListOperations/main.go index e8f2ae7719b2..3f45691b9391 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/ListRagCorpora/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/ListRagCorpora/main.go index f57d49b0f0ab..2252d1f9d245 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/ListRagCorpora/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/ListRagCorpora/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/ListRagFiles/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/ListRagFiles/main.go index ca0e87b2d0df..9d1eb552f65e 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/ListRagFiles/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/ListRagFiles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/SetIamPolicy/main.go index 06aecf018e35..49c0fe4793de 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/TestIamPermissions/main.go index 99e3ededde7c..2c0203f85467 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/UpdateRagCorpus/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/UpdateRagCorpus/main.go index ee688cbbdf90..b448ce2b0c24 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/UpdateRagCorpus/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/UpdateRagCorpus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/UploadRagFile/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/UploadRagFile/main.go index 2a991b134a7b..3eadedd74ca2 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/UploadRagFile/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/UploadRagFile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/WaitOperation/main.go index ed16832aa984..0e32a45c92d9 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VertexRagDataClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VizierClient/AddTrialMeasurement/main.go b/internal/generated/snippets/aiplatform/apiv1/VizierClient/AddTrialMeasurement/main.go index e3b5ddbd321b..1f2f4ae83018 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VizierClient/AddTrialMeasurement/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VizierClient/AddTrialMeasurement/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VizierClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/VizierClient/CancelOperation/main.go index 793858d62486..36c6e18d4cd9 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VizierClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VizierClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VizierClient/CheckTrialEarlyStoppingState/main.go b/internal/generated/snippets/aiplatform/apiv1/VizierClient/CheckTrialEarlyStoppingState/main.go index d45639fcab83..bd01f4ba52f3 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VizierClient/CheckTrialEarlyStoppingState/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VizierClient/CheckTrialEarlyStoppingState/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VizierClient/CompleteTrial/main.go b/internal/generated/snippets/aiplatform/apiv1/VizierClient/CompleteTrial/main.go index a0d369451b6d..34f596b8fea8 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VizierClient/CompleteTrial/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VizierClient/CompleteTrial/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VizierClient/CreateStudy/main.go b/internal/generated/snippets/aiplatform/apiv1/VizierClient/CreateStudy/main.go index aba5b834399d..0786f8711577 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VizierClient/CreateStudy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VizierClient/CreateStudy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VizierClient/CreateTrial/main.go b/internal/generated/snippets/aiplatform/apiv1/VizierClient/CreateTrial/main.go index 702e94833eb6..4c1f9c38cb02 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VizierClient/CreateTrial/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VizierClient/CreateTrial/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VizierClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/VizierClient/DeleteOperation/main.go index 8f553e87297c..eebd83a32d07 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VizierClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VizierClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VizierClient/DeleteStudy/main.go b/internal/generated/snippets/aiplatform/apiv1/VizierClient/DeleteStudy/main.go index 9e8f719a7d55..d87d5fc3b62b 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VizierClient/DeleteStudy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VizierClient/DeleteStudy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VizierClient/DeleteTrial/main.go b/internal/generated/snippets/aiplatform/apiv1/VizierClient/DeleteTrial/main.go index a3130044d37e..c95d77563c41 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VizierClient/DeleteTrial/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VizierClient/DeleteTrial/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VizierClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/VizierClient/GetIamPolicy/main.go index a92376f55a0a..d2cd97ced685 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VizierClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VizierClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VizierClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1/VizierClient/GetLocation/main.go index 01f4ef61f3c3..49da10c3b4a4 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VizierClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VizierClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VizierClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/VizierClient/GetOperation/main.go index 8168ecd9cb1f..5186af447322 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VizierClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VizierClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VizierClient/GetStudy/main.go b/internal/generated/snippets/aiplatform/apiv1/VizierClient/GetStudy/main.go index ecf43d4bf637..87600ec282de 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VizierClient/GetStudy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VizierClient/GetStudy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VizierClient/GetTrial/main.go b/internal/generated/snippets/aiplatform/apiv1/VizierClient/GetTrial/main.go index 52a6117e365b..bc78e5eaadb5 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VizierClient/GetTrial/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VizierClient/GetTrial/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VizierClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1/VizierClient/ListLocations/main.go index f0bfe4b69d96..0e14a48f0e9c 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VizierClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VizierClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VizierClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1/VizierClient/ListOperations/main.go index b733a109c915..7c00b61a60ac 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VizierClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VizierClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VizierClient/ListOptimalTrials/main.go b/internal/generated/snippets/aiplatform/apiv1/VizierClient/ListOptimalTrials/main.go index 224d7bf1f958..d203bc4da9d3 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VizierClient/ListOptimalTrials/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VizierClient/ListOptimalTrials/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VizierClient/ListStudies/main.go b/internal/generated/snippets/aiplatform/apiv1/VizierClient/ListStudies/main.go index 2a512dcf71bb..e839c81be032 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VizierClient/ListStudies/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VizierClient/ListStudies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VizierClient/ListTrials/main.go b/internal/generated/snippets/aiplatform/apiv1/VizierClient/ListTrials/main.go index e8040595291c..e7fd969692ed 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VizierClient/ListTrials/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VizierClient/ListTrials/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VizierClient/LookupStudy/main.go b/internal/generated/snippets/aiplatform/apiv1/VizierClient/LookupStudy/main.go index 0343c2a87946..123220c6e518 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VizierClient/LookupStudy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VizierClient/LookupStudy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VizierClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1/VizierClient/SetIamPolicy/main.go index a8d786fb4323..88d9b9f11e5f 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VizierClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VizierClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VizierClient/StopTrial/main.go b/internal/generated/snippets/aiplatform/apiv1/VizierClient/StopTrial/main.go index 152137686c0f..ccf4938f4650 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VizierClient/StopTrial/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VizierClient/StopTrial/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VizierClient/SuggestTrials/main.go b/internal/generated/snippets/aiplatform/apiv1/VizierClient/SuggestTrials/main.go index ba6c93bc740f..7c7958f7b907 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VizierClient/SuggestTrials/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VizierClient/SuggestTrials/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VizierClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1/VizierClient/TestIamPermissions/main.go index 5744a274e93b..728394094dd0 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VizierClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VizierClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1/VizierClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1/VizierClient/WaitOperation/main.go index 41556d85e219..37307d0a1541 100644 --- a/internal/generated/snippets/aiplatform/apiv1/VizierClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1/VizierClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/CancelOperation/main.go index 1e43e230a672..b2e3f0818654 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/CreateDataset/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/CreateDataset/main.go index a6a0aa00ad60..de3551c70149 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/CreateDataset/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/CreateDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/CreateDatasetVersion/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/CreateDatasetVersion/main.go index c84f1f52a8c7..d74031ccd409 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/CreateDatasetVersion/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/CreateDatasetVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/DeleteDataset/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/DeleteDataset/main.go index 09e78deba2a6..6e8da540a53d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/DeleteDataset/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/DeleteDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/DeleteDatasetVersion/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/DeleteDatasetVersion/main.go index 4ef422acaf8c..6af193292c53 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/DeleteDatasetVersion/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/DeleteDatasetVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/DeleteOperation/main.go index 0f9ed5a9ff69..af13058aafa1 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/DeleteSavedQuery/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/DeleteSavedQuery/main.go index 1431822321af..c0017ef7450b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/DeleteSavedQuery/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/DeleteSavedQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ExportData/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ExportData/main.go index b74e5b18cefb..5f2553db887a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ExportData/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ExportData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/GetAnnotationSpec/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/GetAnnotationSpec/main.go index cb202f074c78..25d621511947 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/GetAnnotationSpec/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/GetAnnotationSpec/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/GetDataset/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/GetDataset/main.go index 2dc6d9037878..cd5750497630 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/GetDataset/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/GetDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/GetDatasetVersion/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/GetDatasetVersion/main.go index a24a4d11360d..57fb57cbb023 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/GetDatasetVersion/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/GetDatasetVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/GetIamPolicy/main.go index fa6de2cd8ca2..ef1f6e2eb172 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/GetLocation/main.go index 842d0c6baa88..92448d083ddf 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/GetOperation/main.go index f136ce75fa6e..e167e70b918b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ImportData/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ImportData/main.go index 7d488789b159..1d7b4579f2d6 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ImportData/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ImportData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ListAnnotations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ListAnnotations/main.go index ab8431540376..e6baba6620d2 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ListAnnotations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ListAnnotations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ListDataItems/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ListDataItems/main.go index 84a2851cec51..f3e13da2ee38 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ListDataItems/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ListDataItems/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ListDatasetVersions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ListDatasetVersions/main.go index 27fef15d29cd..eb239172f917 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ListDatasetVersions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ListDatasetVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ListDatasets/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ListDatasets/main.go index 060e68d7bbfa..280e359029af 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ListDatasets/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ListDatasets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ListLocations/main.go index e5be86de1f02..67577638357d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ListOperations/main.go index b1ca577eca03..f4a689f588d4 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ListSavedQueries/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ListSavedQueries/main.go index 21cbf0abbb49..026d7a4528b9 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ListSavedQueries/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/ListSavedQueries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/RestoreDatasetVersion/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/RestoreDatasetVersion/main.go index 122ef5c80f8d..98f83367c004 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/RestoreDatasetVersion/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/RestoreDatasetVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/SearchDataItems/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/SearchDataItems/main.go index c60be462abd8..7dbcac1ba9f5 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/SearchDataItems/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/SearchDataItems/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/SetIamPolicy/main.go index dcb326b35fce..7ceb8d90c79b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/TestIamPermissions/main.go index e9b927cb60bb..8b95c61dad7a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/UpdateDataset/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/UpdateDataset/main.go index 41a145758a69..05a280413f8c 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/UpdateDataset/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/UpdateDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/UpdateDatasetVersion/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/UpdateDatasetVersion/main.go index 03447b568dd4..af8eec3634ae 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/UpdateDatasetVersion/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/UpdateDatasetVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/WaitOperation/main.go index 7f7e1cbf0a72..099396afc1ae 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DatasetClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/CancelOperation/main.go index b16debfe48b4..313bd7f7cee9 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/CreateDeploymentResourcePool/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/CreateDeploymentResourcePool/main.go index 6b3ec5648dae..1e52a45f1035 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/CreateDeploymentResourcePool/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/CreateDeploymentResourcePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/DeleteDeploymentResourcePool/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/DeleteDeploymentResourcePool/main.go index 6081b4e3626f..2f5042c8a880 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/DeleteDeploymentResourcePool/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/DeleteDeploymentResourcePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/DeleteOperation/main.go index f37317c858ec..4bd54381c43e 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/GetDeploymentResourcePool/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/GetDeploymentResourcePool/main.go index dec831ecc2b3..ac6bc7c9b7d6 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/GetDeploymentResourcePool/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/GetDeploymentResourcePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/GetIamPolicy/main.go index 6bf8c01ded5c..9db75218ca89 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/GetLocation/main.go index 1e8e5b40205e..b8e25b30aada 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/GetOperation/main.go index fb7e9cb6f45d..2b2d80a4814d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/ListDeploymentResourcePools/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/ListDeploymentResourcePools/main.go index 23219f0d5889..fc8a3d35ddd2 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/ListDeploymentResourcePools/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/ListDeploymentResourcePools/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/ListLocations/main.go index 2239c35fff8a..7174efc63acd 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/ListOperations/main.go index 29cf7b33b491..b72515ec467b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/QueryDeployedModels/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/QueryDeployedModels/main.go index 05a524b3f318..f1ed21ed1e35 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/QueryDeployedModels/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/QueryDeployedModels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/SetIamPolicy/main.go index 260e3416811e..2d9d132acc41 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/TestIamPermissions/main.go index d49398f13c30..2892a8d99769 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/UpdateDeploymentResourcePool/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/UpdateDeploymentResourcePool/main.go index d7d369c629e5..9c6b7a7aa711 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/UpdateDeploymentResourcePool/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/UpdateDeploymentResourcePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/WaitOperation/main.go index 663c7530bf1e..0bbfc41b619d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/DeploymentResourcePoolClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/CancelOperation/main.go index 0a911c9c9871..86f3b6ddbe54 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/CreateEndpoint/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/CreateEndpoint/main.go index 5412c8886762..bab4a5196977 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/CreateEndpoint/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/CreateEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/DeleteEndpoint/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/DeleteEndpoint/main.go index 7a5706a29eb9..8cde15894d67 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/DeleteEndpoint/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/DeleteEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/DeleteOperation/main.go index b600fd0e14db..734a85871935 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/DeployModel/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/DeployModel/main.go index 8300d981dd41..a569d0e7e3a4 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/DeployModel/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/DeployModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/GetEndpoint/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/GetEndpoint/main.go index 115e0bd03e11..5f316c528141 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/GetEndpoint/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/GetEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/GetIamPolicy/main.go index eeb58ba71a62..f312e3e2d069 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/GetLocation/main.go index b11cd9f001d9..5768c00e6a66 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/GetOperation/main.go index a4387b51e46b..394594b97391 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/ListEndpoints/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/ListEndpoints/main.go index 1f4b50d2241e..599850b44552 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/ListEndpoints/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/ListEndpoints/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/ListLocations/main.go index 51642e867a98..4d2e7308bcb2 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/ListOperations/main.go index 100e3ae082e3..b8efcebb148f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/MutateDeployedModel/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/MutateDeployedModel/main.go index 938ef791654e..4f00ef4189d7 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/MutateDeployedModel/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/MutateDeployedModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/SetIamPolicy/main.go index 05e4ff6a01e9..9307446ee05d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/TestIamPermissions/main.go index 4df33ee06345..8ec7195c99b9 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/UndeployModel/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/UndeployModel/main.go index 729bbb6da862..aeadbf09074e 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/UndeployModel/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/UndeployModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/UpdateEndpoint/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/UpdateEndpoint/main.go index baba7f623169..e1df8872701f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/UpdateEndpoint/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/UpdateEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/UpdateEndpointLongRunning/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/UpdateEndpointLongRunning/main.go index 4ff9b3430166..b91be3fe7307 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/UpdateEndpointLongRunning/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/UpdateEndpointLongRunning/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/WaitOperation/main.go index e0c904705ab9..953b776d92cc 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EndpointClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/CancelOperation/main.go index d6c88579da9a..0fc0dc1e4242 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/DeleteOperation/main.go index 67c36539cbf3..d2d8dd3a8d32 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/EvaluateInstances/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/EvaluateInstances/main.go index e81c2ca9eed7..7a9a3a8b9642 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/EvaluateInstances/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/EvaluateInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/GetIamPolicy/main.go index 5da9b04fe6a2..2dad9ea30132 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/GetLocation/main.go index 9dc523c79592..ba14b9d5d1ed 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/GetOperation/main.go index 10766c27548e..03687a6713bc 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/ListLocations/main.go index 2914c773f56e..deae08adeac5 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/ListOperations/main.go index 43f8f50597f1..291f9c7c86c5 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/SetIamPolicy/main.go index 4b1d5b9abdcc..ea6ad1cdbe50 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/TestIamPermissions/main.go index e4f6c4b86e3f..73bfe467c9e8 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/WaitOperation/main.go index c9a60044dfab..ece3cae8373a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/EvaluationClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/CancelOperation/main.go index 798bec1245fe..78eaebf3cbd6 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/DeleteOperation/main.go index dfe80286deeb..81330940cd7c 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/ExecuteExtension/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/ExecuteExtension/main.go index c789311f2e29..c2e5ecfed17a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/ExecuteExtension/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/ExecuteExtension/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/GetIamPolicy/main.go index e6da7dbec148..914408fabf94 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/GetLocation/main.go index 7ff2ef049c96..b8840fd122d3 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/GetOperation/main.go index 36f1923b8595..de608ceb97b0 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/ListLocations/main.go index d3086939bb14..21fe481c3a4f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/ListOperations/main.go index b9eedf12b191..5e8615b18eda 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/QueryExtension/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/QueryExtension/main.go index ccedc2258238..48a86a99bb02 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/QueryExtension/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/QueryExtension/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/SetIamPolicy/main.go index 383f3d016055..6207151d3258 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/TestIamPermissions/main.go index b444306e2028..03f09d1f5a5f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/WaitOperation/main.go index b03e027c1449..ef7b179f95d4 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionExecutionClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/CancelOperation/main.go index 6b3b9ce08340..80e6f689ebc1 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/DeleteExtension/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/DeleteExtension/main.go index 34a6f2ab8839..47909a953f63 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/DeleteExtension/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/DeleteExtension/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/DeleteOperation/main.go index e77550deafcc..4fd8e44dbd25 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/GetExtension/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/GetExtension/main.go index bfc209fecbd4..caac1f6d90bc 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/GetExtension/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/GetExtension/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/GetIamPolicy/main.go index 507c8db651a9..ef61d4fe0e34 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/GetLocation/main.go index b20aa3fad1fe..e031d2b61914 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/GetOperation/main.go index 419a369d611f..afb75b5c820a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/ImportExtension/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/ImportExtension/main.go index bdbe65245202..a715dea072e9 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/ImportExtension/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/ImportExtension/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/ListExtensions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/ListExtensions/main.go index c4b365eb9326..e015865023d5 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/ListExtensions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/ListExtensions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/ListLocations/main.go index 8628d0fcb825..510ec9c5d6f6 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/ListOperations/main.go index 4322b7668c01..a35704c8e14b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/SetIamPolicy/main.go index 14e218a2db8f..85e5b522b687 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/TestIamPermissions/main.go index 51aacb1d048b..7182a2df5da6 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/UpdateExtension/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/UpdateExtension/main.go index 8827a8fa10ff..67d40ef97ca7 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/UpdateExtension/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/UpdateExtension/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/WaitOperation/main.go index 5b51f237a9af..a453105a4437 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ExtensionRegistryClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/CancelOperation/main.go index e1090ea840e5..6449a4d4c7a8 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/CreateFeatureOnlineStore/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/CreateFeatureOnlineStore/main.go index 067d0b858de7..94ce6a74ee9b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/CreateFeatureOnlineStore/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/CreateFeatureOnlineStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/CreateFeatureView/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/CreateFeatureView/main.go index 7f28811868d3..43aa4d7ebac7 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/CreateFeatureView/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/CreateFeatureView/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/DeleteFeatureOnlineStore/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/DeleteFeatureOnlineStore/main.go index ef1774c2c6ca..ae679bd73cda 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/DeleteFeatureOnlineStore/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/DeleteFeatureOnlineStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/DeleteFeatureView/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/DeleteFeatureView/main.go index 4b8ee7467952..8020fad404af 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/DeleteFeatureView/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/DeleteFeatureView/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/DeleteOperation/main.go index fe599100574d..1d70e4512942 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/GetFeatureOnlineStore/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/GetFeatureOnlineStore/main.go index a40630584414..3a50a58d86be 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/GetFeatureOnlineStore/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/GetFeatureOnlineStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/GetFeatureView/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/GetFeatureView/main.go index 60927af621ab..995056e5f34c 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/GetFeatureView/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/GetFeatureView/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/GetFeatureViewSync/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/GetFeatureViewSync/main.go index 3e95a2f6f18a..c536aceda373 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/GetFeatureViewSync/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/GetFeatureViewSync/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/GetIamPolicy/main.go index 0c408b8992a1..4bf726a3e5ce 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/GetLocation/main.go index bdf21bec0d1e..841ef614afa4 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/GetOperation/main.go index 27a773241471..5effb7df32ab 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/ListFeatureOnlineStores/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/ListFeatureOnlineStores/main.go index 589be3cd4a43..aa31d22cfa58 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/ListFeatureOnlineStores/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/ListFeatureOnlineStores/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/ListFeatureViewSyncs/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/ListFeatureViewSyncs/main.go index f5243bb69cd2..8adf3c1d3ef6 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/ListFeatureViewSyncs/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/ListFeatureViewSyncs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/ListFeatureViews/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/ListFeatureViews/main.go index 0c65984ac7fa..1a14232c675d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/ListFeatureViews/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/ListFeatureViews/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/ListLocations/main.go index 2bce71716814..b9855d9e623f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/ListOperations/main.go index ce5223e7ee64..73debcda3212 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/SetIamPolicy/main.go index 400af3a249b7..ab1a92c0c7ec 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/SyncFeatureView/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/SyncFeatureView/main.go index 8a5286bd0270..4705e5c5c1a4 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/SyncFeatureView/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/SyncFeatureView/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/TestIamPermissions/main.go index fbf7c657b09c..df95657d612d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/UpdateFeatureOnlineStore/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/UpdateFeatureOnlineStore/main.go index 5c88acad908c..3ae2618c5536 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/UpdateFeatureOnlineStore/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/UpdateFeatureOnlineStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/UpdateFeatureView/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/UpdateFeatureView/main.go index 1a8d9cd938de..e358fa9fc5e4 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/UpdateFeatureView/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/UpdateFeatureView/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/WaitOperation/main.go index 424f7e11e630..a35869b8bfa9 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreAdminClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/CancelOperation/main.go index 77998ad75e9e..c644797e6740 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/DeleteOperation/main.go index 4a27f661e340..f1dd6dfc39a4 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/FetchFeatureValues/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/FetchFeatureValues/main.go index 530844490fbd..22880b290a5c 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/FetchFeatureValues/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/FetchFeatureValues/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/GetIamPolicy/main.go index 802f164740b5..36ca726ce353 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/GetLocation/main.go index c1670551939e..a2c633ea667f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/GetOperation/main.go index 3ebb0ae2f383..35a29de95ecc 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/ListLocations/main.go index 0f8a7d214564..dd27a61f7293 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/ListOperations/main.go index fcd615a4cd7e..e049eb30ded9 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/SearchNearestEntities/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/SearchNearestEntities/main.go index 2fc14c91bd19..e6aa0850243a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/SearchNearestEntities/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/SearchNearestEntities/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/SetIamPolicy/main.go index 46b68ecec229..28bab69b8460 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/StreamingFetchFeatureValues/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/StreamingFetchFeatureValues/main.go index 734aae64afb8..6fe9cf263f1a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/StreamingFetchFeatureValues/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/StreamingFetchFeatureValues/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/TestIamPermissions/main.go index ce5af2281605..06ba43cdbea6 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/WaitOperation/main.go index 890cce2ceb09..2ec7fb3b8898 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureOnlineStoreClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/BatchCreateFeatures/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/BatchCreateFeatures/main.go index a64cc6eca360..db2a13c5a696 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/BatchCreateFeatures/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/BatchCreateFeatures/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/CancelOperation/main.go index f61d57ea5a7a..67fcc4b443b5 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/CreateFeature/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/CreateFeature/main.go index fd8b5c47abb8..1edc761ca723 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/CreateFeature/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/CreateFeature/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/CreateFeatureGroup/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/CreateFeatureGroup/main.go index b8caa96c6098..8e97f02a82fc 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/CreateFeatureGroup/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/CreateFeatureGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/CreateFeatureMonitor/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/CreateFeatureMonitor/main.go index 21d19ac59d4c..75d740e331fd 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/CreateFeatureMonitor/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/CreateFeatureMonitor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/CreateFeatureMonitorJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/CreateFeatureMonitorJob/main.go index 6f4965a9cb89..e949ca538054 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/CreateFeatureMonitorJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/CreateFeatureMonitorJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/DeleteFeature/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/DeleteFeature/main.go index e8511ff45b71..696cf87c90f0 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/DeleteFeature/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/DeleteFeature/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/DeleteFeatureGroup/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/DeleteFeatureGroup/main.go index 856589e6af94..f356b46507de 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/DeleteFeatureGroup/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/DeleteFeatureGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/DeleteFeatureMonitor/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/DeleteFeatureMonitor/main.go index 2cbf7c43d043..1e77e9989b42 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/DeleteFeatureMonitor/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/DeleteFeatureMonitor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/DeleteOperation/main.go index adcbb0c40c87..e24d33bb53de 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/GetFeature/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/GetFeature/main.go index 6cac706dd48c..bd8e32e08a2a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/GetFeature/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/GetFeature/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/GetFeatureGroup/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/GetFeatureGroup/main.go index 1fcdc023cc3a..a1f00241c6eb 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/GetFeatureGroup/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/GetFeatureGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/GetFeatureMonitor/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/GetFeatureMonitor/main.go index f761889d71fe..a0edc7968d1e 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/GetFeatureMonitor/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/GetFeatureMonitor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/GetFeatureMonitorJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/GetFeatureMonitorJob/main.go index b8ba07e0ed3a..8213efb5238d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/GetFeatureMonitorJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/GetFeatureMonitorJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/GetIamPolicy/main.go index f18da2b88319..dc89ff203724 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/GetLocation/main.go index 2679a01cd5b3..639600bf329a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/GetOperation/main.go index 6bab01e405cc..3523a57b3f43 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/ListFeatureGroups/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/ListFeatureGroups/main.go index 17774bdde044..7e6e86dee225 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/ListFeatureGroups/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/ListFeatureGroups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/ListFeatureMonitorJobs/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/ListFeatureMonitorJobs/main.go index 86124051e23b..e260b79a0e28 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/ListFeatureMonitorJobs/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/ListFeatureMonitorJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/ListFeatureMonitors/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/ListFeatureMonitors/main.go index 337a05640c9c..5cbc299deea2 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/ListFeatureMonitors/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/ListFeatureMonitors/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/ListFeatures/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/ListFeatures/main.go index 38c815afd228..0c609c15ac4b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/ListFeatures/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/ListFeatures/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/ListLocations/main.go index 41dad9c274a0..0c4e069e10d8 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/ListOperations/main.go index 05b154837713..ff3f0d1f6691 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/SetIamPolicy/main.go index 8150c160173c..ef241183c0b4 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/TestIamPermissions/main.go index 0097182f34c8..c0b1cc857290 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/UpdateFeature/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/UpdateFeature/main.go index b00ea0686e95..48c6d977b38e 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/UpdateFeature/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/UpdateFeature/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/UpdateFeatureGroup/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/UpdateFeatureGroup/main.go index 99e3328bcc17..df90ee88ee96 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/UpdateFeatureGroup/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/UpdateFeatureGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/WaitOperation/main.go index 267794d20278..c656d5cba8d4 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeatureRegistryClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/BatchCreateFeatures/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/BatchCreateFeatures/main.go index 622d3e57f77d..564366c265f8 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/BatchCreateFeatures/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/BatchCreateFeatures/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/BatchReadFeatureValues/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/BatchReadFeatureValues/main.go index 8d50ed57e4a2..aa107f735e8d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/BatchReadFeatureValues/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/BatchReadFeatureValues/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/CancelOperation/main.go index 7104e14558ee..62110b5763bb 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/CreateEntityType/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/CreateEntityType/main.go index 75090196b440..d41756be57bc 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/CreateEntityType/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/CreateEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/CreateFeature/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/CreateFeature/main.go index aae6fabdbd11..ff164eaab447 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/CreateFeature/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/CreateFeature/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/CreateFeaturestore/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/CreateFeaturestore/main.go index aca0e6274e6e..4b0b40736577 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/CreateFeaturestore/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/CreateFeaturestore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/DeleteEntityType/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/DeleteEntityType/main.go index c9ef251ae98f..28ba05f2003b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/DeleteEntityType/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/DeleteEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/DeleteFeature/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/DeleteFeature/main.go index 87f7d4b3433d..f6cd23b3dc10 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/DeleteFeature/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/DeleteFeature/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/DeleteFeatureValues/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/DeleteFeatureValues/main.go index d6fda044c466..eb8e585d755b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/DeleteFeatureValues/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/DeleteFeatureValues/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/DeleteFeaturestore/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/DeleteFeaturestore/main.go index bb9e03a5f749..82731563fdf6 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/DeleteFeaturestore/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/DeleteFeaturestore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/DeleteOperation/main.go index bb213eafb2f5..94900698d225 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/ExportFeatureValues/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/ExportFeatureValues/main.go index 8544bc9365b2..f392978a622c 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/ExportFeatureValues/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/ExportFeatureValues/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/GetEntityType/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/GetEntityType/main.go index d4ba85af695f..d5f743dc8f90 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/GetEntityType/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/GetEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/GetFeature/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/GetFeature/main.go index 930d31c95a9c..c1d9d9b7b1e2 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/GetFeature/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/GetFeature/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/GetFeaturestore/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/GetFeaturestore/main.go index 3796c3a6cb59..e81cd28ac9b8 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/GetFeaturestore/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/GetFeaturestore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/GetIamPolicy/main.go index 9c9fc5e1d06b..b1017170fdad 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/GetLocation/main.go index e847fafc5266..b9554c66bf7a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/GetOperation/main.go index 55e75f661e90..b453d83bf2f2 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/ImportFeatureValues/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/ImportFeatureValues/main.go index 318b04c47d58..41210029017d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/ImportFeatureValues/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/ImportFeatureValues/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/ListEntityTypes/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/ListEntityTypes/main.go index 841ca25629c1..cca5dcdc3d2c 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/ListEntityTypes/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/ListEntityTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/ListFeatures/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/ListFeatures/main.go index 6ac0b0bb04fe..962fd1639bff 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/ListFeatures/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/ListFeatures/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/ListFeaturestores/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/ListFeaturestores/main.go index 60cf9376b50a..8e4464ad7449 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/ListFeaturestores/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/ListFeaturestores/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/ListLocations/main.go index 0c638003ee76..dd7a9fa9fe75 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/ListOperations/main.go index 60a73a32fad0..ecb330ce8cb0 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/SearchFeatures/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/SearchFeatures/main.go index 33535253bf9b..30d908161b04 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/SearchFeatures/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/SearchFeatures/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/SetIamPolicy/main.go index b733da00010c..8349eb44d20b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/TestIamPermissions/main.go index 9b33c14942f1..d8b5f7a00136 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/UpdateEntityType/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/UpdateEntityType/main.go index b3c880705117..786c38577034 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/UpdateEntityType/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/UpdateEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/UpdateFeature/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/UpdateFeature/main.go index 506aa7a0eb08..7dda718e3d80 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/UpdateFeature/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/UpdateFeature/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/UpdateFeaturestore/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/UpdateFeaturestore/main.go index eedd3bac7221..350aae15db1f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/UpdateFeaturestore/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/UpdateFeaturestore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/WaitOperation/main.go index 23363866be65..a554db67171d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/CancelOperation/main.go index c806d26e0842..16577f890a44 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/DeleteOperation/main.go index 7c08f5f16acf..7637cc36c7ca 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/GetIamPolicy/main.go index 223c5d310a05..a28fd80ddf0d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/GetLocation/main.go index c3eeb3bb6342..907dbfc9ca20 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/GetOperation/main.go index e4b16b48f8a0..d431c92e4923 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/ListLocations/main.go index 6b5a2a03b200..4d3b235d50be 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/ListOperations/main.go index 3cebf7cbe13c..19eec4c02812 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/ReadFeatureValues/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/ReadFeatureValues/main.go index d19019468cf3..657ff3d194fc 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/ReadFeatureValues/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/ReadFeatureValues/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/SetIamPolicy/main.go index fae85b71544c..5aabc515cf0a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/TestIamPermissions/main.go index 347511760041..9730c38ac716 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/WaitOperation/main.go index 3e9bd9fc7582..920380f1444d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/WriteFeatureValues/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/WriteFeatureValues/main.go index a9b9298a7a91..0fedf2cc7164 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/WriteFeatureValues/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/FeaturestoreOnlineServingClient/WriteFeatureValues/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/CancelOperation/main.go index 0e2ab2d81805..33bd0b83f341 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/CreateCachedContent/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/CreateCachedContent/main.go index d960eb653cf9..a7f0b3a23115 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/CreateCachedContent/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/CreateCachedContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/DeleteCachedContent/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/DeleteCachedContent/main.go index 7a292d7eaa9f..e4af0b7713a4 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/DeleteCachedContent/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/DeleteCachedContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/DeleteOperation/main.go index e6f1c0119b48..4b0c5de3c3af 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/GetCachedContent/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/GetCachedContent/main.go index 303424ce18f5..6b32b98d78cd 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/GetCachedContent/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/GetCachedContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/GetIamPolicy/main.go index 027665e571e8..8514e1613507 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/GetLocation/main.go index 4a61c677a247..6b9534da414a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/GetOperation/main.go index 3c03b973ed21..afd5a67ddb18 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/ListCachedContents/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/ListCachedContents/main.go index a8235f0b6bd9..bfc349d463aa 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/ListCachedContents/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/ListCachedContents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/ListLocations/main.go index a0a65cd87892..3bd0ac1c527e 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/ListOperations/main.go index 4c4110baf252..c3f4c6e5d800 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/SetIamPolicy/main.go index 839d57e00920..4aca5ee79806 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/TestIamPermissions/main.go index a78be0540708..d9fe71769743 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/UpdateCachedContent/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/UpdateCachedContent/main.go index 209cb7b5abae..893e03296843 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/UpdateCachedContent/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/UpdateCachedContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/WaitOperation/main.go index a5f0e591470e..9e30dce5ae4a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiCacheClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/CancelOperation/main.go index 44f981d514a0..c26d57d545a2 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/CancelTuningJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/CancelTuningJob/main.go index 14655d0412cb..2dbeff90d795 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/CancelTuningJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/CancelTuningJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/CreateTuningJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/CreateTuningJob/main.go index 6364abdbc182..efd0a976c15a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/CreateTuningJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/CreateTuningJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/DeleteOperation/main.go index 1e51a37524eb..39f0032a3164 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/GetIamPolicy/main.go index 0c10b8d34cd2..c875a9ac32c3 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/GetLocation/main.go index e3891eb0b7c3..508a5caf79d2 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/GetOperation/main.go index 50f0b370f700..c3c4ba5c0e9f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/GetTuningJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/GetTuningJob/main.go index be23e711d729..03a43fbd17d8 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/GetTuningJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/GetTuningJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/ListLocations/main.go index 4ee97970d419..4ebe28aed14b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/ListOperations/main.go index 7002d1024fc5..2cb0f33ecca3 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/ListTuningJobs/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/ListTuningJobs/main.go index 13cf0c236344..ffa11d5bf318 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/ListTuningJobs/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/ListTuningJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/RebaseTunedModel/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/RebaseTunedModel/main.go index 3a41fcb2a9e1..692d9b9c39a9 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/RebaseTunedModel/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/RebaseTunedModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/SetIamPolicy/main.go index 93a4f4b44251..5eb8048fe19b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/TestIamPermissions/main.go index e12475f4d45d..e2dbf8a6a672 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/WaitOperation/main.go index 8c384de504cf..91b2339d9faf 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/GenAiTuningClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/CancelOperation/main.go index 9be4a93de2fa..77d6f32f283d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/CreateIndex/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/CreateIndex/main.go index 0c3f185d97a5..8aee0010852e 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/CreateIndex/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/CreateIndex/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/DeleteIndex/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/DeleteIndex/main.go index 0e61b88658c9..8c15a3fb6d73 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/DeleteIndex/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/DeleteIndex/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/DeleteOperation/main.go index 20c1ed6e280a..6591be382fe6 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/GetIamPolicy/main.go index b09a54235b20..8edfca30cca0 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/GetIndex/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/GetIndex/main.go index 70987f9376fc..73677b47d403 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/GetIndex/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/GetIndex/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/GetLocation/main.go index 8d4689afbfaa..49c80d067165 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/GetOperation/main.go index 19408eaf10ee..79c4b0502618 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/ListIndexes/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/ListIndexes/main.go index c9206b3006ce..3f9e93eec6cc 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/ListIndexes/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/ListIndexes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/ListLocations/main.go index 877c0eb1d4e9..8912231a9082 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/ListOperations/main.go index e1e512614578..1d52ef2bfca0 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/RemoveDatapoints/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/RemoveDatapoints/main.go index 119de132ac70..f597fc51983d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/RemoveDatapoints/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/RemoveDatapoints/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/SetIamPolicy/main.go index 74b996f5b709..9831c3953071 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/TestIamPermissions/main.go index 97f6f188e962..61efda587add 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/UpdateIndex/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/UpdateIndex/main.go index 25c2a9df9db3..80683589e192 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/UpdateIndex/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/UpdateIndex/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/UpsertDatapoints/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/UpsertDatapoints/main.go index e3f159f9c3b8..b3443ea3a077 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/UpsertDatapoints/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/UpsertDatapoints/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/WaitOperation/main.go index b968b86bfe8c..91b8f3a18870 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/CancelOperation/main.go index 8823368908b4..f682614932c0 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/CreateIndexEndpoint/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/CreateIndexEndpoint/main.go index 083acadac855..65c35e07db4a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/CreateIndexEndpoint/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/CreateIndexEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/DeleteIndexEndpoint/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/DeleteIndexEndpoint/main.go index 4ff55ee48262..f2e88155f14f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/DeleteIndexEndpoint/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/DeleteIndexEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/DeleteOperation/main.go index 1c3054166bd9..1632a1194a4f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/DeployIndex/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/DeployIndex/main.go index fa4ac04267a9..4967ac1f8f72 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/DeployIndex/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/DeployIndex/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/GetIamPolicy/main.go index 6986cf88e047..da9a4f21311f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/GetIndexEndpoint/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/GetIndexEndpoint/main.go index 447ce1bd3c22..91a28464d962 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/GetIndexEndpoint/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/GetIndexEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/GetLocation/main.go index 0fe52252ba02..715767443beb 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/GetOperation/main.go index e96cc7239ea5..927bebc6ecd0 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/ListIndexEndpoints/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/ListIndexEndpoints/main.go index eda03e288b21..553b133664b6 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/ListIndexEndpoints/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/ListIndexEndpoints/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/ListLocations/main.go index 42ae53cd77bb..da50f4e535c2 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/ListOperations/main.go index 3e8188fb9b2a..dd48cb41dca9 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/MutateDeployedIndex/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/MutateDeployedIndex/main.go index 1b64419b3dc9..4edc2fffa216 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/MutateDeployedIndex/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/MutateDeployedIndex/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/SetIamPolicy/main.go index 1add870c738d..3f65910509e3 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/TestIamPermissions/main.go index 975384abca1f..1493204fe016 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/UndeployIndex/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/UndeployIndex/main.go index 0345e02480e5..cd032cc86a3b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/UndeployIndex/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/UndeployIndex/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/UpdateIndexEndpoint/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/UpdateIndexEndpoint/main.go index 4bbda5271449..e033c3bafe11 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/UpdateIndexEndpoint/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/UpdateIndexEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/WaitOperation/main.go index 215435ca9644..59a1929f536c 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/IndexEndpointClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CancelBatchPredictionJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CancelBatchPredictionJob/main.go index 242f7bfd1ef3..140b37c1bb42 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CancelBatchPredictionJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CancelBatchPredictionJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CancelCustomJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CancelCustomJob/main.go index 1f17353725ad..ec411da4e0cf 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CancelCustomJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CancelCustomJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CancelDataLabelingJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CancelDataLabelingJob/main.go index d3829e4f3753..5128eb32a7b4 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CancelDataLabelingJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CancelDataLabelingJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CancelHyperparameterTuningJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CancelHyperparameterTuningJob/main.go index 6023db1a062f..23acc5f3aea1 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CancelHyperparameterTuningJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CancelHyperparameterTuningJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CancelNasJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CancelNasJob/main.go index 57643e1e72b1..29191851d303 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CancelNasJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CancelNasJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CancelOperation/main.go index 7790c300ffea..04a5f08d0ff4 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CreateBatchPredictionJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CreateBatchPredictionJob/main.go index 34480a4c96bc..fb49a647ebac 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CreateBatchPredictionJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CreateBatchPredictionJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CreateCustomJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CreateCustomJob/main.go index 8e40f5114b91..7fb1fe00e5ee 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CreateCustomJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CreateCustomJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CreateDataLabelingJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CreateDataLabelingJob/main.go index fc7a1f05f2df..5e2a3c0d5a5f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CreateDataLabelingJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CreateDataLabelingJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CreateHyperparameterTuningJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CreateHyperparameterTuningJob/main.go index 1b56a948e6a6..f3321d333580 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CreateHyperparameterTuningJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CreateHyperparameterTuningJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CreateModelDeploymentMonitoringJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CreateModelDeploymentMonitoringJob/main.go index 789ccea77494..0d277f8af8df 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CreateModelDeploymentMonitoringJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CreateModelDeploymentMonitoringJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CreateNasJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CreateNasJob/main.go index 69c01c758822..fae5fd840f78 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CreateNasJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/CreateNasJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/DeleteBatchPredictionJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/DeleteBatchPredictionJob/main.go index 7da0f4867d74..b787b7d2b344 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/DeleteBatchPredictionJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/DeleteBatchPredictionJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/DeleteCustomJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/DeleteCustomJob/main.go index 286d265f1f28..e8aff742f9c7 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/DeleteCustomJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/DeleteCustomJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/DeleteDataLabelingJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/DeleteDataLabelingJob/main.go index 5a3247c055d3..01364d33b110 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/DeleteDataLabelingJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/DeleteDataLabelingJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/DeleteHyperparameterTuningJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/DeleteHyperparameterTuningJob/main.go index c26ebc60e4af..dacaaff16c9f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/DeleteHyperparameterTuningJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/DeleteHyperparameterTuningJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/DeleteModelDeploymentMonitoringJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/DeleteModelDeploymentMonitoringJob/main.go index 85498ae71f37..88b031808c3c 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/DeleteModelDeploymentMonitoringJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/DeleteModelDeploymentMonitoringJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/DeleteNasJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/DeleteNasJob/main.go index 8b44fff2c058..518883f4df1c 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/DeleteNasJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/DeleteNasJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/DeleteOperation/main.go index 0c723f5309fc..a77c87c0bc74 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetBatchPredictionJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetBatchPredictionJob/main.go index bc69398ca8e4..0883de9ddd17 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetBatchPredictionJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetBatchPredictionJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetCustomJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetCustomJob/main.go index 5af6d906f524..e67dcc009aa3 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetCustomJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetCustomJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetDataLabelingJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetDataLabelingJob/main.go index 2d322341844f..09ef15c5d369 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetDataLabelingJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetDataLabelingJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetHyperparameterTuningJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetHyperparameterTuningJob/main.go index c28e8dc8a79c..56ef6e8120e6 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetHyperparameterTuningJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetHyperparameterTuningJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetIamPolicy/main.go index 4abda2c422ba..5d7344075a92 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetLocation/main.go index b375ac09438f..17f33ec8895e 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetModelDeploymentMonitoringJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetModelDeploymentMonitoringJob/main.go index 3556898f0c4b..a1bacec8e2f0 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetModelDeploymentMonitoringJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetModelDeploymentMonitoringJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetNasJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetNasJob/main.go index 5316c5bf8a21..acc41ea0998c 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetNasJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetNasJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetNasTrialDetail/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetNasTrialDetail/main.go index a4efe130a6bd..350b475a1ba2 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetNasTrialDetail/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetNasTrialDetail/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetOperation/main.go index c0aa32bf0d35..dcda0531bc71 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListBatchPredictionJobs/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListBatchPredictionJobs/main.go index 8922074baec4..cb40b2770443 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListBatchPredictionJobs/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListBatchPredictionJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListCustomJobs/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListCustomJobs/main.go index 39678d94bcd7..d908070c2c4c 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListCustomJobs/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListCustomJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListDataLabelingJobs/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListDataLabelingJobs/main.go index aba6a647843a..d47c59fe60aa 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListDataLabelingJobs/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListDataLabelingJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListHyperparameterTuningJobs/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListHyperparameterTuningJobs/main.go index d7aeb67671ab..ed5e1adef275 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListHyperparameterTuningJobs/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListHyperparameterTuningJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListLocations/main.go index 0c34a4fa63de..ef7bc3c89ff8 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListModelDeploymentMonitoringJobs/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListModelDeploymentMonitoringJobs/main.go index 338a681756a9..fbaa2516abbe 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListModelDeploymentMonitoringJobs/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListModelDeploymentMonitoringJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListNasJobs/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListNasJobs/main.go index c258af0e54e2..ccd49bd4659f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListNasJobs/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListNasJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListNasTrialDetails/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListNasTrialDetails/main.go index d534520da547..51c073a6fe34 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListNasTrialDetails/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListNasTrialDetails/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListOperations/main.go index c0ca151ad28c..52054d835d6a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/PauseModelDeploymentMonitoringJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/PauseModelDeploymentMonitoringJob/main.go index 73d9459cfcde..4ccf0221445d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/PauseModelDeploymentMonitoringJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/PauseModelDeploymentMonitoringJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ResumeModelDeploymentMonitoringJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ResumeModelDeploymentMonitoringJob/main.go index 4ef0cdd22950..9e19e9865753 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ResumeModelDeploymentMonitoringJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/ResumeModelDeploymentMonitoringJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/SearchModelDeploymentMonitoringStatsAnomalies/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/SearchModelDeploymentMonitoringStatsAnomalies/main.go index a1c4915280fc..35be510dc85b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/SearchModelDeploymentMonitoringStatsAnomalies/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/SearchModelDeploymentMonitoringStatsAnomalies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/SetIamPolicy/main.go index 86ef30a70ed8..b49c4749c64b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/TestIamPermissions/main.go index f96034a8a234..d389e6d606b1 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/UpdateModelDeploymentMonitoringJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/UpdateModelDeploymentMonitoringJob/main.go index 1e8414db7163..50f7c3b90731 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/UpdateModelDeploymentMonitoringJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/UpdateModelDeploymentMonitoringJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/WaitOperation/main.go index 1d2a11b2b76b..bff469286fa2 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/JobClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/CancelOperation/main.go index b1c9fb78c795..f3062a62efb4 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/ComputeTokens/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/ComputeTokens/main.go index a6807374cd37..a630eeb31c1e 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/ComputeTokens/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/ComputeTokens/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/DeleteOperation/main.go index 23e873c325c9..111cc4980a7e 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/GetIamPolicy/main.go index 945d37c4b4ce..2ec1f475f34f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/GetLocation/main.go index 48398966d86c..53ebc440969a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/GetOperation/main.go index 4797a2a50006..aba1609aa63d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/ListLocations/main.go index fec356793a61..39072beefb04 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/ListOperations/main.go index 56667539b6ed..2a0acc5dfa94 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/SetIamPolicy/main.go index f06586a797b1..264563d29aa3 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/TestIamPermissions/main.go index 473128dfbd9a..df240cb52348 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/WaitOperation/main.go index 878f019e11e4..0b5297cad54b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/LlmUtilityClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/CancelOperation/main.go index 039cff54a9ae..961a58a23db8 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/DeleteOperation/main.go index 7588c158cef5..06ed88cae41c 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/FindNeighbors/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/FindNeighbors/main.go index b086af11594b..7735b4090e23 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/FindNeighbors/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/FindNeighbors/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/GetIamPolicy/main.go index f7e9503fde64..d6a8d6fff880 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/GetLocation/main.go index bf3fa5fa3c41..b575bf066ab9 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/GetOperation/main.go index ecfa12f761d3..62630afb9a0a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/ListLocations/main.go index 5ed40768d303..db3bf6fd6eb1 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/ListOperations/main.go index fc8b86346b7d..4758c556aacd 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/ReadIndexDatapoints/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/ReadIndexDatapoints/main.go index 83dee383a7d1..114799d31118 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/ReadIndexDatapoints/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/ReadIndexDatapoints/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/SetIamPolicy/main.go index 517d2110ec56..b521d38ed989 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/TestIamPermissions/main.go index 9b572af3ffdd..c35d7fa2fe7b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/WaitOperation/main.go index 9401f0b17168..1c425522b0ae 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MatchClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/AddContextArtifactsAndExecutions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/AddContextArtifactsAndExecutions/main.go index d798dbf254e8..949deeec7b80 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/AddContextArtifactsAndExecutions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/AddContextArtifactsAndExecutions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/AddContextChildren/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/AddContextChildren/main.go index 72a595a12bab..96a9163c357f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/AddContextChildren/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/AddContextChildren/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/AddExecutionEvents/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/AddExecutionEvents/main.go index 9589ce0830c5..c2b0e9356ec2 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/AddExecutionEvents/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/AddExecutionEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/CancelOperation/main.go index c7540da1afe8..fef006b08da5 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/CreateArtifact/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/CreateArtifact/main.go index 687395b7f03e..bf3f72b06113 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/CreateArtifact/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/CreateArtifact/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/CreateContext/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/CreateContext/main.go index fa2234dfbb64..6201aac6adeb 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/CreateContext/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/CreateContext/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/CreateExecution/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/CreateExecution/main.go index 05745720728f..60d524120b6b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/CreateExecution/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/CreateExecution/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/CreateMetadataSchema/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/CreateMetadataSchema/main.go index 0e0002bb174a..1b892a3db6d0 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/CreateMetadataSchema/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/CreateMetadataSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/CreateMetadataStore/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/CreateMetadataStore/main.go index 6e0328167f87..443383277ce1 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/CreateMetadataStore/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/CreateMetadataStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/DeleteArtifact/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/DeleteArtifact/main.go index 1124dc6298d6..582bb2620453 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/DeleteArtifact/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/DeleteArtifact/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/DeleteContext/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/DeleteContext/main.go index 1b5f27cd6d88..7bc87c6bcbac 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/DeleteContext/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/DeleteContext/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/DeleteExecution/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/DeleteExecution/main.go index 6bbe0cab7545..06338d5ae549 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/DeleteExecution/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/DeleteExecution/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/DeleteMetadataStore/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/DeleteMetadataStore/main.go index b6b83e0aa167..7a5c551b3447 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/DeleteMetadataStore/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/DeleteMetadataStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/DeleteOperation/main.go index 72fc1e09154f..59a3e1f69652 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetArtifact/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetArtifact/main.go index 79474248462a..62b2a67156c6 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetArtifact/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetArtifact/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetContext/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetContext/main.go index c1b3045542aa..12ba7c89d410 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetContext/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetContext/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetExecution/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetExecution/main.go index 89c7436972cd..e1aad8fc1fe3 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetExecution/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetExecution/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetIamPolicy/main.go index ebb65c1f8deb..94e51bfe742a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetLocation/main.go index 3bff2d24c90d..07cdff394995 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetMetadataSchema/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetMetadataSchema/main.go index 9c0aaf4a70fb..0f29736f0dee 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetMetadataSchema/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetMetadataSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetMetadataStore/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetMetadataStore/main.go index 7e64d8fc328e..ffa5206988b2 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetMetadataStore/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetMetadataStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetOperation/main.go index 633d1abdb310..7d06a12ae2ea 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/ListArtifacts/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/ListArtifacts/main.go index c48492b72e80..c1fe55dab46f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/ListArtifacts/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/ListArtifacts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/ListContexts/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/ListContexts/main.go index 7c40a5a2d86d..19de2ff938db 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/ListContexts/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/ListContexts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/ListExecutions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/ListExecutions/main.go index 8ba85ca10b3d..1dc02d1199dc 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/ListExecutions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/ListExecutions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/ListLocations/main.go index 76988f2ee6a3..ba0ec487ce44 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/ListMetadataSchemas/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/ListMetadataSchemas/main.go index 748cf5018aa6..a951c34acc1d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/ListMetadataSchemas/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/ListMetadataSchemas/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/ListMetadataStores/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/ListMetadataStores/main.go index bfd89a0429b0..d8193fdffe45 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/ListMetadataStores/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/ListMetadataStores/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/ListOperations/main.go index 6bad185d787a..fa90a86ebe5e 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/PurgeArtifacts/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/PurgeArtifacts/main.go index b6871dd2d633..83838def7567 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/PurgeArtifacts/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/PurgeArtifacts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/PurgeContexts/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/PurgeContexts/main.go index 5c800b8d1672..89695f6da62a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/PurgeContexts/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/PurgeContexts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/PurgeExecutions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/PurgeExecutions/main.go index f1913c377be7..847501bed8e5 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/PurgeExecutions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/PurgeExecutions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/QueryArtifactLineageSubgraph/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/QueryArtifactLineageSubgraph/main.go index 5c11e6df6fa3..72cac2be55e8 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/QueryArtifactLineageSubgraph/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/QueryArtifactLineageSubgraph/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/QueryContextLineageSubgraph/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/QueryContextLineageSubgraph/main.go index 3642172acdcf..70c0b33f112d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/QueryContextLineageSubgraph/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/QueryContextLineageSubgraph/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/QueryExecutionInputsAndOutputs/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/QueryExecutionInputsAndOutputs/main.go index e5fc2119efed..8c73c7128a3f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/QueryExecutionInputsAndOutputs/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/QueryExecutionInputsAndOutputs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/RemoveContextChildren/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/RemoveContextChildren/main.go index b9573fac72c3..b5f6b21a6134 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/RemoveContextChildren/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/RemoveContextChildren/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/SetIamPolicy/main.go index 083fcaa13500..6b66a4cb15e6 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/TestIamPermissions/main.go index f426ddabe02f..fb9215113862 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/UpdateArtifact/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/UpdateArtifact/main.go index 7cd922f677fd..2fd74ec3a9b9 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/UpdateArtifact/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/UpdateArtifact/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/UpdateContext/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/UpdateContext/main.go index bdf45418433f..e4023e3390c2 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/UpdateContext/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/UpdateContext/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/UpdateExecution/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/UpdateExecution/main.go index 6f2393a69546..4eabd8acd8d7 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/UpdateExecution/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/UpdateExecution/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/WaitOperation/main.go index aa73e0e790b9..0197b487f35c 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MetadataClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/BatchMigrateResources/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/BatchMigrateResources/main.go index 005b2e560063..8aec8d15b8b1 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/BatchMigrateResources/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/BatchMigrateResources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/CancelOperation/main.go index b1ae401bfb2b..133379028291 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/DeleteOperation/main.go index f2d727053c78..54390a2f650b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/GetIamPolicy/main.go index c09ff9634ed5..23e3668bf813 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/GetLocation/main.go index 84ed7457ba07..7a9e9729581c 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/GetOperation/main.go index 049ec5595dd7..1fbbcd157e89 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/ListLocations/main.go index 20e4ac9f4131..b346d6e79239 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/ListOperations/main.go index 7ead36cae2ae..816556c08059 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/SearchMigratableResources/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/SearchMigratableResources/main.go index 5d9df85c70fb..e8c84afdf124 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/SearchMigratableResources/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/SearchMigratableResources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/SetIamPolicy/main.go index da9834989c6b..61b9c9caa90b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/TestIamPermissions/main.go index a0507311d3c5..899d3bd90ac3 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/WaitOperation/main.go index d20d6dcff0af..ee720d6b297f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/MigrationClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/BatchImportEvaluatedAnnotations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/BatchImportEvaluatedAnnotations/main.go index 40f312e2791f..38b6c705626d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/BatchImportEvaluatedAnnotations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/BatchImportEvaluatedAnnotations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/BatchImportModelEvaluationSlices/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/BatchImportModelEvaluationSlices/main.go index 0d5ad493a956..283929c61245 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/BatchImportModelEvaluationSlices/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/BatchImportModelEvaluationSlices/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/CancelOperation/main.go index b749c50218e0..4217cd259d76 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/CopyModel/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/CopyModel/main.go index 5b5aa8b3aea6..2858dcb95fb1 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/CopyModel/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/CopyModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/DeleteModel/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/DeleteModel/main.go index a534d8458a71..cbf2be4395a9 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/DeleteModel/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/DeleteModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/DeleteModelVersion/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/DeleteModelVersion/main.go index 5cf9f3e0d4da..04de7b7bf1c6 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/DeleteModelVersion/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/DeleteModelVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/DeleteOperation/main.go index 9ec89eb72027..f4eb81e95225 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ExportModel/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ExportModel/main.go index e47af34678bb..93db63821a9e 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ExportModel/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ExportModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/GetIamPolicy/main.go index 80b2e3df0075..05610be32736 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/GetLocation/main.go index 3fe2e12ddeb1..5d32913da447 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/GetModel/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/GetModel/main.go index 13c9733e7599..a07b9ae20bf0 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/GetModel/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/GetModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/GetModelEvaluation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/GetModelEvaluation/main.go index 77d39431fe1c..f4fbbc684ca9 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/GetModelEvaluation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/GetModelEvaluation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/GetModelEvaluationSlice/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/GetModelEvaluationSlice/main.go index c8d145670a67..f034b094eb8f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/GetModelEvaluationSlice/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/GetModelEvaluationSlice/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/GetOperation/main.go index 47d93ebc578c..5f0cb052ad14 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ImportModelEvaluation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ImportModelEvaluation/main.go index 902d6789b9d7..181e1c4b1652 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ImportModelEvaluation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ImportModelEvaluation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ListLocations/main.go index 2bbe6fbc04a8..03c68e00af2e 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ListModelEvaluationSlices/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ListModelEvaluationSlices/main.go index f8b4722988ff..cb3776d8e48a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ListModelEvaluationSlices/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ListModelEvaluationSlices/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ListModelEvaluations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ListModelEvaluations/main.go index dadacc9a9b4d..7759b550d5af 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ListModelEvaluations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ListModelEvaluations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ListModelVersions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ListModelVersions/main.go index d40e9067cca5..ff4872f6d622 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ListModelVersions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ListModelVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ListModels/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ListModels/main.go index 90be2f9923d3..34c6569a13d2 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ListModels/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ListModels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ListOperations/main.go index 77dff9a7d319..1d1477767975 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/MergeVersionAliases/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/MergeVersionAliases/main.go index 48b79d3410d8..8238039593be 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/MergeVersionAliases/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/MergeVersionAliases/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/SetIamPolicy/main.go index ea6fd94f4ae6..cd93535c449a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/TestIamPermissions/main.go index b67ed4a8e04c..f1391eec3228 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/UpdateExplanationDataset/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/UpdateExplanationDataset/main.go index 913b1ad6e16e..d6e58fce8870 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/UpdateExplanationDataset/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/UpdateExplanationDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/UpdateModel/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/UpdateModel/main.go index d70f6a99a822..3bd0a2d296e2 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/UpdateModel/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/UpdateModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/UploadModel/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/UploadModel/main.go index b39765e4b78e..050d34b242c3 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/UploadModel/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/UploadModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/WaitOperation/main.go index 97880bed574c..0d68b02064dd 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/CancelOperation/main.go index 81118ab26e1d..3e92c7274d9b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/DeleteOperation/main.go index fe5a0227b521..35f628128215 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/DeployPublisherModel/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/DeployPublisherModel/main.go index 6cd552d44020..a8b567af6ae1 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/DeployPublisherModel/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/DeployPublisherModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/GetIamPolicy/main.go index 4bb679f20ee1..d3f81a321b9b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/GetLocation/main.go index 2f31789f6132..200b122b1296 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/GetOperation/main.go index 1cd0652da5cc..b765b9e2eabd 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/GetPublisherModel/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/GetPublisherModel/main.go index 6371edffd9a8..716a1dee9129 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/GetPublisherModel/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/GetPublisherModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/ListLocations/main.go index d025c9fa55cc..55e179035bfd 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/ListOperations/main.go index ad7be96cce27..d972aa079621 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/ListPublisherModels/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/ListPublisherModels/main.go index 71bd35aebb32..9918cb99437d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/ListPublisherModels/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/ListPublisherModels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/SetIamPolicy/main.go index 9f3acfb2bb08..79b4731e2ba1 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/TestIamPermissions/main.go index 4046b2ea5156..7c99e2b7618a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/WaitOperation/main.go index 603196e290b8..9686c4848a43 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelGardenClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/CancelOperation/main.go index a55c5f500da4..40f5711f708d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/CreateModelMonitor/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/CreateModelMonitor/main.go index ee5d653b134f..d487a2c369da 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/CreateModelMonitor/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/CreateModelMonitor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/CreateModelMonitoringJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/CreateModelMonitoringJob/main.go index c388422bfe69..9d75482e9a59 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/CreateModelMonitoringJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/CreateModelMonitoringJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/DeleteModelMonitor/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/DeleteModelMonitor/main.go index 6ada22501fc8..e25d1d2526ce 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/DeleteModelMonitor/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/DeleteModelMonitor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/DeleteModelMonitoringJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/DeleteModelMonitoringJob/main.go index 145f29cd4296..cb0e8bd13e2c 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/DeleteModelMonitoringJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/DeleteModelMonitoringJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/DeleteOperation/main.go index 7fd38347f6d2..6d50040faddb 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/GetIamPolicy/main.go index f4618a68f49c..0f884ac3abe6 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/GetLocation/main.go index 35739d8f7019..c2adfdd638a8 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/GetModelMonitor/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/GetModelMonitor/main.go index ccf8f7d7b5a7..eade6d03ca30 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/GetModelMonitor/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/GetModelMonitor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/GetModelMonitoringJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/GetModelMonitoringJob/main.go index 7561253f90e5..91138dd53b48 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/GetModelMonitoringJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/GetModelMonitoringJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/GetOperation/main.go index 4683d299d415..10103d65e0fa 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/ListLocations/main.go index a7a7bb92feb6..37e2a8ce2242 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/ListModelMonitoringJobs/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/ListModelMonitoringJobs/main.go index 6a569adaf227..bbb7e98ca45c 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/ListModelMonitoringJobs/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/ListModelMonitoringJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/ListModelMonitors/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/ListModelMonitors/main.go index d22f368f8293..a0a67201b4d2 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/ListModelMonitors/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/ListModelMonitors/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/ListOperations/main.go index 0587c1377f07..740d427bf9d3 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/SearchModelMonitoringAlerts/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/SearchModelMonitoringAlerts/main.go index 7bd2a8b682bd..ad48e81edcd9 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/SearchModelMonitoringAlerts/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/SearchModelMonitoringAlerts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/SearchModelMonitoringStats/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/SearchModelMonitoringStats/main.go index 290828074e22..eed17476e20c 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/SearchModelMonitoringStats/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/SearchModelMonitoringStats/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/SetIamPolicy/main.go index f3bcfd7c3184..0285167c462d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/TestIamPermissions/main.go index a93b4f3090e3..8c0db1748798 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/UpdateModelMonitor/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/UpdateModelMonitor/main.go index c801425150a9..91036ca5275e 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/UpdateModelMonitor/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/UpdateModelMonitor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/WaitOperation/main.go index e11856e95408..a21b9be5b940 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ModelMonitoringClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/AssignNotebookRuntime/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/AssignNotebookRuntime/main.go index 37260df0829b..2b9633ec2f07 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/AssignNotebookRuntime/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/AssignNotebookRuntime/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/CancelOperation/main.go index ad2f23d40353..a1ccb72d5771 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/CreateNotebookExecutionJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/CreateNotebookExecutionJob/main.go index 0c96e3bb0e63..09a5dd8ad3f4 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/CreateNotebookExecutionJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/CreateNotebookExecutionJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/CreateNotebookRuntimeTemplate/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/CreateNotebookRuntimeTemplate/main.go index f50e6317cf24..afaf05c3eb9b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/CreateNotebookRuntimeTemplate/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/CreateNotebookRuntimeTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/DeleteNotebookExecutionJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/DeleteNotebookExecutionJob/main.go index 26781bfc7149..f76053147156 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/DeleteNotebookExecutionJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/DeleteNotebookExecutionJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/DeleteNotebookRuntime/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/DeleteNotebookRuntime/main.go index 1cb7a097076e..8f3bfd4b6620 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/DeleteNotebookRuntime/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/DeleteNotebookRuntime/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/DeleteNotebookRuntimeTemplate/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/DeleteNotebookRuntimeTemplate/main.go index 07a709fd57cc..844b159aac4b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/DeleteNotebookRuntimeTemplate/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/DeleteNotebookRuntimeTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/DeleteOperation/main.go index 457d9ba74399..cd094aa2171c 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/GetIamPolicy/main.go index ac7dbb3af4b4..375f9ef673a1 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/GetLocation/main.go index 969591f9859c..a89afb852b09 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/GetNotebookExecutionJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/GetNotebookExecutionJob/main.go index 97532545e29f..0337f92511ee 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/GetNotebookExecutionJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/GetNotebookExecutionJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/GetNotebookRuntime/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/GetNotebookRuntime/main.go index d71f5c1af2b7..069f45ec65ab 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/GetNotebookRuntime/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/GetNotebookRuntime/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/GetNotebookRuntimeTemplate/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/GetNotebookRuntimeTemplate/main.go index 217d2ecb9fa6..953431da6506 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/GetNotebookRuntimeTemplate/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/GetNotebookRuntimeTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/GetOperation/main.go index 75227640fe3a..aaa4c4d0585c 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/ListLocations/main.go index 69b6e8ee53c4..05f60e52450b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/ListNotebookExecutionJobs/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/ListNotebookExecutionJobs/main.go index 93d89887e96e..0d3159adc158 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/ListNotebookExecutionJobs/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/ListNotebookExecutionJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/ListNotebookRuntimeTemplates/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/ListNotebookRuntimeTemplates/main.go index 938e42fecd66..30d436a32d08 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/ListNotebookRuntimeTemplates/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/ListNotebookRuntimeTemplates/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/ListNotebookRuntimes/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/ListNotebookRuntimes/main.go index d699f8156310..3d1e5e79793b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/ListNotebookRuntimes/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/ListNotebookRuntimes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/ListOperations/main.go index 0a6a7902061b..adf988b7a688 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/SetIamPolicy/main.go index ef3b6dd3d883..c7227afca94a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/StartNotebookRuntime/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/StartNotebookRuntime/main.go index a744317ecb44..f9faad496ca8 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/StartNotebookRuntime/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/StartNotebookRuntime/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/StopNotebookRuntime/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/StopNotebookRuntime/main.go index 572d05459da9..7ba19c04aba5 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/StopNotebookRuntime/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/StopNotebookRuntime/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/TestIamPermissions/main.go index 4777e7d9a849..c740e7f3a8a1 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/UpdateNotebookRuntimeTemplate/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/UpdateNotebookRuntimeTemplate/main.go index 2e4ee463fa1b..c371a7720ea2 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/UpdateNotebookRuntimeTemplate/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/UpdateNotebookRuntimeTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/UpgradeNotebookRuntime/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/UpgradeNotebookRuntime/main.go index 927f7b337be2..e96b3cbf4dcc 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/UpgradeNotebookRuntime/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/UpgradeNotebookRuntime/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/WaitOperation/main.go index 1b08a6031a2c..6278b843db10 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/NotebookClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/CancelOperation/main.go index 4eaa86f6672f..3ee68ad24df7 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/CreatePersistentResource/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/CreatePersistentResource/main.go index e9429b667bca..e1f397c55410 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/CreatePersistentResource/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/CreatePersistentResource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/DeleteOperation/main.go index 550596d9248f..15e9cc657941 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/DeletePersistentResource/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/DeletePersistentResource/main.go index e71e86f2da56..a7a95ef0ed75 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/DeletePersistentResource/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/DeletePersistentResource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/GetIamPolicy/main.go index 2e5c5ffdad34..35d035cb8279 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/GetLocation/main.go index 365ed8896548..8b34115b5e7a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/GetOperation/main.go index 69995b866307..ddcf83cd4fcc 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/GetPersistentResource/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/GetPersistentResource/main.go index 161cd61a71c5..1f7c1b25f6e9 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/GetPersistentResource/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/GetPersistentResource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/ListLocations/main.go index cdd632725bc6..736280e4ecf8 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/ListOperations/main.go index bfbbe97b7e77..792c5b6ebbda 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/ListPersistentResources/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/ListPersistentResources/main.go index c04db6a5fe01..b4d12d410552 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/ListPersistentResources/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/ListPersistentResources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/RebootPersistentResource/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/RebootPersistentResource/main.go index 376d336e343e..47911b66acf3 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/RebootPersistentResource/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/RebootPersistentResource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/SetIamPolicy/main.go index 71caff4fcf17..150b7edad9da 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/TestIamPermissions/main.go index fde0b3b218e6..46e42caa2fb8 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/UpdatePersistentResource/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/UpdatePersistentResource/main.go index 3e39a9f4ca7f..0bf286797b04 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/UpdatePersistentResource/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/UpdatePersistentResource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/WaitOperation/main.go index 219fca653d2a..0d548c74cc3f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PersistentResourceClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/BatchCancelPipelineJobs/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/BatchCancelPipelineJobs/main.go index 5ac3fcf00ac9..20e6fdbd9ca8 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/BatchCancelPipelineJobs/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/BatchCancelPipelineJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/BatchDeletePipelineJobs/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/BatchDeletePipelineJobs/main.go index 000a98498794..2af5022407df 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/BatchDeletePipelineJobs/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/BatchDeletePipelineJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/CancelOperation/main.go index fc3191b78d04..97848218ad32 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/CancelPipelineJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/CancelPipelineJob/main.go index 565422b056b2..d0ef6af81b6c 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/CancelPipelineJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/CancelPipelineJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/CancelTrainingPipeline/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/CancelTrainingPipeline/main.go index 3c07959d6886..b429d6dba55f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/CancelTrainingPipeline/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/CancelTrainingPipeline/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/CreatePipelineJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/CreatePipelineJob/main.go index de26c4f0b8e8..1093691184fc 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/CreatePipelineJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/CreatePipelineJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/CreateTrainingPipeline/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/CreateTrainingPipeline/main.go index 3a06c924c8c2..718d0b50e2b9 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/CreateTrainingPipeline/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/CreateTrainingPipeline/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/DeleteOperation/main.go index e727802bbf0e..cc43b4692592 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/DeletePipelineJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/DeletePipelineJob/main.go index c606b4169b85..887691b9dc77 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/DeletePipelineJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/DeletePipelineJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/DeleteTrainingPipeline/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/DeleteTrainingPipeline/main.go index aa7e02e79cdb..44fbe0b79ad9 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/DeleteTrainingPipeline/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/DeleteTrainingPipeline/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/GetIamPolicy/main.go index 51655d85c33f..68441bafbc30 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/GetLocation/main.go index baa56165f7ee..80afefd34572 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/GetOperation/main.go index 8cf71be5a067..14d4e244fde2 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/GetPipelineJob/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/GetPipelineJob/main.go index 199825536de0..ca03df182e0f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/GetPipelineJob/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/GetPipelineJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/GetTrainingPipeline/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/GetTrainingPipeline/main.go index 635071f43a66..af6fc5afffd3 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/GetTrainingPipeline/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/GetTrainingPipeline/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/ListLocations/main.go index d5e204da7dcf..feaa646de8d7 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/ListOperations/main.go index 39841fbd341f..f5e98b759c48 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/ListPipelineJobs/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/ListPipelineJobs/main.go index f5295b46d416..e5e4305b251a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/ListPipelineJobs/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/ListPipelineJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/ListTrainingPipelines/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/ListTrainingPipelines/main.go index ac8025b71f48..ff1ae13f7050 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/ListTrainingPipelines/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/ListTrainingPipelines/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/SetIamPolicy/main.go index fd158874c13f..cdff435f187d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/TestIamPermissions/main.go index 149542634535..dee12b55c99c 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/WaitOperation/main.go index b6d90216571f..9f511fdd795c 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PipelineClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/CancelOperation/main.go index 70740b425df1..ae2b6edad5b0 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/CountTokens/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/CountTokens/main.go index 70f8d893962b..9fd606073785 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/CountTokens/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/CountTokens/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/DeleteOperation/main.go index 689c5fa04bf1..1e2d56b57388 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/DirectPredict/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/DirectPredict/main.go index 3df3ee92ef24..15a1565f3e3d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/DirectPredict/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/DirectPredict/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/DirectRawPredict/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/DirectRawPredict/main.go index 267be7f256b5..39597a2194ba 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/DirectRawPredict/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/DirectRawPredict/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/Explain/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/Explain/main.go index 8c6b58dad9c1..e300ac4c290a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/Explain/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/Explain/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/GenerateContent/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/GenerateContent/main.go index 65b83797d475..1381384854ac 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/GenerateContent/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/GenerateContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/GetIamPolicy/main.go index f41b5a3727ba..242b3e0c8a97 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/GetLocation/main.go index c166888023dc..bacb94734ff7 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/GetOperation/main.go index 30776b5e0394..2999c1442f0b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/ListLocations/main.go index f3a83c58f1bc..daa041311141 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/ListOperations/main.go index b050455f2cdc..77245746dc0f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/Predict/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/Predict/main.go index c3d0f55e8990..48ba8494d0f1 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/Predict/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/Predict/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/RawPredict/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/RawPredict/main.go index 9fbe14ab9f13..5fed60ec3b99 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/RawPredict/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/RawPredict/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/SetIamPolicy/main.go index e0274510af1f..08c652b9a69a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/StreamDirectPredict/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/StreamDirectPredict/main.go index c7f4c9f817c3..9281bcf408c3 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/StreamDirectPredict/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/StreamDirectPredict/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/StreamDirectRawPredict/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/StreamDirectRawPredict/main.go index 77ce022a995b..17b35b84cc8b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/StreamDirectRawPredict/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/StreamDirectRawPredict/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/StreamingPredict/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/StreamingPredict/main.go index fd44661f36dc..c7b94186dfe8 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/StreamingPredict/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/StreamingPredict/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/StreamingRawPredict/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/StreamingRawPredict/main.go index eaecbacb551d..c9c50f1cc589 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/StreamingRawPredict/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/StreamingRawPredict/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/TestIamPermissions/main.go index 8fdc3ba9235d..c157faed780c 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/WaitOperation/main.go index 738d465f6946..20548480a5e7 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/PredictionClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/CancelOperation/main.go index 7c672dcbe876..8653b8ab98e0 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/CreateReasoningEngine/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/CreateReasoningEngine/main.go index bffbf2d13815..cd393859342e 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/CreateReasoningEngine/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/CreateReasoningEngine/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/DeleteOperation/main.go index 37724ae6002a..11b5a1db5d23 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/DeleteReasoningEngine/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/DeleteReasoningEngine/main.go index 632a41874039..96b241c6fae0 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/DeleteReasoningEngine/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/DeleteReasoningEngine/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/GetIamPolicy/main.go index e456b54ae3eb..612ba9cf3ade 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/GetLocation/main.go index cbb0886b6561..1b0da6bc01ef 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/GetOperation/main.go index f9a56e019cbe..d4686b43a10a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/GetReasoningEngine/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/GetReasoningEngine/main.go index 30b9b46dd914..e35eb8af62fc 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/GetReasoningEngine/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/GetReasoningEngine/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/ListLocations/main.go index c363b2927bac..f03c41f309c7 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/ListOperations/main.go index 2455a76dc4e3..9609718901eb 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/ListReasoningEngines/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/ListReasoningEngines/main.go index 975472125854..a94fbc0f68e5 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/ListReasoningEngines/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/ListReasoningEngines/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/SetIamPolicy/main.go index a17409b9493e..8adf47dab7c2 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/TestIamPermissions/main.go index ea1fccc064d6..9900c0d84a0f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/UpdateReasoningEngine/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/UpdateReasoningEngine/main.go index c7f0cfd85225..bf19f43ad6e1 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/UpdateReasoningEngine/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/UpdateReasoningEngine/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/WaitOperation/main.go index 6e04a117a11a..7ad47ee8f0b1 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/CancelOperation/main.go index 82304a22cde3..78d6d3bea6de 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/DeleteOperation/main.go index bbef72bdf98a..764541a05476 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/GetIamPolicy/main.go index 638c74f86647..df6df1069792 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/GetLocation/main.go index 0b2ca3f14474..f06a62f1f3bc 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/GetOperation/main.go index 38a846069bbf..ca5bc9af0a64 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/ListLocations/main.go index fa245a5a9b45..1f408f301673 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/ListOperations/main.go index 6fd3a0142427..a7844c1e0180 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/QueryReasoningEngine/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/QueryReasoningEngine/main.go index acdaa5e6f132..570b1f3a6d42 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/QueryReasoningEngine/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/QueryReasoningEngine/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/SetIamPolicy/main.go index 9b8ba4b92989..7265dd1b6022 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/TestIamPermissions/main.go index 260b8be78f86..073aaed084a7 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/WaitOperation/main.go index 92f9611c2053..c98065591722 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ReasoningEngineExecutionClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/CancelOperation/main.go index 60e2d5b7617b..6552c3a7d1ca 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/CreateSchedule/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/CreateSchedule/main.go index 2016517cfe8d..ef35d94304ff 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/CreateSchedule/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/CreateSchedule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/DeleteOperation/main.go index 84f6c7c1280c..02114ed1ec6b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/DeleteSchedule/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/DeleteSchedule/main.go index cbc759ed15d1..13e4bcda1003 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/DeleteSchedule/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/DeleteSchedule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/GetIamPolicy/main.go index 5c5eff1ba1a6..b33d1a92f4af 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/GetLocation/main.go index 60277ddeb788..7d86adec448a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/GetOperation/main.go index b64730c389d8..9544ef5f85e3 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/GetSchedule/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/GetSchedule/main.go index a6f6d526ee24..62e4a4a74750 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/GetSchedule/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/GetSchedule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/ListLocations/main.go index 9dcd0e7b9452..88a506d3fad9 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/ListOperations/main.go index 7eceed04f16c..89b3edbf1a0c 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/ListSchedules/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/ListSchedules/main.go index a5fa5036fc01..fd79767934f7 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/ListSchedules/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/ListSchedules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/PauseSchedule/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/PauseSchedule/main.go index 6a54c16eb1f7..a9462d928a68 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/PauseSchedule/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/PauseSchedule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/ResumeSchedule/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/ResumeSchedule/main.go index 45a7a33f25c9..ccc1013def9f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/ResumeSchedule/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/ResumeSchedule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/SetIamPolicy/main.go index bc52eea0cc82..39cfc5cca17b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/TestIamPermissions/main.go index ac7fc57e2eb7..15ed2f9c9d5a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/UpdateSchedule/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/UpdateSchedule/main.go index 5aa959481a62..edb81c640561 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/UpdateSchedule/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/UpdateSchedule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/WaitOperation/main.go index 920ee020d87b..1585fe75598e 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/ScheduleClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/CancelOperation/main.go index 9a752c086957..be071e6270c7 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/CreateSpecialistPool/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/CreateSpecialistPool/main.go index 74788dff6433..dbfc2eb65d0d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/CreateSpecialistPool/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/CreateSpecialistPool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/DeleteOperation/main.go index 55eac2e36e23..da3a266f16d9 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/DeleteSpecialistPool/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/DeleteSpecialistPool/main.go index 6ae81053a04c..3ccfe10f0d19 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/DeleteSpecialistPool/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/DeleteSpecialistPool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/GetIamPolicy/main.go index ef2649eecd8b..a0293ac2b23a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/GetLocation/main.go index b82835cf7cf8..9af466de0bcc 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/GetOperation/main.go index 39c79ee01257..0c43fe01009f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/GetSpecialistPool/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/GetSpecialistPool/main.go index 8e681f7d4715..3eae502d9c73 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/GetSpecialistPool/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/GetSpecialistPool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/ListLocations/main.go index bc9b29cef80f..766410cb77ac 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/ListOperations/main.go index 20378c878279..f24528450107 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/ListSpecialistPools/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/ListSpecialistPools/main.go index 3f2b5c7b1cc5..a4572eadb2b0 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/ListSpecialistPools/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/ListSpecialistPools/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/SetIamPolicy/main.go index b4c49a370b49..9ca7c267d197 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/TestIamPermissions/main.go index 40129b6148cf..b4850db6c1ba 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/UpdateSpecialistPool/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/UpdateSpecialistPool/main.go index 12a76d77d08c..c8fa9b828bc3 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/UpdateSpecialistPool/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/UpdateSpecialistPool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/WaitOperation/main.go index c8c513d50ac9..a7272c9c677d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/SpecialistPoolClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/BatchCreateTensorboardRuns/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/BatchCreateTensorboardRuns/main.go index bd658bdd9a92..36cbe3e3ee38 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/BatchCreateTensorboardRuns/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/BatchCreateTensorboardRuns/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/BatchCreateTensorboardTimeSeries/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/BatchCreateTensorboardTimeSeries/main.go index a96410f0ee73..7d73dc31e57a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/BatchCreateTensorboardTimeSeries/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/BatchCreateTensorboardTimeSeries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/BatchReadTensorboardTimeSeriesData/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/BatchReadTensorboardTimeSeriesData/main.go index e8dd169f2878..26238c849010 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/BatchReadTensorboardTimeSeriesData/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/BatchReadTensorboardTimeSeriesData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/CancelOperation/main.go index 3cb77dd19587..50446def2bff 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/CreateTensorboard/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/CreateTensorboard/main.go index 98a8795c7b4d..fffb758ee36d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/CreateTensorboard/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/CreateTensorboard/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/CreateTensorboardExperiment/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/CreateTensorboardExperiment/main.go index 1c71404163ac..61ff93e219b4 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/CreateTensorboardExperiment/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/CreateTensorboardExperiment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/CreateTensorboardRun/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/CreateTensorboardRun/main.go index 37001e8596b6..14164caff028 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/CreateTensorboardRun/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/CreateTensorboardRun/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/CreateTensorboardTimeSeries/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/CreateTensorboardTimeSeries/main.go index 0b3133f5a265..00dadbc442a8 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/CreateTensorboardTimeSeries/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/CreateTensorboardTimeSeries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/DeleteOperation/main.go index 28321121ae56..ba3e7e9cd65d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/DeleteTensorboard/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/DeleteTensorboard/main.go index 8a28a372b3d8..a076ed71ee59 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/DeleteTensorboard/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/DeleteTensorboard/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/DeleteTensorboardExperiment/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/DeleteTensorboardExperiment/main.go index 7ead9fb1fa91..28234204b84a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/DeleteTensorboardExperiment/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/DeleteTensorboardExperiment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/DeleteTensorboardRun/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/DeleteTensorboardRun/main.go index 62c9529f2aa7..5956d70c9e38 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/DeleteTensorboardRun/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/DeleteTensorboardRun/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/DeleteTensorboardTimeSeries/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/DeleteTensorboardTimeSeries/main.go index f68554c7d3ff..caf660c85b89 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/DeleteTensorboardTimeSeries/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/DeleteTensorboardTimeSeries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ExportTensorboardTimeSeriesData/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ExportTensorboardTimeSeriesData/main.go index 408ab6051c3f..c2626d3a7c0e 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ExportTensorboardTimeSeriesData/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ExportTensorboardTimeSeriesData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/GetIamPolicy/main.go index 0e0b6c8b1e92..4847cee133ea 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/GetLocation/main.go index 43328cabf0cb..7408b4e95bb7 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/GetOperation/main.go index 89c51c40ab17..8b1f8e414b27 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/GetTensorboard/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/GetTensorboard/main.go index b1b426839523..4a2e45c24662 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/GetTensorboard/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/GetTensorboard/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/GetTensorboardExperiment/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/GetTensorboardExperiment/main.go index a23237579459..d1084da2bcc3 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/GetTensorboardExperiment/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/GetTensorboardExperiment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/GetTensorboardRun/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/GetTensorboardRun/main.go index d3fee4dc7dc9..989ccc18a540 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/GetTensorboardRun/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/GetTensorboardRun/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/GetTensorboardTimeSeries/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/GetTensorboardTimeSeries/main.go index 25d7cf8c3abd..7b2c7eadaa16 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/GetTensorboardTimeSeries/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/GetTensorboardTimeSeries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ListLocations/main.go index 5297a8eed892..fc7f45e8d21e 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ListOperations/main.go index c329b2426040..c0f06b59c419 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ListTensorboardExperiments/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ListTensorboardExperiments/main.go index 5bb9a579d4fe..ceae59ede634 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ListTensorboardExperiments/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ListTensorboardExperiments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ListTensorboardRuns/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ListTensorboardRuns/main.go index 1aa622566769..1abd62221f59 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ListTensorboardRuns/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ListTensorboardRuns/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ListTensorboardTimeSeries/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ListTensorboardTimeSeries/main.go index e718067738b5..18dab17f908c 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ListTensorboardTimeSeries/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ListTensorboardTimeSeries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ListTensorboards/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ListTensorboards/main.go index 6493a22101a0..093ee3687a65 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ListTensorboards/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ListTensorboards/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ReadTensorboardSize/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ReadTensorboardSize/main.go index b86fddf00116..5b73869bc7d6 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ReadTensorboardSize/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ReadTensorboardSize/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ReadTensorboardTimeSeriesData/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ReadTensorboardTimeSeriesData/main.go index 15638a979d32..d429ebd5328a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ReadTensorboardTimeSeriesData/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ReadTensorboardTimeSeriesData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ReadTensorboardUsage/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ReadTensorboardUsage/main.go index 3609d3c9a4f4..60da6d57a300 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ReadTensorboardUsage/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/ReadTensorboardUsage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/SetIamPolicy/main.go index 7ae4ee26348c..fb31c8bd9801 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/TestIamPermissions/main.go index 564668a25f54..080149fb3bfd 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/UpdateTensorboard/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/UpdateTensorboard/main.go index 62fca815648d..dcc89c3fda60 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/UpdateTensorboard/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/UpdateTensorboard/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/UpdateTensorboardExperiment/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/UpdateTensorboardExperiment/main.go index 0e02ba997351..32b023d5214c 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/UpdateTensorboardExperiment/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/UpdateTensorboardExperiment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/UpdateTensorboardRun/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/UpdateTensorboardRun/main.go index b46797da574b..516d998a0842 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/UpdateTensorboardRun/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/UpdateTensorboardRun/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/UpdateTensorboardTimeSeries/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/UpdateTensorboardTimeSeries/main.go index 20db7ea059b3..c9c8351ece34 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/UpdateTensorboardTimeSeries/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/UpdateTensorboardTimeSeries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/WaitOperation/main.go index 762e138681b4..93a715f07d41 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/WriteTensorboardExperimentData/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/WriteTensorboardExperimentData/main.go index 246419c286b1..8c6360e83f3a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/WriteTensorboardExperimentData/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/WriteTensorboardExperimentData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/WriteTensorboardRunData/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/WriteTensorboardRunData/main.go index f7a74a803069..13a748e847dc 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/WriteTensorboardRunData/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/TensorboardClient/WriteTensorboardRunData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/AugmentPrompt/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/AugmentPrompt/main.go index 7fb4054f1b8d..d9d0aa553c0f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/AugmentPrompt/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/AugmentPrompt/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/CancelOperation/main.go index bb9b42ab33ad..7d39368d6420 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/CorroborateContent/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/CorroborateContent/main.go index ee6a07487bd1..54249ac25403 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/CorroborateContent/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/CorroborateContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/DeleteOperation/main.go index 75b512c4339d..64f5a2040357 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/GetIamPolicy/main.go index 1dbf6deebef8..369cb7283ab0 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/GetLocation/main.go index 069d1e73166c..eb51ac6693e6 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/GetOperation/main.go index 83796a358db8..c5d600571e1d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/ListLocations/main.go index e869345c3ecd..13bacae287f6 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/ListOperations/main.go index ac3e4a5b2602..d74a15e03ef8 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/RetrieveContexts/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/RetrieveContexts/main.go index e942743301a4..f119dbea28a8 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/RetrieveContexts/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/RetrieveContexts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/SetIamPolicy/main.go index 7a0d044277ac..df14d49f9a1a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/TestIamPermissions/main.go index 5ef145276ef9..55ee3ad0810e 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/WaitOperation/main.go index 729cec77e1ce..96f0423eb32f 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/CancelOperation/main.go index ad7fe7430c57..640c9dc867e8 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/CreateRagCorpus/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/CreateRagCorpus/main.go index 1e8dc68744d1..77cafa54e9ad 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/CreateRagCorpus/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/CreateRagCorpus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/DeleteOperation/main.go index eac31a57726c..10ceb74d0452 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/DeleteRagCorpus/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/DeleteRagCorpus/main.go index c953eb63c0fd..981fd1561cce 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/DeleteRagCorpus/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/DeleteRagCorpus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/DeleteRagFile/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/DeleteRagFile/main.go index 7e11cc576322..3b186350401d 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/DeleteRagFile/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/DeleteRagFile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/GetIamPolicy/main.go index dbc9161c1e7f..9ad6b62b8c74 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/GetLocation/main.go index 33c595648024..7697a42ebd68 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/GetOperation/main.go index e5ba4f43d100..5a655d93b9fa 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/GetRagCorpus/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/GetRagCorpus/main.go index 3e1742aa4547..82c0557ac9a9 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/GetRagCorpus/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/GetRagCorpus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/GetRagFile/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/GetRagFile/main.go index e2cd573588d2..026aee68d063 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/GetRagFile/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/GetRagFile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/ImportRagFiles/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/ImportRagFiles/main.go index d8ed6da6202b..7d3ca4e2673b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/ImportRagFiles/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/ImportRagFiles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/ListLocations/main.go index e18f938a5428..5c8a63cefa05 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/ListOperations/main.go index 5122d2814e7f..da014a6ad6eb 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/ListRagCorpora/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/ListRagCorpora/main.go index a6ed2b56ecdc..24f686989087 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/ListRagCorpora/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/ListRagCorpora/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/ListRagFiles/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/ListRagFiles/main.go index f28c5215e27e..f8d6bc9915c8 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/ListRagFiles/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/ListRagFiles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/SetIamPolicy/main.go index 8d8ddd038dd2..7ec5eb933813 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/TestIamPermissions/main.go index 717eb0123b30..de14f46a7876 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/UpdateRagCorpus/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/UpdateRagCorpus/main.go index 75a29c344ed9..88a4386ece59 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/UpdateRagCorpus/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/UpdateRagCorpus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/UploadRagFile/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/UploadRagFile/main.go index 15c7c5cfe0f7..f4cd39071ce5 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/UploadRagFile/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/UploadRagFile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/WaitOperation/main.go index a7489a41519b..0ce18656dd95 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VertexRagDataClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/AddTrialMeasurement/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/AddTrialMeasurement/main.go index e25265471ede..ae6ca03c3462 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/AddTrialMeasurement/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/AddTrialMeasurement/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/CancelOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/CancelOperation/main.go index c4f242d5807b..8b6e8048448e 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/CancelOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/CheckTrialEarlyStoppingState/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/CheckTrialEarlyStoppingState/main.go index 978be19c0aeb..7a43db815c56 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/CheckTrialEarlyStoppingState/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/CheckTrialEarlyStoppingState/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/CompleteTrial/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/CompleteTrial/main.go index 7b30f399d650..6c0f5cf3f58a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/CompleteTrial/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/CompleteTrial/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/CreateStudy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/CreateStudy/main.go index 28e4e448c27f..3079c12dfbe1 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/CreateStudy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/CreateStudy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/CreateTrial/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/CreateTrial/main.go index 588072d86671..fecf715be17a 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/CreateTrial/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/CreateTrial/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/DeleteOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/DeleteOperation/main.go index 859680513999..f40deddb1cc3 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/DeleteOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/DeleteStudy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/DeleteStudy/main.go index 7d949a1f91df..ecc2586d9f08 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/DeleteStudy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/DeleteStudy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/DeleteTrial/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/DeleteTrial/main.go index b67e007568ca..956f25e6e5aa 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/DeleteTrial/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/DeleteTrial/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/GetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/GetIamPolicy/main.go index bc51bdaf0528..d1810746c519 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/GetLocation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/GetLocation/main.go index 3ada53162a92..f57ac0e8d230 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/GetLocation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/GetOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/GetOperation/main.go index b5f2449b02e7..78777a0f3606 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/GetOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/GetStudy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/GetStudy/main.go index c9ece613eb36..a69593d538c6 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/GetStudy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/GetStudy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/GetTrial/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/GetTrial/main.go index ce29cd6a84cd..291be94b15f4 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/GetTrial/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/GetTrial/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/ListLocations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/ListLocations/main.go index bc3397c7f8b6..69d4c9eb7d67 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/ListLocations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/ListOperations/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/ListOperations/main.go index 24ebf7e8dc43..c869adf470bf 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/ListOperations/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/ListOptimalTrials/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/ListOptimalTrials/main.go index 4a5958796aea..c337d78e71ea 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/ListOptimalTrials/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/ListOptimalTrials/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/ListStudies/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/ListStudies/main.go index 376f3427cc67..56ae2b05bfc9 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/ListStudies/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/ListStudies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/ListTrials/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/ListTrials/main.go index 89bc57038c37..ef737464e743 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/ListTrials/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/ListTrials/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/LookupStudy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/LookupStudy/main.go index 031821b95f6c..61f191e54b59 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/LookupStudy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/LookupStudy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/SetIamPolicy/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/SetIamPolicy/main.go index 6ac888dc9c6b..3958c25729f0 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/StopTrial/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/StopTrial/main.go index d14582ee9225..9ae9b04b073b 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/StopTrial/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/StopTrial/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/SuggestTrials/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/SuggestTrials/main.go index 2b447ad54b26..b313d07e0e0c 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/SuggestTrials/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/SuggestTrials/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/TestIamPermissions/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/TestIamPermissions/main.go index 63c4b30e02c7..cce5d5ca17f4 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/WaitOperation/main.go b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/WaitOperation/main.go index 6f0dad4d875a..8068acf5fbf6 100644 --- a/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/WaitOperation/main.go +++ b/internal/generated/snippets/aiplatform/apiv1beta1/VizierClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/BatchCreateInstances/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/BatchCreateInstances/main.go index 28f6726a8344..722a24a37bc6 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/BatchCreateInstances/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/BatchCreateInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/CancelOperation/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/CancelOperation/main.go index 42f2b07e631a..521df89897c0 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/CancelOperation/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/CreateBackup/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/CreateBackup/main.go index e5eba0dc04a7..2263ee44ec95 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/CreateBackup/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/CreateBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/CreateCluster/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/CreateCluster/main.go index 83fd98593f17..a4292030572b 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/CreateCluster/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/CreateCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/CreateInstance/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/CreateInstance/main.go index c3fd94d09ead..60978b5e8024 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/CreateInstance/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/CreateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/CreateSecondaryCluster/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/CreateSecondaryCluster/main.go index f0c7cb277200..2ba72a5c647a 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/CreateSecondaryCluster/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/CreateSecondaryCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/CreateSecondaryInstance/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/CreateSecondaryInstance/main.go index 99a25d9b1a26..18e33d974ba3 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/CreateSecondaryInstance/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/CreateSecondaryInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/CreateUser/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/CreateUser/main.go index b95214ac20be..8ee81ed2a7d5 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/CreateUser/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/CreateUser/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/DeleteBackup/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/DeleteBackup/main.go index f5203d9cc6e5..744ef42abe1c 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/DeleteBackup/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/DeleteBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/DeleteCluster/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/DeleteCluster/main.go index f930cb629db9..e133366c92a6 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/DeleteCluster/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/DeleteCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/DeleteInstance/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/DeleteInstance/main.go index c010f5e76649..2cae91ca3925 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/DeleteInstance/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/DeleteInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/DeleteOperation/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/DeleteOperation/main.go index b7fc60f66134..bfacdcded7a4 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/DeleteOperation/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/DeleteUser/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/DeleteUser/main.go index d9436816c393..9114c4235d12 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/DeleteUser/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/DeleteUser/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ExecuteSql/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ExecuteSql/main.go index 3aeaac566fab..ad445113241a 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ExecuteSql/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ExecuteSql/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/FailoverInstance/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/FailoverInstance/main.go index 1b21ee737a66..9106a4a9724c 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/FailoverInstance/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/FailoverInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GenerateClientCertificate/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GenerateClientCertificate/main.go index 416daf507650..610421b41dcc 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GenerateClientCertificate/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GenerateClientCertificate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GetBackup/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GetBackup/main.go index b56409adf4aa..2db19c76fbd8 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GetBackup/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GetBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GetCluster/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GetCluster/main.go index 4f225cbb970a..bab430b0f2d3 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GetCluster/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GetCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GetConnectionInfo/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GetConnectionInfo/main.go index 08c7f6eb4dea..cae4dd16f9ba 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GetConnectionInfo/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GetConnectionInfo/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GetInstance/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GetInstance/main.go index 37d88e8ae03b..88d634dcfa87 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GetInstance/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GetInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GetLocation/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GetLocation/main.go index 5e42deb1cae4..c4a88527d690 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GetLocation/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GetOperation/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GetOperation/main.go index 3d82d47e0d98..b481270545f5 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GetOperation/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GetUser/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GetUser/main.go index ab2101e30e15..9dcad64eedce 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GetUser/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/GetUser/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/InjectFault/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/InjectFault/main.go index a8aea37fb4eb..550d92775ee3 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/InjectFault/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/InjectFault/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListBackups/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListBackups/main.go index 5deb70e1e94c..67a90f803e5f 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListBackups/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListBackups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListClusters/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListClusters/main.go index 0c9917bc28c0..892a06fc98b9 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListClusters/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListClusters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListDatabases/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListDatabases/main.go index 8d128b54734b..6734ae67976d 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListDatabases/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListDatabases/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListInstances/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListInstances/main.go index 076073d5a981..efeaeac80d7e 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListInstances/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListLocations/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListLocations/main.go index 4e917ee83b42..bdbdf61be0cf 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListLocations/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListOperations/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListOperations/main.go index ae9cba3f2110..7476bdffe6e4 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListOperations/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListSupportedDatabaseFlags/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListSupportedDatabaseFlags/main.go index cc59f881272c..7b82da537350 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListSupportedDatabaseFlags/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListSupportedDatabaseFlags/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListUsers/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListUsers/main.go index b73d180a7655..341f08dcd51b 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListUsers/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/ListUsers/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/PromoteCluster/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/PromoteCluster/main.go index 0729e14dfa32..b18447361005 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/PromoteCluster/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/PromoteCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/RestartInstance/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/RestartInstance/main.go index 091540bedca5..3e8d7199ad25 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/RestartInstance/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/RestartInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/RestoreCluster/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/RestoreCluster/main.go index 7db6ce49d149..f04c90cbbee8 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/RestoreCluster/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/RestoreCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/SwitchoverCluster/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/SwitchoverCluster/main.go index ce113ce8c2ca..536b40cf7980 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/SwitchoverCluster/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/SwitchoverCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/UpdateBackup/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/UpdateBackup/main.go index f658aad7b8b0..82211cbd303e 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/UpdateBackup/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/UpdateBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/UpdateCluster/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/UpdateCluster/main.go index 742d477e640b..4e636c48c1a0 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/UpdateCluster/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/UpdateCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/UpdateInstance/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/UpdateInstance/main.go index 08287af767b2..dbdb32ddb18b 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/UpdateInstance/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/UpdateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/UpdateUser/main.go b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/UpdateUser/main.go index 3d56b6d6ea08..2cc2bb371003 100644 --- a/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/UpdateUser/main.go +++ b/internal/generated/snippets/alloydb/apiv1/AlloyDBAdminClient/UpdateUser/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1/snippet_metadata.google.cloud.alloydb.v1.json b/internal/generated/snippets/alloydb/apiv1/snippet_metadata.google.cloud.alloydb.v1.json index 1c05f4b07318..ec8e674bdd5c 100644 --- a/internal/generated/snippets/alloydb/apiv1/snippet_metadata.google.cloud.alloydb.v1.json +++ b/internal/generated/snippets/alloydb/apiv1/snippet_metadata.google.cloud.alloydb.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/alloydb/apiv1", - "version": "1.14.0", + "version": "1.14.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/BatchCreateInstances/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/BatchCreateInstances/main.go index f268817372e4..562530fff8f5 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/BatchCreateInstances/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/BatchCreateInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/CancelOperation/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/CancelOperation/main.go index 72db0ca02858..67ce1e6db593 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/CancelOperation/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/CreateBackup/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/CreateBackup/main.go index b9042fa347c7..c5cf98a1324d 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/CreateBackup/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/CreateBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/CreateCluster/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/CreateCluster/main.go index 6ebf0cb9a035..b053f6ff3eeb 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/CreateCluster/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/CreateCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/CreateInstance/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/CreateInstance/main.go index 1028a1cd9159..1facec88b75c 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/CreateInstance/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/CreateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/CreateSecondaryCluster/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/CreateSecondaryCluster/main.go index c15ce4fb720c..23eae384979a 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/CreateSecondaryCluster/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/CreateSecondaryCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/CreateSecondaryInstance/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/CreateSecondaryInstance/main.go index 5233a6052869..56f9cc952f75 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/CreateSecondaryInstance/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/CreateSecondaryInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/CreateUser/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/CreateUser/main.go index 33dcced77bd1..899e5a6b4fcc 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/CreateUser/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/CreateUser/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/DeleteBackup/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/DeleteBackup/main.go index 94f0a106607b..103b3ec347ae 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/DeleteBackup/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/DeleteBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/DeleteCluster/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/DeleteCluster/main.go index 09030dd68e33..62880cd6e701 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/DeleteCluster/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/DeleteCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/DeleteInstance/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/DeleteInstance/main.go index fa2fb20d1653..6ae03b9ceda7 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/DeleteInstance/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/DeleteInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/DeleteOperation/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/DeleteOperation/main.go index 46c175bbeef4..09126323dd98 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/DeleteOperation/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/DeleteUser/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/DeleteUser/main.go index 3c987f25f0a7..42f74c1ed48a 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/DeleteUser/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/DeleteUser/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ExecuteSql/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ExecuteSql/main.go index ee27fcf21f82..0c41fed22dad 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ExecuteSql/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ExecuteSql/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/FailoverInstance/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/FailoverInstance/main.go index 76d8236e0848..91ebf1beb17d 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/FailoverInstance/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/FailoverInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GenerateClientCertificate/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GenerateClientCertificate/main.go index 08cedbeafae8..fa4f27e8a248 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GenerateClientCertificate/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GenerateClientCertificate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GetBackup/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GetBackup/main.go index e3719eed6eef..b8fd1f77faa8 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GetBackup/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GetBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GetCluster/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GetCluster/main.go index fd8af28a5dcf..04272621cdb5 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GetCluster/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GetCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GetConnectionInfo/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GetConnectionInfo/main.go index 5125bb1d8b1d..eac43b7dcec1 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GetConnectionInfo/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GetConnectionInfo/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GetInstance/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GetInstance/main.go index bffb5a0d2005..44030d3e85b6 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GetInstance/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GetInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GetLocation/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GetLocation/main.go index 3f64f7ecb3cd..21fe34170d39 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GetLocation/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GetOperation/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GetOperation/main.go index 42172db0fccc..6b66ab65d6cc 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GetOperation/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GetUser/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GetUser/main.go index cf195ded5aca..e8bb24a6988b 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GetUser/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/GetUser/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/InjectFault/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/InjectFault/main.go index 34ac2a41056a..d52beb6b25e9 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/InjectFault/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/InjectFault/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListBackups/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListBackups/main.go index 243b7d4a77c2..62175978721d 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListBackups/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListBackups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListClusters/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListClusters/main.go index edd02163e393..cc8dc15bc260 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListClusters/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListClusters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListDatabases/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListDatabases/main.go index 322e37ee697e..52a29ea56b08 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListDatabases/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListDatabases/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListInstances/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListInstances/main.go index 39ab7462ede0..01e1047b115a 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListInstances/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListLocations/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListLocations/main.go index e4201bcd59e1..0f07e9174d96 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListLocations/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListOperations/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListOperations/main.go index c0da7f5a0020..fe57f5392204 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListOperations/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListSupportedDatabaseFlags/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListSupportedDatabaseFlags/main.go index 47f3d0a2e6bb..48abdb2dd1b2 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListSupportedDatabaseFlags/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListSupportedDatabaseFlags/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListUsers/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListUsers/main.go index b5d9d2b2a63d..da14193782a7 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListUsers/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/ListUsers/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/PromoteCluster/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/PromoteCluster/main.go index 6a8c9ae31500..300f7225a763 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/PromoteCluster/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/PromoteCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/RestartInstance/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/RestartInstance/main.go index c7206b195640..d15114dd2300 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/RestartInstance/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/RestartInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/RestoreCluster/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/RestoreCluster/main.go index 3ba1bd25a0ee..6660200c3d2f 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/RestoreCluster/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/RestoreCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/SwitchoverCluster/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/SwitchoverCluster/main.go index 3b208c95f703..cd555dc379b8 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/SwitchoverCluster/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/SwitchoverCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/UpdateBackup/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/UpdateBackup/main.go index fd71df6a6b9f..f57dc46666f0 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/UpdateBackup/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/UpdateBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/UpdateCluster/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/UpdateCluster/main.go index 1f7e1cba1e95..85762db08a19 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/UpdateCluster/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/UpdateCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/UpdateInstance/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/UpdateInstance/main.go index 465cbd35928f..72c7e4cbb528 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/UpdateInstance/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/UpdateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/UpdateUser/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/UpdateUser/main.go index e3445b97946c..401132dcb8ee 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/UpdateUser/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/UpdateUser/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/UpgradeCluster/main.go b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/UpgradeCluster/main.go index 46b02b78724c..527e4e5be3fc 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/UpgradeCluster/main.go +++ b/internal/generated/snippets/alloydb/apiv1alpha/AlloyDBAdminClient/UpgradeCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1alpha/snippet_metadata.google.cloud.alloydb.v1alpha.json b/internal/generated/snippets/alloydb/apiv1alpha/snippet_metadata.google.cloud.alloydb.v1alpha.json index b7bff8604570..ff6690e18083 100644 --- a/internal/generated/snippets/alloydb/apiv1alpha/snippet_metadata.google.cloud.alloydb.v1alpha.json +++ b/internal/generated/snippets/alloydb/apiv1alpha/snippet_metadata.google.cloud.alloydb.v1alpha.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/alloydb/apiv1alpha", - "version": "1.14.0", + "version": "1.14.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/BatchCreateInstances/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/BatchCreateInstances/main.go index c8bdead73c40..c75d0c8281c8 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/BatchCreateInstances/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/BatchCreateInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/CancelOperation/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/CancelOperation/main.go index ff632dd4ea2b..e543138c37c8 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/CancelOperation/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/CreateBackup/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/CreateBackup/main.go index c7033bfbb75c..3b1597c94722 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/CreateBackup/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/CreateBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/CreateCluster/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/CreateCluster/main.go index 6a027d21cef5..9739b97687dd 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/CreateCluster/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/CreateCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/CreateInstance/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/CreateInstance/main.go index ea0a470dc18e..d14f7cd35a9d 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/CreateInstance/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/CreateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/CreateSecondaryCluster/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/CreateSecondaryCluster/main.go index 50d18b61ba47..cb4a078f3e00 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/CreateSecondaryCluster/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/CreateSecondaryCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/CreateSecondaryInstance/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/CreateSecondaryInstance/main.go index aced7fec26f2..1ce1f628dc4d 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/CreateSecondaryInstance/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/CreateSecondaryInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/CreateUser/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/CreateUser/main.go index 6ac2e2b9d87b..719631ca1113 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/CreateUser/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/CreateUser/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/DeleteBackup/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/DeleteBackup/main.go index c55c80b4d6f8..267daff8fe59 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/DeleteBackup/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/DeleteBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/DeleteCluster/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/DeleteCluster/main.go index b0ef5e9e4f88..1aa0429b9b05 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/DeleteCluster/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/DeleteCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/DeleteInstance/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/DeleteInstance/main.go index 338b9d720850..1ad2a901937a 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/DeleteInstance/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/DeleteInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/DeleteOperation/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/DeleteOperation/main.go index 7cd62b1566c7..6f5e713b8c54 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/DeleteOperation/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/DeleteUser/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/DeleteUser/main.go index 11e6980249a1..e331e1380007 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/DeleteUser/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/DeleteUser/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ExecuteSql/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ExecuteSql/main.go index 88f7bb8ff7a5..61fa67d500d8 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ExecuteSql/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ExecuteSql/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/FailoverInstance/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/FailoverInstance/main.go index f7ec8c883719..a71f59ca0d09 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/FailoverInstance/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/FailoverInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GenerateClientCertificate/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GenerateClientCertificate/main.go index 0ef61ceb6dc5..24f3d81cdee8 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GenerateClientCertificate/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GenerateClientCertificate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GetBackup/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GetBackup/main.go index 37364587b4aa..90545b94e034 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GetBackup/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GetBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GetCluster/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GetCluster/main.go index f4bac6f47abc..6027237e61ce 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GetCluster/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GetCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GetConnectionInfo/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GetConnectionInfo/main.go index d123cb01111a..9e11c4278291 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GetConnectionInfo/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GetConnectionInfo/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GetInstance/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GetInstance/main.go index 98c05e1d5142..9dd432689896 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GetInstance/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GetInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GetLocation/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GetLocation/main.go index 8c9f6c711417..b700a8f6d00f 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GetLocation/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GetOperation/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GetOperation/main.go index a35b97e47892..92429c9d8bbf 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GetOperation/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GetUser/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GetUser/main.go index ca753541a066..6eb3d76e1f7e 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GetUser/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/GetUser/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/InjectFault/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/InjectFault/main.go index 59ace2aa2879..ca01c46f15b6 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/InjectFault/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/InjectFault/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListBackups/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListBackups/main.go index 50ee8181df9b..6ac0ba4e0fd3 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListBackups/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListBackups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListClusters/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListClusters/main.go index 489bb5b030ed..b3df49cb60e7 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListClusters/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListClusters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListDatabases/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListDatabases/main.go index 6362fa5d70cf..152333d68bcf 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListDatabases/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListDatabases/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListInstances/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListInstances/main.go index 66481b9b2710..e8ac59eeafb7 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListInstances/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListLocations/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListLocations/main.go index 71eda95b3525..908c6db2c55d 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListLocations/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListOperations/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListOperations/main.go index 5a7e1d0b1226..60292935c20b 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListOperations/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListSupportedDatabaseFlags/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListSupportedDatabaseFlags/main.go index 34744ae5f211..2ab54bd0efba 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListSupportedDatabaseFlags/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListSupportedDatabaseFlags/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListUsers/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListUsers/main.go index 7ccc8d751aeb..1147463e9871 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListUsers/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/ListUsers/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/PromoteCluster/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/PromoteCluster/main.go index 62a12542c030..0a59b778aa33 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/PromoteCluster/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/PromoteCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/RestartInstance/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/RestartInstance/main.go index 58b0f497fe78..4eeebab18dc8 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/RestartInstance/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/RestartInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/RestoreCluster/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/RestoreCluster/main.go index a06e5c9c6a0e..b35b09be7d05 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/RestoreCluster/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/RestoreCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/SwitchoverCluster/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/SwitchoverCluster/main.go index 2af28ba07087..4ce98587572e 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/SwitchoverCluster/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/SwitchoverCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/UpdateBackup/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/UpdateBackup/main.go index ff62c73b1ac9..a31a4e2d5d3e 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/UpdateBackup/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/UpdateBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/UpdateCluster/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/UpdateCluster/main.go index 8def0b17e1f9..9b3e06cdd310 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/UpdateCluster/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/UpdateCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/UpdateInstance/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/UpdateInstance/main.go index ff98a42a072c..937ffe00c91f 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/UpdateInstance/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/UpdateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/UpdateUser/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/UpdateUser/main.go index 7c091ce8514d..21cda1a7a707 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/UpdateUser/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/UpdateUser/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/UpgradeCluster/main.go b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/UpgradeCluster/main.go index 3c883992df38..a40e7504b5ce 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/UpgradeCluster/main.go +++ b/internal/generated/snippets/alloydb/apiv1beta/AlloyDBAdminClient/UpgradeCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/alloydb/apiv1beta/snippet_metadata.google.cloud.alloydb.v1beta.json b/internal/generated/snippets/alloydb/apiv1beta/snippet_metadata.google.cloud.alloydb.v1beta.json index a4e0307ed256..adf8d48d8ccc 100644 --- a/internal/generated/snippets/alloydb/apiv1beta/snippet_metadata.google.cloud.alloydb.v1beta.json +++ b/internal/generated/snippets/alloydb/apiv1beta/snippet_metadata.google.cloud.alloydb.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/alloydb/apiv1beta", - "version": "1.14.0", + "version": "1.14.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/AcknowledgeUserDataCollection/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/AcknowledgeUserDataCollection/main.go index fda747642008..37e2365d8504 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/AcknowledgeUserDataCollection/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/AcknowledgeUserDataCollection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ApproveDisplayVideo360AdvertiserLinkProposal/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ApproveDisplayVideo360AdvertiserLinkProposal/main.go index b050823dcd7b..7011c3e6f760 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ApproveDisplayVideo360AdvertiserLinkProposal/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ApproveDisplayVideo360AdvertiserLinkProposal/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ArchiveAudience/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ArchiveAudience/main.go index 1a41181e895f..a724dff49da0 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ArchiveAudience/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ArchiveAudience/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ArchiveCustomDimension/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ArchiveCustomDimension/main.go index 0f5e42bca376..bd4541b4a29a 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ArchiveCustomDimension/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ArchiveCustomDimension/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ArchiveCustomMetric/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ArchiveCustomMetric/main.go index a79aa3c02a66..a9c7dbb03897 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ArchiveCustomMetric/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ArchiveCustomMetric/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/BatchCreateAccessBindings/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/BatchCreateAccessBindings/main.go index df4970b52c6e..a6703f9edacb 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/BatchCreateAccessBindings/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/BatchCreateAccessBindings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/BatchDeleteAccessBindings/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/BatchDeleteAccessBindings/main.go index 64485e53a225..9a315abef42a 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/BatchDeleteAccessBindings/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/BatchDeleteAccessBindings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/BatchGetAccessBindings/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/BatchGetAccessBindings/main.go index eaa0684e2f9c..4ad1bebdc27b 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/BatchGetAccessBindings/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/BatchGetAccessBindings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/BatchUpdateAccessBindings/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/BatchUpdateAccessBindings/main.go index 0ad2dfe3d87d..c5951262346c 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/BatchUpdateAccessBindings/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/BatchUpdateAccessBindings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CancelDisplayVideo360AdvertiserLinkProposal/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CancelDisplayVideo360AdvertiserLinkProposal/main.go index f9e4bad54386..f1afeb362bd4 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CancelDisplayVideo360AdvertiserLinkProposal/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CancelDisplayVideo360AdvertiserLinkProposal/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateAccessBinding/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateAccessBinding/main.go index 49ed8fd9d708..842918682daa 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateAccessBinding/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateAccessBinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateAdSenseLink/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateAdSenseLink/main.go index 53bf4754d96e..8951bb90826c 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateAdSenseLink/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateAdSenseLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateAudience/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateAudience/main.go index 863b2f78a45e..79f39b824e2d 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateAudience/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateAudience/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateBigQueryLink/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateBigQueryLink/main.go index f2932cff6e72..95d474213bcd 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateBigQueryLink/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateBigQueryLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateCalculatedMetric/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateCalculatedMetric/main.go index 03e4f2a9dd14..1a0a4656db7f 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateCalculatedMetric/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateCalculatedMetric/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateChannelGroup/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateChannelGroup/main.go index 43c941c9ca82..f545642c536f 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateChannelGroup/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateChannelGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateConnectedSiteTag/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateConnectedSiteTag/main.go index 4493a470ea7d..a2c86ae2f387 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateConnectedSiteTag/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateConnectedSiteTag/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateConversionEvent/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateConversionEvent/main.go index 1727d52fe1cf..cf58879d44fb 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateConversionEvent/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateConversionEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateCustomDimension/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateCustomDimension/main.go index c7e7bb4363f9..c2077ff7157f 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateCustomDimension/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateCustomDimension/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateCustomMetric/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateCustomMetric/main.go index 910285f47c5a..4466f18f93b3 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateCustomMetric/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateCustomMetric/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateDataStream/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateDataStream/main.go index 59800a953b30..2861cf488a82 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateDataStream/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateDataStream/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateDisplayVideo360AdvertiserLink/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateDisplayVideo360AdvertiserLink/main.go index 3886b9622dbd..1dcd352b8b18 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateDisplayVideo360AdvertiserLink/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateDisplayVideo360AdvertiserLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateDisplayVideo360AdvertiserLinkProposal/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateDisplayVideo360AdvertiserLinkProposal/main.go index f724a6a842cf..f30c6a70571d 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateDisplayVideo360AdvertiserLinkProposal/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateDisplayVideo360AdvertiserLinkProposal/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateEventCreateRule/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateEventCreateRule/main.go index 19be11c3a8ce..db80da3d6695 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateEventCreateRule/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateEventCreateRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateEventEditRule/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateEventEditRule/main.go index 7b10dbb52dd8..cb83d014c441 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateEventEditRule/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateEventEditRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateExpandedDataSet/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateExpandedDataSet/main.go index 4bdbeafe2ae6..aca9577f3a1a 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateExpandedDataSet/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateExpandedDataSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateFirebaseLink/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateFirebaseLink/main.go index e3f496abca98..08ff6aaa6d17 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateFirebaseLink/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateFirebaseLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateGoogleAdsLink/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateGoogleAdsLink/main.go index 2ed62e1d612c..74614bd2b7ed 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateGoogleAdsLink/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateGoogleAdsLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateKeyEvent/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateKeyEvent/main.go index 68bf15cbf26a..269a643c6c02 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateKeyEvent/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateKeyEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateMeasurementProtocolSecret/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateMeasurementProtocolSecret/main.go index 876b5b38853a..f64aeb50e963 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateMeasurementProtocolSecret/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateMeasurementProtocolSecret/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateProperty/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateProperty/main.go index 29056a3a6448..a7cea796fd86 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateProperty/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateProperty/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateRollupProperty/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateRollupProperty/main.go index 7950fd6e94ec..94fe58932dac 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateRollupProperty/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateRollupProperty/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateRollupPropertySourceLink/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateRollupPropertySourceLink/main.go index d25e10b0a73b..87d846733849 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateRollupPropertySourceLink/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateRollupPropertySourceLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateSKAdNetworkConversionValueSchema/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateSKAdNetworkConversionValueSchema/main.go index d8ef57d94545..1d237f033f56 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateSKAdNetworkConversionValueSchema/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateSKAdNetworkConversionValueSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateSearchAds360Link/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateSearchAds360Link/main.go index 0548898a2252..10062eea9004 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateSearchAds360Link/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateSearchAds360Link/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateSubpropertyEventFilter/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateSubpropertyEventFilter/main.go index 3faed95e2d24..6007871e643e 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateSubpropertyEventFilter/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/CreateSubpropertyEventFilter/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteAccessBinding/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteAccessBinding/main.go index b70c6d315691..e841aa7b97a7 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteAccessBinding/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteAccessBinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteAccount/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteAccount/main.go index ea9c7adf7e10..b8660c8d561f 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteAccount/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteAccount/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteAdSenseLink/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteAdSenseLink/main.go index e94665217a69..438d27f394fc 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteAdSenseLink/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteAdSenseLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteBigQueryLink/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteBigQueryLink/main.go index 3de3438c8f06..c67f22974fee 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteBigQueryLink/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteBigQueryLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteCalculatedMetric/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteCalculatedMetric/main.go index f0a631d5bb9f..154476e3ebe8 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteCalculatedMetric/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteCalculatedMetric/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteChannelGroup/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteChannelGroup/main.go index 9a21e933ab7f..1ac72a0a5eeb 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteChannelGroup/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteChannelGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteConnectedSiteTag/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteConnectedSiteTag/main.go index 8aea55ec87f1..1677de176afc 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteConnectedSiteTag/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteConnectedSiteTag/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteConversionEvent/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteConversionEvent/main.go index 5952dd3e6eb2..1c6bf91ad056 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteConversionEvent/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteConversionEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteDataStream/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteDataStream/main.go index 477b2fa3d5f7..2dfcc6fdf1d6 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteDataStream/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteDataStream/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteDisplayVideo360AdvertiserLink/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteDisplayVideo360AdvertiserLink/main.go index 41284b594c66..189333f5db5e 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteDisplayVideo360AdvertiserLink/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteDisplayVideo360AdvertiserLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteDisplayVideo360AdvertiserLinkProposal/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteDisplayVideo360AdvertiserLinkProposal/main.go index fc56656ca5aa..ef7e4e11c1a4 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteDisplayVideo360AdvertiserLinkProposal/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteDisplayVideo360AdvertiserLinkProposal/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteEventCreateRule/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteEventCreateRule/main.go index 0348f07f535a..15055f0543f2 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteEventCreateRule/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteEventCreateRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteEventEditRule/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteEventEditRule/main.go index ac4f9076f80f..70b6a54ecd57 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteEventEditRule/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteEventEditRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteExpandedDataSet/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteExpandedDataSet/main.go index c1d2dc4ccdb0..e0b50a2e599e 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteExpandedDataSet/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteExpandedDataSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteFirebaseLink/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteFirebaseLink/main.go index a94312d76ba1..d84a64140541 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteFirebaseLink/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteFirebaseLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteGoogleAdsLink/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteGoogleAdsLink/main.go index 937dfdd48d36..1175e0a4d38f 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteGoogleAdsLink/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteGoogleAdsLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteKeyEvent/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteKeyEvent/main.go index 711c3de51a11..56d3229e06b4 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteKeyEvent/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteKeyEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteMeasurementProtocolSecret/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteMeasurementProtocolSecret/main.go index 47e5aab598a3..80f3c91311b7 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteMeasurementProtocolSecret/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteMeasurementProtocolSecret/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteProperty/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteProperty/main.go index 208d822b9d00..b17d2687290e 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteProperty/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteProperty/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteRollupPropertySourceLink/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteRollupPropertySourceLink/main.go index 0d9843166eae..35a941823eb8 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteRollupPropertySourceLink/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteRollupPropertySourceLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteSKAdNetworkConversionValueSchema/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteSKAdNetworkConversionValueSchema/main.go index ae59420a77b7..9dfaf74afa5b 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteSKAdNetworkConversionValueSchema/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteSKAdNetworkConversionValueSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteSearchAds360Link/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteSearchAds360Link/main.go index d8fca11d23d9..bc1daaedb869 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteSearchAds360Link/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteSearchAds360Link/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteSubpropertyEventFilter/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteSubpropertyEventFilter/main.go index 5d97196cb3d7..24e75d6b45ad 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteSubpropertyEventFilter/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/DeleteSubpropertyEventFilter/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/FetchAutomatedGa4ConfigurationOptOut/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/FetchAutomatedGa4ConfigurationOptOut/main.go index 22a447828fac..a9d5d45e7cad 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/FetchAutomatedGa4ConfigurationOptOut/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/FetchAutomatedGa4ConfigurationOptOut/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/FetchConnectedGa4Property/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/FetchConnectedGa4Property/main.go index 795e8e0f2664..7847175099d0 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/FetchConnectedGa4Property/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/FetchConnectedGa4Property/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetAccessBinding/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetAccessBinding/main.go index 15b2f939a3a9..0794791a2f22 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetAccessBinding/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetAccessBinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetAccount/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetAccount/main.go index 32eb1bc888ff..5ecc902ecb99 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetAccount/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetAccount/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetAdSenseLink/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetAdSenseLink/main.go index 84499d74b670..c6cbbbcddbb1 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetAdSenseLink/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetAdSenseLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetAttributionSettings/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetAttributionSettings/main.go index 2469883eb329..585f8d451122 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetAttributionSettings/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetAttributionSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetAudience/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetAudience/main.go index 2b4c4cd8391b..9a4aa09159c9 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetAudience/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetAudience/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetBigQueryLink/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetBigQueryLink/main.go index 324386905979..1d12c1c0ad7c 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetBigQueryLink/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetBigQueryLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetCalculatedMetric/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetCalculatedMetric/main.go index 71ff47479785..1fd603f21756 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetCalculatedMetric/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetCalculatedMetric/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetChannelGroup/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetChannelGroup/main.go index 32c2f5b48fae..08c3a9520b26 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetChannelGroup/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetChannelGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetConversionEvent/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetConversionEvent/main.go index 7a5030d7a134..edf8745a9ab5 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetConversionEvent/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetConversionEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetCustomDimension/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetCustomDimension/main.go index 68fa092142a8..e6b4dba366fe 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetCustomDimension/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetCustomDimension/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetCustomMetric/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetCustomMetric/main.go index 179f7b6bd6f1..93579e56dacc 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetCustomMetric/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetCustomMetric/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetDataRedactionSettings/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetDataRedactionSettings/main.go index 0f50572feefc..f35e574b63a6 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetDataRedactionSettings/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetDataRedactionSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetDataRetentionSettings/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetDataRetentionSettings/main.go index 4a8d8fc3299b..25115b6657a6 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetDataRetentionSettings/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetDataRetentionSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetDataSharingSettings/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetDataSharingSettings/main.go index a12d24ab2207..4af53b4a3974 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetDataSharingSettings/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetDataSharingSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetDataStream/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetDataStream/main.go index 70372851da13..27ff4e8045ce 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetDataStream/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetDataStream/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetDisplayVideo360AdvertiserLink/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetDisplayVideo360AdvertiserLink/main.go index df67a8bcfd49..539b848fc7a9 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetDisplayVideo360AdvertiserLink/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetDisplayVideo360AdvertiserLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetDisplayVideo360AdvertiserLinkProposal/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetDisplayVideo360AdvertiserLinkProposal/main.go index cbcb400244cb..ec1f0ee58f9c 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetDisplayVideo360AdvertiserLinkProposal/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetDisplayVideo360AdvertiserLinkProposal/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetEnhancedMeasurementSettings/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetEnhancedMeasurementSettings/main.go index 54bfa24d6114..ae3ba477ada0 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetEnhancedMeasurementSettings/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetEnhancedMeasurementSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetEventCreateRule/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetEventCreateRule/main.go index 84c63e6795b9..cce1aedfda79 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetEventCreateRule/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetEventCreateRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetEventEditRule/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetEventEditRule/main.go index e2abd3195738..01af52b6a081 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetEventEditRule/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetEventEditRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetExpandedDataSet/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetExpandedDataSet/main.go index a90cc5bad416..2920c5e44b3b 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetExpandedDataSet/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetExpandedDataSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetGlobalSiteTag/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetGlobalSiteTag/main.go index bb52895bf759..501a957de289 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetGlobalSiteTag/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetGlobalSiteTag/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetGoogleSignalsSettings/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetGoogleSignalsSettings/main.go index c88d85e47d2e..ff3a06c37dec 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetGoogleSignalsSettings/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetGoogleSignalsSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetKeyEvent/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetKeyEvent/main.go index 326ceb5833dd..8ae836e94eeb 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetKeyEvent/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetKeyEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetMeasurementProtocolSecret/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetMeasurementProtocolSecret/main.go index d531d04fbe6b..fb922d428aef 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetMeasurementProtocolSecret/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetMeasurementProtocolSecret/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetProperty/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetProperty/main.go index 24aa456ff627..8450315c334c 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetProperty/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetProperty/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetRollupPropertySourceLink/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetRollupPropertySourceLink/main.go index 32ebc6c8b29b..c56bca6a2477 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetRollupPropertySourceLink/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetRollupPropertySourceLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetSKAdNetworkConversionValueSchema/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetSKAdNetworkConversionValueSchema/main.go index f8ba0555f0f1..2a2e5ccd5ea3 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetSKAdNetworkConversionValueSchema/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetSKAdNetworkConversionValueSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetSearchAds360Link/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetSearchAds360Link/main.go index 46febce5cb5d..fcdc1dce328c 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetSearchAds360Link/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetSearchAds360Link/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetSubpropertyEventFilter/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetSubpropertyEventFilter/main.go index f482c8f6b148..f85afcde35ce 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetSubpropertyEventFilter/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/GetSubpropertyEventFilter/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListAccessBindings/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListAccessBindings/main.go index 7d3a375b46dd..761ab2b4e609 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListAccessBindings/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListAccessBindings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListAccountSummaries/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListAccountSummaries/main.go index 28f8ecfaf49a..122de3833d0e 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListAccountSummaries/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListAccountSummaries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListAccounts/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListAccounts/main.go index 49289978eab8..ba1d831ce1ca 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListAccounts/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListAccounts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListAdSenseLinks/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListAdSenseLinks/main.go index a5be3ebdd645..db34e2f8d244 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListAdSenseLinks/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListAdSenseLinks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListAudiences/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListAudiences/main.go index 4a3691aadb22..d604b338b59e 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListAudiences/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListAudiences/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListBigQueryLinks/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListBigQueryLinks/main.go index 833140bb3ea1..9f92ea665681 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListBigQueryLinks/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListBigQueryLinks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListCalculatedMetrics/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListCalculatedMetrics/main.go index be63d6ec5595..ee641168866b 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListCalculatedMetrics/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListCalculatedMetrics/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListChannelGroups/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListChannelGroups/main.go index 94574b90cee9..7ff9c198a7a7 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListChannelGroups/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListChannelGroups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListConnectedSiteTags/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListConnectedSiteTags/main.go index 5badfd71b1c0..086a3ba22ac8 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListConnectedSiteTags/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListConnectedSiteTags/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListConversionEvents/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListConversionEvents/main.go index 22fc6b7e0611..ba3d678a7795 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListConversionEvents/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListConversionEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListCustomDimensions/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListCustomDimensions/main.go index 2bce1bac5910..5049d988bf91 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListCustomDimensions/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListCustomDimensions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListCustomMetrics/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListCustomMetrics/main.go index a1a1a5f584ad..b3092b6672f9 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListCustomMetrics/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListCustomMetrics/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListDataStreams/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListDataStreams/main.go index fea2f71c389d..32fcd68f8bf2 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListDataStreams/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListDataStreams/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListDisplayVideo360AdvertiserLinkProposals/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListDisplayVideo360AdvertiserLinkProposals/main.go index be8a580e238d..187db684656d 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListDisplayVideo360AdvertiserLinkProposals/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListDisplayVideo360AdvertiserLinkProposals/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListDisplayVideo360AdvertiserLinks/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListDisplayVideo360AdvertiserLinks/main.go index 5caf1066eadb..51ac99c25375 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListDisplayVideo360AdvertiserLinks/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListDisplayVideo360AdvertiserLinks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListEventCreateRules/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListEventCreateRules/main.go index f795de1d1f5f..950043983d90 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListEventCreateRules/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListEventCreateRules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListEventEditRules/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListEventEditRules/main.go index 680e5859e774..dbe0640b9952 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListEventEditRules/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListEventEditRules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListExpandedDataSets/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListExpandedDataSets/main.go index 921d1f85f218..cfd9e8ccaead 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListExpandedDataSets/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListExpandedDataSets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListFirebaseLinks/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListFirebaseLinks/main.go index 10ddd2e1d5ad..0430a7045489 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListFirebaseLinks/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListFirebaseLinks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListGoogleAdsLinks/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListGoogleAdsLinks/main.go index 4057e56caf33..0e2e0830a1b7 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListGoogleAdsLinks/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListGoogleAdsLinks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListKeyEvents/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListKeyEvents/main.go index fc48b34f1876..3fdc5d33aa47 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListKeyEvents/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListKeyEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListMeasurementProtocolSecrets/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListMeasurementProtocolSecrets/main.go index 33e64d1a0e41..0396ba9b9236 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListMeasurementProtocolSecrets/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListMeasurementProtocolSecrets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListProperties/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListProperties/main.go index dcbefd4b6cb1..361d84873b92 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListProperties/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListProperties/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListRollupPropertySourceLinks/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListRollupPropertySourceLinks/main.go index a32f962cd838..f0f3d20914fb 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListRollupPropertySourceLinks/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListRollupPropertySourceLinks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListSKAdNetworkConversionValueSchemas/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListSKAdNetworkConversionValueSchemas/main.go index 3c104396f3e1..953f7100b157 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListSKAdNetworkConversionValueSchemas/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListSKAdNetworkConversionValueSchemas/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListSearchAds360Links/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListSearchAds360Links/main.go index 7a7a822273d0..88d4ee0ca272 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListSearchAds360Links/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListSearchAds360Links/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListSubpropertyEventFilters/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListSubpropertyEventFilters/main.go index f675952c7fb2..540ef60d59f3 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListSubpropertyEventFilters/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ListSubpropertyEventFilters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ProvisionAccountTicket/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ProvisionAccountTicket/main.go index 905804bb4e0d..b2a39f901b6d 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ProvisionAccountTicket/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ProvisionAccountTicket/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ProvisionSubproperty/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ProvisionSubproperty/main.go index 29477117d7ea..bd8d8e434c7d 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ProvisionSubproperty/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ProvisionSubproperty/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ReorderEventEditRules/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ReorderEventEditRules/main.go index ff55b557c7cd..2dadacf7d3cf 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ReorderEventEditRules/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/ReorderEventEditRules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/RunAccessReport/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/RunAccessReport/main.go index b5fcdc783af9..0d52891947c2 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/RunAccessReport/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/RunAccessReport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/SearchChangeHistoryEvents/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/SearchChangeHistoryEvents/main.go index c60e03b17099..975bc68f6795 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/SearchChangeHistoryEvents/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/SearchChangeHistoryEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/SetAutomatedGa4ConfigurationOptOut/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/SetAutomatedGa4ConfigurationOptOut/main.go index 0a7434b0c0e0..8cfc7033776d 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/SetAutomatedGa4ConfigurationOptOut/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/SetAutomatedGa4ConfigurationOptOut/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateAccessBinding/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateAccessBinding/main.go index b07e84864c51..75c2874566f0 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateAccessBinding/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateAccessBinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateAccount/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateAccount/main.go index 901a6a1146ed..ac4340ea1984 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateAccount/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateAccount/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateAttributionSettings/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateAttributionSettings/main.go index 0071a492e401..682ee594edc2 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateAttributionSettings/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateAttributionSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateAudience/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateAudience/main.go index 52d10429481e..e8c607900a36 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateAudience/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateAudience/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateBigQueryLink/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateBigQueryLink/main.go index 469745582e0e..e1a2b6074cf7 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateBigQueryLink/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateBigQueryLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateCalculatedMetric/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateCalculatedMetric/main.go index d36efcb8bed4..8a38d6317f6f 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateCalculatedMetric/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateCalculatedMetric/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateChannelGroup/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateChannelGroup/main.go index 43b03f9ea67f..a6b680608ab6 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateChannelGroup/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateChannelGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateConversionEvent/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateConversionEvent/main.go index 36cdce9bfdf2..ea867212e0ed 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateConversionEvent/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateConversionEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateCustomDimension/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateCustomDimension/main.go index 097558339ad2..b06d3ef83e96 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateCustomDimension/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateCustomDimension/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateCustomMetric/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateCustomMetric/main.go index 2819080089bb..d263f57e90d2 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateCustomMetric/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateCustomMetric/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateDataRedactionSettings/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateDataRedactionSettings/main.go index 58d16dbf014d..30e36f4f2e6a 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateDataRedactionSettings/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateDataRedactionSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateDataRetentionSettings/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateDataRetentionSettings/main.go index 3a5ce4c79170..bc3ff87d4be7 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateDataRetentionSettings/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateDataRetentionSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateDataStream/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateDataStream/main.go index 4c8eef296143..403ea832f09f 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateDataStream/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateDataStream/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateDisplayVideo360AdvertiserLink/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateDisplayVideo360AdvertiserLink/main.go index fbebf2b9c6af..1103169732af 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateDisplayVideo360AdvertiserLink/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateDisplayVideo360AdvertiserLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateEnhancedMeasurementSettings/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateEnhancedMeasurementSettings/main.go index d5839ede9c0b..7bcc0e00196a 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateEnhancedMeasurementSettings/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateEnhancedMeasurementSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateEventCreateRule/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateEventCreateRule/main.go index eb6a3cca6827..1390c21e8ea0 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateEventCreateRule/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateEventCreateRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateEventEditRule/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateEventEditRule/main.go index e4630136cf84..133f5fcb6184 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateEventEditRule/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateEventEditRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateExpandedDataSet/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateExpandedDataSet/main.go index 3344168d7870..bfdc7db806e4 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateExpandedDataSet/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateExpandedDataSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateGoogleAdsLink/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateGoogleAdsLink/main.go index 4d409bbd5a52..0a1473dfcaf9 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateGoogleAdsLink/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateGoogleAdsLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateGoogleSignalsSettings/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateGoogleSignalsSettings/main.go index 43243bef19ab..a5e07c8d69c8 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateGoogleSignalsSettings/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateGoogleSignalsSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateKeyEvent/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateKeyEvent/main.go index 8e52fb67a5b6..8d6742a77766 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateKeyEvent/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateKeyEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateMeasurementProtocolSecret/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateMeasurementProtocolSecret/main.go index d4c5bdb2f551..a9774d9d852d 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateMeasurementProtocolSecret/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateMeasurementProtocolSecret/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateProperty/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateProperty/main.go index a1e834be462a..b91c245b0b7e 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateProperty/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateProperty/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateSKAdNetworkConversionValueSchema/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateSKAdNetworkConversionValueSchema/main.go index 5ebf92e4e27a..67e73cbcd2d2 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateSKAdNetworkConversionValueSchema/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateSKAdNetworkConversionValueSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateSearchAds360Link/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateSearchAds360Link/main.go index b5672deb0702..f61e98d5267a 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateSearchAds360Link/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateSearchAds360Link/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateSubpropertyEventFilter/main.go b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateSubpropertyEventFilter/main.go index 1ad099c87edf..00e57e019246 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateSubpropertyEventFilter/main.go +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/AnalyticsAdminClient/UpdateSubpropertyEventFilter/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/analytics/admin/apiv1alpha/snippet_metadata.google.analytics.admin.v1alpha.json b/internal/generated/snippets/analytics/admin/apiv1alpha/snippet_metadata.google.analytics.admin.v1alpha.json index f39b9fa01964..700060bca02d 100644 --- a/internal/generated/snippets/analytics/admin/apiv1alpha/snippet_metadata.google.analytics.admin.v1alpha.json +++ b/internal/generated/snippets/analytics/admin/apiv1alpha/snippet_metadata.google.analytics.admin.v1alpha.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/analytics/admin/apiv1alpha", - "version": "0.25.2", + "version": "0.25.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/apigateway/apiv1/Client/CreateApi/main.go b/internal/generated/snippets/apigateway/apiv1/Client/CreateApi/main.go index b832e8cd4b80..d463b99b47bb 100644 --- a/internal/generated/snippets/apigateway/apiv1/Client/CreateApi/main.go +++ b/internal/generated/snippets/apigateway/apiv1/Client/CreateApi/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigateway/apiv1/Client/CreateApiConfig/main.go b/internal/generated/snippets/apigateway/apiv1/Client/CreateApiConfig/main.go index eca0cc372b86..e07aa8e82f11 100644 --- a/internal/generated/snippets/apigateway/apiv1/Client/CreateApiConfig/main.go +++ b/internal/generated/snippets/apigateway/apiv1/Client/CreateApiConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigateway/apiv1/Client/CreateGateway/main.go b/internal/generated/snippets/apigateway/apiv1/Client/CreateGateway/main.go index 013b9067cbc6..2518794aa3ce 100644 --- a/internal/generated/snippets/apigateway/apiv1/Client/CreateGateway/main.go +++ b/internal/generated/snippets/apigateway/apiv1/Client/CreateGateway/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigateway/apiv1/Client/DeleteApi/main.go b/internal/generated/snippets/apigateway/apiv1/Client/DeleteApi/main.go index 86395ca3e08e..b9ea75782899 100644 --- a/internal/generated/snippets/apigateway/apiv1/Client/DeleteApi/main.go +++ b/internal/generated/snippets/apigateway/apiv1/Client/DeleteApi/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigateway/apiv1/Client/DeleteApiConfig/main.go b/internal/generated/snippets/apigateway/apiv1/Client/DeleteApiConfig/main.go index 2af444e1a907..56b74dcb3104 100644 --- a/internal/generated/snippets/apigateway/apiv1/Client/DeleteApiConfig/main.go +++ b/internal/generated/snippets/apigateway/apiv1/Client/DeleteApiConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigateway/apiv1/Client/DeleteGateway/main.go b/internal/generated/snippets/apigateway/apiv1/Client/DeleteGateway/main.go index 2e96437405f0..d892ff76f4e0 100644 --- a/internal/generated/snippets/apigateway/apiv1/Client/DeleteGateway/main.go +++ b/internal/generated/snippets/apigateway/apiv1/Client/DeleteGateway/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigateway/apiv1/Client/GetApi/main.go b/internal/generated/snippets/apigateway/apiv1/Client/GetApi/main.go index fafd6a632937..8ad1d206cdc7 100644 --- a/internal/generated/snippets/apigateway/apiv1/Client/GetApi/main.go +++ b/internal/generated/snippets/apigateway/apiv1/Client/GetApi/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigateway/apiv1/Client/GetApiConfig/main.go b/internal/generated/snippets/apigateway/apiv1/Client/GetApiConfig/main.go index 3d074ffb1451..44d3ddbf9c5f 100644 --- a/internal/generated/snippets/apigateway/apiv1/Client/GetApiConfig/main.go +++ b/internal/generated/snippets/apigateway/apiv1/Client/GetApiConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigateway/apiv1/Client/GetGateway/main.go b/internal/generated/snippets/apigateway/apiv1/Client/GetGateway/main.go index 002897dea509..c36eb031c224 100644 --- a/internal/generated/snippets/apigateway/apiv1/Client/GetGateway/main.go +++ b/internal/generated/snippets/apigateway/apiv1/Client/GetGateway/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigateway/apiv1/Client/ListApiConfigs/main.go b/internal/generated/snippets/apigateway/apiv1/Client/ListApiConfigs/main.go index eaed5f3f0bde..a567d4e3d438 100644 --- a/internal/generated/snippets/apigateway/apiv1/Client/ListApiConfigs/main.go +++ b/internal/generated/snippets/apigateway/apiv1/Client/ListApiConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigateway/apiv1/Client/ListApis/main.go b/internal/generated/snippets/apigateway/apiv1/Client/ListApis/main.go index 371f7bde097b..b8ceccced52c 100644 --- a/internal/generated/snippets/apigateway/apiv1/Client/ListApis/main.go +++ b/internal/generated/snippets/apigateway/apiv1/Client/ListApis/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigateway/apiv1/Client/ListGateways/main.go b/internal/generated/snippets/apigateway/apiv1/Client/ListGateways/main.go index a1cd557c4fb3..b381a187ee54 100644 --- a/internal/generated/snippets/apigateway/apiv1/Client/ListGateways/main.go +++ b/internal/generated/snippets/apigateway/apiv1/Client/ListGateways/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigateway/apiv1/Client/UpdateApi/main.go b/internal/generated/snippets/apigateway/apiv1/Client/UpdateApi/main.go index 3d16827a85b7..fe0ef4962f5e 100644 --- a/internal/generated/snippets/apigateway/apiv1/Client/UpdateApi/main.go +++ b/internal/generated/snippets/apigateway/apiv1/Client/UpdateApi/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigateway/apiv1/Client/UpdateApiConfig/main.go b/internal/generated/snippets/apigateway/apiv1/Client/UpdateApiConfig/main.go index 9627106a464f..dbdf2605918b 100644 --- a/internal/generated/snippets/apigateway/apiv1/Client/UpdateApiConfig/main.go +++ b/internal/generated/snippets/apigateway/apiv1/Client/UpdateApiConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigateway/apiv1/Client/UpdateGateway/main.go b/internal/generated/snippets/apigateway/apiv1/Client/UpdateGateway/main.go index 05a53cccbe04..42b171c6fe96 100644 --- a/internal/generated/snippets/apigateway/apiv1/Client/UpdateGateway/main.go +++ b/internal/generated/snippets/apigateway/apiv1/Client/UpdateGateway/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeconnect/apiv1/ConnectionClient/ListConnections/main.go b/internal/generated/snippets/apigeeconnect/apiv1/ConnectionClient/ListConnections/main.go index 90eb1d21fb30..a1714f461b29 100644 --- a/internal/generated/snippets/apigeeconnect/apiv1/ConnectionClient/ListConnections/main.go +++ b/internal/generated/snippets/apigeeconnect/apiv1/ConnectionClient/ListConnections/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeconnect/apiv1/TetherClient/Egress/main.go b/internal/generated/snippets/apigeeconnect/apiv1/TetherClient/Egress/main.go index f1d63c8e4535..029453a61890 100644 --- a/internal/generated/snippets/apigeeconnect/apiv1/TetherClient/Egress/main.go +++ b/internal/generated/snippets/apigeeconnect/apiv1/TetherClient/Egress/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/CancelOperation/main.go b/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/CancelOperation/main.go index 1e8b289a5337..0502f40c26a3 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/CancelOperation/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/CreateInstance/main.go b/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/CreateInstance/main.go index dbdadc57aa2d..9bea9705aa85 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/CreateInstance/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/CreateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/DeleteInstance/main.go b/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/DeleteInstance/main.go index ffaafdcc76cc..58b1ec20d460 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/DeleteInstance/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/DeleteInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/DeleteOperation/main.go b/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/DeleteOperation/main.go index eaf509a217cd..87e44fd6f53c 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/DeleteOperation/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/GetIamPolicy/main.go b/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/GetIamPolicy/main.go index 4a3bd8e736ac..2eef968d23a8 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/GetInstance/main.go b/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/GetInstance/main.go index 4ba1ca8c2069..653049528a89 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/GetInstance/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/GetInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/GetLocation/main.go b/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/GetLocation/main.go index 3cad4bd67697..20590e7feb23 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/GetLocation/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/GetOperation/main.go b/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/GetOperation/main.go index 204618f41070..23f534a703ca 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/GetOperation/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/ListLocations/main.go b/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/ListLocations/main.go index 88b9eac7c7cb..08f52d95f833 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/ListLocations/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/ListOperations/main.go b/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/ListOperations/main.go index 52c773f64a37..3f230afc3bd2 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/ListOperations/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/SetIamPolicy/main.go b/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/SetIamPolicy/main.go index 820a2152858e..4e2a720fe55d 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/TestIamPermissions/main.go b/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/TestIamPermissions/main.go index 90cfbb6b73a6..829e6b6e6026 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/ProvisioningClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/CancelOperation/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/CancelOperation/main.go index 4f18e2127e46..d23c21e3b549 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/CancelOperation/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/CreateApi/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/CreateApi/main.go index 4ffdb1f0e17e..b87c49026634 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/CreateApi/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/CreateApi/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/CreateApiDeployment/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/CreateApiDeployment/main.go index 59ff5b0a44c2..cc0921118ed2 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/CreateApiDeployment/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/CreateApiDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/CreateApiSpec/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/CreateApiSpec/main.go index aa39cb09a4ee..fca40fa38c19 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/CreateApiSpec/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/CreateApiSpec/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/CreateApiVersion/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/CreateApiVersion/main.go index f083fd253454..b47818d8e6cb 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/CreateApiVersion/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/CreateApiVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/CreateArtifact/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/CreateArtifact/main.go index 433df5b02c47..43b0a27e75ed 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/CreateArtifact/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/CreateArtifact/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteApi/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteApi/main.go index 05c9f0a16084..8515070779d3 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteApi/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteApi/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteApiDeployment/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteApiDeployment/main.go index af848390eae1..e690f0fb03ca 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteApiDeployment/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteApiDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteApiDeploymentRevision/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteApiDeploymentRevision/main.go index 4744b9e97427..b5112275ae41 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteApiDeploymentRevision/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteApiDeploymentRevision/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteApiSpec/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteApiSpec/main.go index 7f87a4637893..a7f4fe292d1d 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteApiSpec/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteApiSpec/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteApiSpecRevision/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteApiSpecRevision/main.go index bde13b30bb46..58466a485bf6 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteApiSpecRevision/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteApiSpecRevision/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteApiVersion/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteApiVersion/main.go index f256c697df52..8f0d5a900a1e 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteApiVersion/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteApiVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteArtifact/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteArtifact/main.go index 483edc12fc18..f2953e3e3de7 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteArtifact/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteArtifact/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteOperation/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteOperation/main.go index 44c46df715f3..4760bb1095aa 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteOperation/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetApi/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetApi/main.go index e5608ade3a44..cae49035bc06 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetApi/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetApi/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetApiDeployment/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetApiDeployment/main.go index bf9d91213f37..5ef6a07d2c68 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetApiDeployment/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetApiDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetApiSpec/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetApiSpec/main.go index 8999589a2cef..cb27d1b8033a 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetApiSpec/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetApiSpec/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetApiSpecContents/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetApiSpecContents/main.go index 59b164aa2401..db7bcdab458b 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetApiSpecContents/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetApiSpecContents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetApiVersion/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetApiVersion/main.go index 7da363af771a..fd764ab4e64d 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetApiVersion/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetApiVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetArtifact/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetArtifact/main.go index a689f83a2b6e..989be2e840c1 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetArtifact/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetArtifact/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetArtifactContents/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetArtifactContents/main.go index 8b5ae0f20901..debd7f6a6a44 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetArtifactContents/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetArtifactContents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetIamPolicy/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetIamPolicy/main.go index ca2124f73010..5659fc6c0328 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetLocation/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetLocation/main.go index 57689b0af1bd..aac08bd408c0 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetLocation/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetOperation/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetOperation/main.go index f5eee39404c0..6895d360bb9e 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetOperation/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListApiDeploymentRevisions/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListApiDeploymentRevisions/main.go index 97df22302a86..bf1993478c1b 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListApiDeploymentRevisions/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListApiDeploymentRevisions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListApiDeployments/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListApiDeployments/main.go index d2163e48ec91..1042f03896f5 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListApiDeployments/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListApiDeployments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListApiSpecRevisions/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListApiSpecRevisions/main.go index 097672b998dd..43368402616f 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListApiSpecRevisions/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListApiSpecRevisions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListApiSpecs/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListApiSpecs/main.go index 5806a2ea1483..58345dc7dd6d 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListApiSpecs/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListApiSpecs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListApiVersions/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListApiVersions/main.go index 714939912aed..e17ddc7e2632 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListApiVersions/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListApiVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListApis/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListApis/main.go index 604d4dd14d0d..4017b796b96e 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListApis/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListApis/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListArtifacts/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListArtifacts/main.go index 594e09a4c307..a074d07508bb 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListArtifacts/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListArtifacts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListLocations/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListLocations/main.go index 3e87a17635a2..83b10489fe0a 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListLocations/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListOperations/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListOperations/main.go index b5b286d7d2dd..2ec0a714b8df 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListOperations/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ReplaceArtifact/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ReplaceArtifact/main.go index f910e64c5666..7ce4b5cf8ad9 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ReplaceArtifact/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/ReplaceArtifact/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/RollbackApiDeployment/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/RollbackApiDeployment/main.go index 877a50a1db88..09a89bf3f324 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/RollbackApiDeployment/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/RollbackApiDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/RollbackApiSpec/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/RollbackApiSpec/main.go index b9577eaa4a09..7714455bee1d 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/RollbackApiSpec/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/RollbackApiSpec/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/SetIamPolicy/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/SetIamPolicy/main.go index d2dcc0bede80..58adb2ced57e 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/TagApiDeploymentRevision/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/TagApiDeploymentRevision/main.go index 7b1ffb68b50c..0a507e94b420 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/TagApiDeploymentRevision/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/TagApiDeploymentRevision/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/TagApiSpecRevision/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/TagApiSpecRevision/main.go index 19e5c67ee572..a260d24437d7 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/TagApiSpecRevision/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/TagApiSpecRevision/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/TestIamPermissions/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/TestIamPermissions/main.go index 87b88dc82cc5..f6c55796a27d 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/UpdateApi/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/UpdateApi/main.go index acd513309fa8..01d8ae13f5cc 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/UpdateApi/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/UpdateApi/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/UpdateApiDeployment/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/UpdateApiDeployment/main.go index 2589d47d5df8..8f1a8a15db83 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/UpdateApiDeployment/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/UpdateApiDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/UpdateApiSpec/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/UpdateApiSpec/main.go index 9fbccbb942a4..e876cad386c7 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/UpdateApiSpec/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/UpdateApiSpec/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/UpdateApiVersion/main.go b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/UpdateApiVersion/main.go index 0c6cb1181811..f576d4d7412a 100644 --- a/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/UpdateApiVersion/main.go +++ b/internal/generated/snippets/apigeeregistry/apiv1/RegistryClient/UpdateApiVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/CancelOperation/main.go b/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/CancelOperation/main.go index 6c4828b56de0..c664681245d8 100644 --- a/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/CancelOperation/main.go +++ b/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/CreateDependency/main.go b/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/CreateDependency/main.go index b57a2bb015e7..1068d7604362 100644 --- a/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/CreateDependency/main.go +++ b/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/CreateDependency/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/DeleteDependency/main.go b/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/DeleteDependency/main.go index 274ebcf90ee5..e61aa3757f33 100644 --- a/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/DeleteDependency/main.go +++ b/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/DeleteDependency/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/DeleteOperation/main.go b/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/DeleteOperation/main.go index 425e9f69b3eb..2b786616705e 100644 --- a/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/DeleteOperation/main.go +++ b/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/GetDependency/main.go b/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/GetDependency/main.go index 34e0f1667474..b5c3a465e61d 100644 --- a/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/GetDependency/main.go +++ b/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/GetDependency/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/GetLocation/main.go b/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/GetLocation/main.go index 1a8ae15ca734..d6d6734d60a0 100644 --- a/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/GetLocation/main.go +++ b/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/GetOperation/main.go b/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/GetOperation/main.go index 592f68ed1670..a9edce912558 100644 --- a/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/GetOperation/main.go +++ b/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/ListDependencies/main.go b/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/ListDependencies/main.go index eeea06708ca7..bf3c71566737 100644 --- a/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/ListDependencies/main.go +++ b/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/ListDependencies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/ListLocations/main.go b/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/ListLocations/main.go index 6c8023f4fc52..76c29d8a602c 100644 --- a/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/ListLocations/main.go +++ b/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/ListOperations/main.go b/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/ListOperations/main.go index 8bcc7d948639..1766354a1bfb 100644 --- a/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/ListOperations/main.go +++ b/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/UpdateDependency/main.go b/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/UpdateDependency/main.go index 721d41333cd3..4cb84960a71e 100644 --- a/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/UpdateDependency/main.go +++ b/internal/generated/snippets/apihub/apiv1/ApiHubDependenciesClient/UpdateDependency/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/CancelOperation/main.go b/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/CancelOperation/main.go index ac6415f854b0..9bd39463b562 100644 --- a/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/CancelOperation/main.go +++ b/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/DeleteOperation/main.go b/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/DeleteOperation/main.go index 0355e8b7a613..7063e8846767 100644 --- a/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/DeleteOperation/main.go +++ b/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/DisablePlugin/main.go b/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/DisablePlugin/main.go index ef8973ce2fb1..3c064c2b8d02 100644 --- a/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/DisablePlugin/main.go +++ b/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/DisablePlugin/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/EnablePlugin/main.go b/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/EnablePlugin/main.go index edda8907e61d..be54159e64a1 100644 --- a/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/EnablePlugin/main.go +++ b/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/EnablePlugin/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/GetLocation/main.go b/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/GetLocation/main.go index 0eb2a7773ca0..affbb0bf252e 100644 --- a/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/GetLocation/main.go +++ b/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/GetOperation/main.go b/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/GetOperation/main.go index cac9458668f3..6848f9a161a7 100644 --- a/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/GetOperation/main.go +++ b/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/GetPlugin/main.go b/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/GetPlugin/main.go index 512c6af36770..fdee9717bee9 100644 --- a/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/GetPlugin/main.go +++ b/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/GetPlugin/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/ListLocations/main.go b/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/ListLocations/main.go index 2947af421bae..d5f04b76f4d7 100644 --- a/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/ListLocations/main.go +++ b/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/ListOperations/main.go b/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/ListOperations/main.go index 8a492a012b68..54664585d564 100644 --- a/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/ListOperations/main.go +++ b/internal/generated/snippets/apihub/apiv1/ApiHubPluginClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/apihub/apiv1/Client/CancelOperation/main.go index f8a6124a05f2..78d889c7074e 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/CreateApi/main.go b/internal/generated/snippets/apihub/apiv1/Client/CreateApi/main.go index c6b3c4407a6a..585f7d03afd8 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/CreateApi/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/CreateApi/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/CreateAttribute/main.go b/internal/generated/snippets/apihub/apiv1/Client/CreateAttribute/main.go index 5073fef1eb02..b29a168b2483 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/CreateAttribute/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/CreateAttribute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/CreateDeployment/main.go b/internal/generated/snippets/apihub/apiv1/Client/CreateDeployment/main.go index 75789679d297..4574ccb1399a 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/CreateDeployment/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/CreateDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/CreateExternalApi/main.go b/internal/generated/snippets/apihub/apiv1/Client/CreateExternalApi/main.go index 7a008aa3a514..b8074c41dea7 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/CreateExternalApi/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/CreateExternalApi/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/CreateSpec/main.go b/internal/generated/snippets/apihub/apiv1/Client/CreateSpec/main.go index af705acbb369..d97723de910d 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/CreateSpec/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/CreateSpec/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/CreateVersion/main.go b/internal/generated/snippets/apihub/apiv1/Client/CreateVersion/main.go index 373b95549c90..6c2b1a8e2413 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/CreateVersion/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/CreateVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/DeleteApi/main.go b/internal/generated/snippets/apihub/apiv1/Client/DeleteApi/main.go index 1dcfcfa7d5a6..8061952df84d 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/DeleteApi/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/DeleteApi/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/DeleteAttribute/main.go b/internal/generated/snippets/apihub/apiv1/Client/DeleteAttribute/main.go index 99707663bd73..1e9687d74377 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/DeleteAttribute/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/DeleteAttribute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/DeleteDeployment/main.go b/internal/generated/snippets/apihub/apiv1/Client/DeleteDeployment/main.go index 1738bc469da6..733960700451 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/DeleteDeployment/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/DeleteDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/DeleteExternalApi/main.go b/internal/generated/snippets/apihub/apiv1/Client/DeleteExternalApi/main.go index 498932755983..0e9c8ac6615a 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/DeleteExternalApi/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/DeleteExternalApi/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/apihub/apiv1/Client/DeleteOperation/main.go index 7a25622d9f09..bb12307f243b 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/DeleteSpec/main.go b/internal/generated/snippets/apihub/apiv1/Client/DeleteSpec/main.go index ee40b2d1c5c5..4bdafc8461fb 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/DeleteSpec/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/DeleteSpec/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/DeleteVersion/main.go b/internal/generated/snippets/apihub/apiv1/Client/DeleteVersion/main.go index 837039ce2958..7ec320ea3267 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/DeleteVersion/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/DeleteVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/GetApi/main.go b/internal/generated/snippets/apihub/apiv1/Client/GetApi/main.go index a4fc37a6b0c2..4838f66c3b45 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/GetApi/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/GetApi/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/GetApiOperation/main.go b/internal/generated/snippets/apihub/apiv1/Client/GetApiOperation/main.go index 3806dbcb919a..e58646479e52 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/GetApiOperation/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/GetApiOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/GetAttribute/main.go b/internal/generated/snippets/apihub/apiv1/Client/GetAttribute/main.go index c44046ae5cb8..864fb2403eac 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/GetAttribute/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/GetAttribute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/GetDefinition/main.go b/internal/generated/snippets/apihub/apiv1/Client/GetDefinition/main.go index 5bd7d02b4c29..0b8a99fca5d5 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/GetDefinition/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/GetDefinition/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/GetDeployment/main.go b/internal/generated/snippets/apihub/apiv1/Client/GetDeployment/main.go index bf9de7b16361..bae1a589988a 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/GetDeployment/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/GetDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/GetExternalApi/main.go b/internal/generated/snippets/apihub/apiv1/Client/GetExternalApi/main.go index 87e02c3e73fe..324aad1c6c14 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/GetExternalApi/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/GetExternalApi/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/apihub/apiv1/Client/GetLocation/main.go index 0b8d98e07e94..eb60c7153553 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/apihub/apiv1/Client/GetOperation/main.go index 7edb045ba3d0..f09e6dafb53d 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/GetSpec/main.go b/internal/generated/snippets/apihub/apiv1/Client/GetSpec/main.go index 0499866cbe4b..46d5ad139df4 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/GetSpec/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/GetSpec/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/GetSpecContents/main.go b/internal/generated/snippets/apihub/apiv1/Client/GetSpecContents/main.go index 197441e1a431..ca7db285b7a8 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/GetSpecContents/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/GetSpecContents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/GetVersion/main.go b/internal/generated/snippets/apihub/apiv1/Client/GetVersion/main.go index eed4fcc3a820..4159c6788ba2 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/GetVersion/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/GetVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/ListApiOperations/main.go b/internal/generated/snippets/apihub/apiv1/Client/ListApiOperations/main.go index 6b2c59f398c2..389efe575e62 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/ListApiOperations/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/ListApiOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/ListApis/main.go b/internal/generated/snippets/apihub/apiv1/Client/ListApis/main.go index a49a6085258b..2bd4d0f18cac 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/ListApis/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/ListApis/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/ListAttributes/main.go b/internal/generated/snippets/apihub/apiv1/Client/ListAttributes/main.go index c64da5a8b471..c25afd1a4b51 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/ListAttributes/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/ListAttributes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/ListDeployments/main.go b/internal/generated/snippets/apihub/apiv1/Client/ListDeployments/main.go index eb9878f31245..3df635ccf590 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/ListDeployments/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/ListDeployments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/ListExternalApis/main.go b/internal/generated/snippets/apihub/apiv1/Client/ListExternalApis/main.go index c30becc2d79d..403373a01036 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/ListExternalApis/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/ListExternalApis/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/apihub/apiv1/Client/ListLocations/main.go index 021fc8f6337c..4d4cfcd1311e 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/apihub/apiv1/Client/ListOperations/main.go index 6d96f0628e6e..aff57ff2052d 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/ListSpecs/main.go b/internal/generated/snippets/apihub/apiv1/Client/ListSpecs/main.go index f5806d8bb478..539514ca7b9a 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/ListSpecs/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/ListSpecs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/ListVersions/main.go b/internal/generated/snippets/apihub/apiv1/Client/ListVersions/main.go index 17648c6951e2..866a00f5a6b6 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/ListVersions/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/ListVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/SearchResources/main.go b/internal/generated/snippets/apihub/apiv1/Client/SearchResources/main.go index 011e78104cec..7bde95c43756 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/SearchResources/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/SearchResources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/UpdateApi/main.go b/internal/generated/snippets/apihub/apiv1/Client/UpdateApi/main.go index cb7b268734f3..86028f8aacc0 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/UpdateApi/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/UpdateApi/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/UpdateAttribute/main.go b/internal/generated/snippets/apihub/apiv1/Client/UpdateAttribute/main.go index 0f55a88de0a1..fe7c5c80b5e8 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/UpdateAttribute/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/UpdateAttribute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/UpdateDeployment/main.go b/internal/generated/snippets/apihub/apiv1/Client/UpdateDeployment/main.go index e5669eb7b1dd..c38748a97cc0 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/UpdateDeployment/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/UpdateDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/UpdateExternalApi/main.go b/internal/generated/snippets/apihub/apiv1/Client/UpdateExternalApi/main.go index 4bdde310d077..44acdd91e750 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/UpdateExternalApi/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/UpdateExternalApi/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/UpdateSpec/main.go b/internal/generated/snippets/apihub/apiv1/Client/UpdateSpec/main.go index 704dd4e9b8da..eebd0a659119 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/UpdateSpec/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/UpdateSpec/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/Client/UpdateVersion/main.go b/internal/generated/snippets/apihub/apiv1/Client/UpdateVersion/main.go index 2f2296fa4171..2d499e887588 100644 --- a/internal/generated/snippets/apihub/apiv1/Client/UpdateVersion/main.go +++ b/internal/generated/snippets/apihub/apiv1/Client/UpdateVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/CancelOperation/main.go b/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/CancelOperation/main.go index d2d0e6b0728a..89061d612644 100644 --- a/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/CancelOperation/main.go +++ b/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/CreateHostProjectRegistration/main.go b/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/CreateHostProjectRegistration/main.go index e316b967454e..86ce0dc6149b 100644 --- a/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/CreateHostProjectRegistration/main.go +++ b/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/CreateHostProjectRegistration/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/DeleteOperation/main.go b/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/DeleteOperation/main.go index ac9316507d58..49150c01b151 100644 --- a/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/DeleteOperation/main.go +++ b/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/GetHostProjectRegistration/main.go b/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/GetHostProjectRegistration/main.go index 36da85b3905c..f6cb0ddcd85f 100644 --- a/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/GetHostProjectRegistration/main.go +++ b/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/GetHostProjectRegistration/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/GetLocation/main.go b/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/GetLocation/main.go index b9564e4a3663..3fd57ea54cf4 100644 --- a/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/GetLocation/main.go +++ b/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/GetOperation/main.go b/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/GetOperation/main.go index 4e452cfa763e..52eec0417492 100644 --- a/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/GetOperation/main.go +++ b/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/ListHostProjectRegistrations/main.go b/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/ListHostProjectRegistrations/main.go index fc420a09d231..90803bed034e 100644 --- a/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/ListHostProjectRegistrations/main.go +++ b/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/ListHostProjectRegistrations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/ListLocations/main.go b/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/ListLocations/main.go index 2ae5025803e6..bca98949e1a8 100644 --- a/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/ListLocations/main.go +++ b/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/ListOperations/main.go b/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/ListOperations/main.go index b6e2247bec87..d4d227b1640a 100644 --- a/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/ListOperations/main.go +++ b/internal/generated/snippets/apihub/apiv1/HostProjectRegistrationClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/LintingClient/CancelOperation/main.go b/internal/generated/snippets/apihub/apiv1/LintingClient/CancelOperation/main.go index 5aa05711267b..3f37cde6f632 100644 --- a/internal/generated/snippets/apihub/apiv1/LintingClient/CancelOperation/main.go +++ b/internal/generated/snippets/apihub/apiv1/LintingClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/LintingClient/DeleteOperation/main.go b/internal/generated/snippets/apihub/apiv1/LintingClient/DeleteOperation/main.go index a2c9084bf63e..4f7025277f8e 100644 --- a/internal/generated/snippets/apihub/apiv1/LintingClient/DeleteOperation/main.go +++ b/internal/generated/snippets/apihub/apiv1/LintingClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/LintingClient/GetLocation/main.go b/internal/generated/snippets/apihub/apiv1/LintingClient/GetLocation/main.go index 5477368ce2ac..f48537b81d76 100644 --- a/internal/generated/snippets/apihub/apiv1/LintingClient/GetLocation/main.go +++ b/internal/generated/snippets/apihub/apiv1/LintingClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/LintingClient/GetOperation/main.go b/internal/generated/snippets/apihub/apiv1/LintingClient/GetOperation/main.go index c58644aeecd4..ab1ac904e2cc 100644 --- a/internal/generated/snippets/apihub/apiv1/LintingClient/GetOperation/main.go +++ b/internal/generated/snippets/apihub/apiv1/LintingClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/LintingClient/GetStyleGuide/main.go b/internal/generated/snippets/apihub/apiv1/LintingClient/GetStyleGuide/main.go index 3debc6f4c346..0f2dd4ff98e2 100644 --- a/internal/generated/snippets/apihub/apiv1/LintingClient/GetStyleGuide/main.go +++ b/internal/generated/snippets/apihub/apiv1/LintingClient/GetStyleGuide/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/LintingClient/GetStyleGuideContents/main.go b/internal/generated/snippets/apihub/apiv1/LintingClient/GetStyleGuideContents/main.go index 91cbcfc1d01b..a137305cfbb9 100644 --- a/internal/generated/snippets/apihub/apiv1/LintingClient/GetStyleGuideContents/main.go +++ b/internal/generated/snippets/apihub/apiv1/LintingClient/GetStyleGuideContents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/LintingClient/LintSpec/main.go b/internal/generated/snippets/apihub/apiv1/LintingClient/LintSpec/main.go index 25c90f2d52e4..f6e2d80d48e4 100644 --- a/internal/generated/snippets/apihub/apiv1/LintingClient/LintSpec/main.go +++ b/internal/generated/snippets/apihub/apiv1/LintingClient/LintSpec/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/LintingClient/ListLocations/main.go b/internal/generated/snippets/apihub/apiv1/LintingClient/ListLocations/main.go index 3df2d920094e..f54b2c89f47b 100644 --- a/internal/generated/snippets/apihub/apiv1/LintingClient/ListLocations/main.go +++ b/internal/generated/snippets/apihub/apiv1/LintingClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/LintingClient/ListOperations/main.go b/internal/generated/snippets/apihub/apiv1/LintingClient/ListOperations/main.go index f5356e6ca7db..0d30fb69807b 100644 --- a/internal/generated/snippets/apihub/apiv1/LintingClient/ListOperations/main.go +++ b/internal/generated/snippets/apihub/apiv1/LintingClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/LintingClient/UpdateStyleGuide/main.go b/internal/generated/snippets/apihub/apiv1/LintingClient/UpdateStyleGuide/main.go index 2b3cd57d8c52..c84063377554 100644 --- a/internal/generated/snippets/apihub/apiv1/LintingClient/UpdateStyleGuide/main.go +++ b/internal/generated/snippets/apihub/apiv1/LintingClient/UpdateStyleGuide/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ProvisioningClient/CancelOperation/main.go b/internal/generated/snippets/apihub/apiv1/ProvisioningClient/CancelOperation/main.go index bc764079c8c1..d1314c2723de 100644 --- a/internal/generated/snippets/apihub/apiv1/ProvisioningClient/CancelOperation/main.go +++ b/internal/generated/snippets/apihub/apiv1/ProvisioningClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ProvisioningClient/CreateApiHubInstance/main.go b/internal/generated/snippets/apihub/apiv1/ProvisioningClient/CreateApiHubInstance/main.go index d91cedf11bae..7b1451ba260c 100644 --- a/internal/generated/snippets/apihub/apiv1/ProvisioningClient/CreateApiHubInstance/main.go +++ b/internal/generated/snippets/apihub/apiv1/ProvisioningClient/CreateApiHubInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ProvisioningClient/DeleteOperation/main.go b/internal/generated/snippets/apihub/apiv1/ProvisioningClient/DeleteOperation/main.go index 89b635dc9f1a..aae317a70707 100644 --- a/internal/generated/snippets/apihub/apiv1/ProvisioningClient/DeleteOperation/main.go +++ b/internal/generated/snippets/apihub/apiv1/ProvisioningClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ProvisioningClient/GetApiHubInstance/main.go b/internal/generated/snippets/apihub/apiv1/ProvisioningClient/GetApiHubInstance/main.go index 19b79e9d7ecd..ef6025db76f1 100644 --- a/internal/generated/snippets/apihub/apiv1/ProvisioningClient/GetApiHubInstance/main.go +++ b/internal/generated/snippets/apihub/apiv1/ProvisioningClient/GetApiHubInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ProvisioningClient/GetLocation/main.go b/internal/generated/snippets/apihub/apiv1/ProvisioningClient/GetLocation/main.go index 4234853dc298..63cab6a7b61c 100644 --- a/internal/generated/snippets/apihub/apiv1/ProvisioningClient/GetLocation/main.go +++ b/internal/generated/snippets/apihub/apiv1/ProvisioningClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ProvisioningClient/GetOperation/main.go b/internal/generated/snippets/apihub/apiv1/ProvisioningClient/GetOperation/main.go index 2cc145d8feee..18e9da397064 100644 --- a/internal/generated/snippets/apihub/apiv1/ProvisioningClient/GetOperation/main.go +++ b/internal/generated/snippets/apihub/apiv1/ProvisioningClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ProvisioningClient/ListLocations/main.go b/internal/generated/snippets/apihub/apiv1/ProvisioningClient/ListLocations/main.go index 936d40d36006..7ada23dfb2e3 100644 --- a/internal/generated/snippets/apihub/apiv1/ProvisioningClient/ListLocations/main.go +++ b/internal/generated/snippets/apihub/apiv1/ProvisioningClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ProvisioningClient/ListOperations/main.go b/internal/generated/snippets/apihub/apiv1/ProvisioningClient/ListOperations/main.go index 14e97bd2ff3f..7d8938e93d09 100644 --- a/internal/generated/snippets/apihub/apiv1/ProvisioningClient/ListOperations/main.go +++ b/internal/generated/snippets/apihub/apiv1/ProvisioningClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/ProvisioningClient/LookupApiHubInstance/main.go b/internal/generated/snippets/apihub/apiv1/ProvisioningClient/LookupApiHubInstance/main.go index b057e06700e6..1fcca11d95e9 100644 --- a/internal/generated/snippets/apihub/apiv1/ProvisioningClient/LookupApiHubInstance/main.go +++ b/internal/generated/snippets/apihub/apiv1/ProvisioningClient/LookupApiHubInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/CancelOperation/main.go b/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/CancelOperation/main.go index f3e4018d0b01..167f44d001a1 100644 --- a/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/CancelOperation/main.go +++ b/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/CreateRuntimeProjectAttachment/main.go b/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/CreateRuntimeProjectAttachment/main.go index 7bd7a50a3522..19362edf3276 100644 --- a/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/CreateRuntimeProjectAttachment/main.go +++ b/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/CreateRuntimeProjectAttachment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/DeleteOperation/main.go b/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/DeleteOperation/main.go index 80f4d916e4e0..c958abcaab36 100644 --- a/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/DeleteOperation/main.go +++ b/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/DeleteRuntimeProjectAttachment/main.go b/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/DeleteRuntimeProjectAttachment/main.go index 94598f49711b..0ebe3d70b713 100644 --- a/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/DeleteRuntimeProjectAttachment/main.go +++ b/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/DeleteRuntimeProjectAttachment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/GetLocation/main.go b/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/GetLocation/main.go index bf87e5c955e6..cd69c8f0b0f2 100644 --- a/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/GetLocation/main.go +++ b/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/GetOperation/main.go b/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/GetOperation/main.go index 5c9dafdc6823..5ab152aa0d4f 100644 --- a/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/GetOperation/main.go +++ b/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/GetRuntimeProjectAttachment/main.go b/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/GetRuntimeProjectAttachment/main.go index 5d6a7f5e611f..ce995c763635 100644 --- a/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/GetRuntimeProjectAttachment/main.go +++ b/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/GetRuntimeProjectAttachment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/ListLocations/main.go b/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/ListLocations/main.go index fcaf704a81e5..e9854c6a1352 100644 --- a/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/ListLocations/main.go +++ b/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/ListOperations/main.go b/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/ListOperations/main.go index 4bc83b4359f5..4dcefff0a6a5 100644 --- a/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/ListOperations/main.go +++ b/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/ListRuntimeProjectAttachments/main.go b/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/ListRuntimeProjectAttachments/main.go index f7beafce9fe2..25fc657a5af4 100644 --- a/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/ListRuntimeProjectAttachments/main.go +++ b/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/ListRuntimeProjectAttachments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/LookupRuntimeProjectAttachment/main.go b/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/LookupRuntimeProjectAttachment/main.go index 752cd4f45510..ea1ab7e46570 100644 --- a/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/LookupRuntimeProjectAttachment/main.go +++ b/internal/generated/snippets/apihub/apiv1/RuntimeProjectAttachmentClient/LookupRuntimeProjectAttachment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apihub/apiv1/snippet_metadata.google.cloud.apihub.v1.json b/internal/generated/snippets/apihub/apiv1/snippet_metadata.google.cloud.apihub.v1.json index d88015e760e9..027b018a6724 100644 --- a/internal/generated/snippets/apihub/apiv1/snippet_metadata.google.cloud.apihub.v1.json +++ b/internal/generated/snippets/apihub/apiv1/snippet_metadata.google.cloud.apihub.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/apihub/apiv1", - "version": "0.1.2", + "version": "0.1.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/apikeys/apiv2/Client/CreateKey/main.go b/internal/generated/snippets/apikeys/apiv2/Client/CreateKey/main.go index ede22f646991..30f2648a615a 100644 --- a/internal/generated/snippets/apikeys/apiv2/Client/CreateKey/main.go +++ b/internal/generated/snippets/apikeys/apiv2/Client/CreateKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apikeys/apiv2/Client/DeleteKey/main.go b/internal/generated/snippets/apikeys/apiv2/Client/DeleteKey/main.go index 1353863d2668..385cfe60419d 100644 --- a/internal/generated/snippets/apikeys/apiv2/Client/DeleteKey/main.go +++ b/internal/generated/snippets/apikeys/apiv2/Client/DeleteKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apikeys/apiv2/Client/GetKey/main.go b/internal/generated/snippets/apikeys/apiv2/Client/GetKey/main.go index 73331b55a2dc..67a457ef6812 100644 --- a/internal/generated/snippets/apikeys/apiv2/Client/GetKey/main.go +++ b/internal/generated/snippets/apikeys/apiv2/Client/GetKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apikeys/apiv2/Client/GetKeyString/main.go b/internal/generated/snippets/apikeys/apiv2/Client/GetKeyString/main.go index 7023ed923755..912033cf1743 100644 --- a/internal/generated/snippets/apikeys/apiv2/Client/GetKeyString/main.go +++ b/internal/generated/snippets/apikeys/apiv2/Client/GetKeyString/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apikeys/apiv2/Client/GetOperation/main.go b/internal/generated/snippets/apikeys/apiv2/Client/GetOperation/main.go index e085a412ad17..beb10bcc77b2 100644 --- a/internal/generated/snippets/apikeys/apiv2/Client/GetOperation/main.go +++ b/internal/generated/snippets/apikeys/apiv2/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apikeys/apiv2/Client/ListKeys/main.go b/internal/generated/snippets/apikeys/apiv2/Client/ListKeys/main.go index 50a79d7a2e5a..1d879cc4b9dc 100644 --- a/internal/generated/snippets/apikeys/apiv2/Client/ListKeys/main.go +++ b/internal/generated/snippets/apikeys/apiv2/Client/ListKeys/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apikeys/apiv2/Client/LookupKey/main.go b/internal/generated/snippets/apikeys/apiv2/Client/LookupKey/main.go index d12041391891..2a343e29d5ac 100644 --- a/internal/generated/snippets/apikeys/apiv2/Client/LookupKey/main.go +++ b/internal/generated/snippets/apikeys/apiv2/Client/LookupKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apikeys/apiv2/Client/UndeleteKey/main.go b/internal/generated/snippets/apikeys/apiv2/Client/UndeleteKey/main.go index ed03a2397df9..d8ef5a64cc37 100644 --- a/internal/generated/snippets/apikeys/apiv2/Client/UndeleteKey/main.go +++ b/internal/generated/snippets/apikeys/apiv2/Client/UndeleteKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apikeys/apiv2/Client/UpdateKey/main.go b/internal/generated/snippets/apikeys/apiv2/Client/UpdateKey/main.go index 41bfabaee2d4..52c1d92b4657 100644 --- a/internal/generated/snippets/apikeys/apiv2/Client/UpdateKey/main.go +++ b/internal/generated/snippets/apikeys/apiv2/Client/UpdateKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/ApplicationsClient/CreateApplication/main.go b/internal/generated/snippets/appengine/apiv1/ApplicationsClient/CreateApplication/main.go index 332937987f37..9e5fcbe0821c 100644 --- a/internal/generated/snippets/appengine/apiv1/ApplicationsClient/CreateApplication/main.go +++ b/internal/generated/snippets/appengine/apiv1/ApplicationsClient/CreateApplication/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/ApplicationsClient/GetApplication/main.go b/internal/generated/snippets/appengine/apiv1/ApplicationsClient/GetApplication/main.go index b2bf96775f5f..2947066a6ff9 100644 --- a/internal/generated/snippets/appengine/apiv1/ApplicationsClient/GetApplication/main.go +++ b/internal/generated/snippets/appengine/apiv1/ApplicationsClient/GetApplication/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/ApplicationsClient/RepairApplication/main.go b/internal/generated/snippets/appengine/apiv1/ApplicationsClient/RepairApplication/main.go index e58ac8a251ee..f26fae87d943 100644 --- a/internal/generated/snippets/appengine/apiv1/ApplicationsClient/RepairApplication/main.go +++ b/internal/generated/snippets/appengine/apiv1/ApplicationsClient/RepairApplication/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/ApplicationsClient/UpdateApplication/main.go b/internal/generated/snippets/appengine/apiv1/ApplicationsClient/UpdateApplication/main.go index 9ad5d4366214..f8cde21710a2 100644 --- a/internal/generated/snippets/appengine/apiv1/ApplicationsClient/UpdateApplication/main.go +++ b/internal/generated/snippets/appengine/apiv1/ApplicationsClient/UpdateApplication/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/AuthorizedCertificatesClient/CreateAuthorizedCertificate/main.go b/internal/generated/snippets/appengine/apiv1/AuthorizedCertificatesClient/CreateAuthorizedCertificate/main.go index 1fcfbe57b58b..2e6d4034c88a 100644 --- a/internal/generated/snippets/appengine/apiv1/AuthorizedCertificatesClient/CreateAuthorizedCertificate/main.go +++ b/internal/generated/snippets/appengine/apiv1/AuthorizedCertificatesClient/CreateAuthorizedCertificate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/AuthorizedCertificatesClient/DeleteAuthorizedCertificate/main.go b/internal/generated/snippets/appengine/apiv1/AuthorizedCertificatesClient/DeleteAuthorizedCertificate/main.go index 73e770ad97e4..76f001bef31b 100644 --- a/internal/generated/snippets/appengine/apiv1/AuthorizedCertificatesClient/DeleteAuthorizedCertificate/main.go +++ b/internal/generated/snippets/appengine/apiv1/AuthorizedCertificatesClient/DeleteAuthorizedCertificate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/AuthorizedCertificatesClient/GetAuthorizedCertificate/main.go b/internal/generated/snippets/appengine/apiv1/AuthorizedCertificatesClient/GetAuthorizedCertificate/main.go index c4a5785b9946..26a111757306 100644 --- a/internal/generated/snippets/appengine/apiv1/AuthorizedCertificatesClient/GetAuthorizedCertificate/main.go +++ b/internal/generated/snippets/appengine/apiv1/AuthorizedCertificatesClient/GetAuthorizedCertificate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/AuthorizedCertificatesClient/ListAuthorizedCertificates/main.go b/internal/generated/snippets/appengine/apiv1/AuthorizedCertificatesClient/ListAuthorizedCertificates/main.go index 30faeded763c..0dda282a7fcd 100644 --- a/internal/generated/snippets/appengine/apiv1/AuthorizedCertificatesClient/ListAuthorizedCertificates/main.go +++ b/internal/generated/snippets/appengine/apiv1/AuthorizedCertificatesClient/ListAuthorizedCertificates/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/AuthorizedCertificatesClient/UpdateAuthorizedCertificate/main.go b/internal/generated/snippets/appengine/apiv1/AuthorizedCertificatesClient/UpdateAuthorizedCertificate/main.go index ae7696a6c699..5001d9faafa8 100644 --- a/internal/generated/snippets/appengine/apiv1/AuthorizedCertificatesClient/UpdateAuthorizedCertificate/main.go +++ b/internal/generated/snippets/appengine/apiv1/AuthorizedCertificatesClient/UpdateAuthorizedCertificate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/AuthorizedDomainsClient/ListAuthorizedDomains/main.go b/internal/generated/snippets/appengine/apiv1/AuthorizedDomainsClient/ListAuthorizedDomains/main.go index 801f29581b4c..6024e44ad58d 100644 --- a/internal/generated/snippets/appengine/apiv1/AuthorizedDomainsClient/ListAuthorizedDomains/main.go +++ b/internal/generated/snippets/appengine/apiv1/AuthorizedDomainsClient/ListAuthorizedDomains/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/DomainMappingsClient/CreateDomainMapping/main.go b/internal/generated/snippets/appengine/apiv1/DomainMappingsClient/CreateDomainMapping/main.go index dbf125de631c..08d0aaeed2df 100644 --- a/internal/generated/snippets/appengine/apiv1/DomainMappingsClient/CreateDomainMapping/main.go +++ b/internal/generated/snippets/appengine/apiv1/DomainMappingsClient/CreateDomainMapping/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/DomainMappingsClient/DeleteDomainMapping/main.go b/internal/generated/snippets/appengine/apiv1/DomainMappingsClient/DeleteDomainMapping/main.go index 6fe77750de13..0b5d57c99acd 100644 --- a/internal/generated/snippets/appengine/apiv1/DomainMappingsClient/DeleteDomainMapping/main.go +++ b/internal/generated/snippets/appengine/apiv1/DomainMappingsClient/DeleteDomainMapping/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/DomainMappingsClient/GetDomainMapping/main.go b/internal/generated/snippets/appengine/apiv1/DomainMappingsClient/GetDomainMapping/main.go index 5a97cd838344..6271c93be324 100644 --- a/internal/generated/snippets/appengine/apiv1/DomainMappingsClient/GetDomainMapping/main.go +++ b/internal/generated/snippets/appengine/apiv1/DomainMappingsClient/GetDomainMapping/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/DomainMappingsClient/ListDomainMappings/main.go b/internal/generated/snippets/appengine/apiv1/DomainMappingsClient/ListDomainMappings/main.go index d396f0cb4ff8..917a56d9f531 100644 --- a/internal/generated/snippets/appengine/apiv1/DomainMappingsClient/ListDomainMappings/main.go +++ b/internal/generated/snippets/appengine/apiv1/DomainMappingsClient/ListDomainMappings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/DomainMappingsClient/UpdateDomainMapping/main.go b/internal/generated/snippets/appengine/apiv1/DomainMappingsClient/UpdateDomainMapping/main.go index 0adcc7e1584c..eac9ac6786bf 100644 --- a/internal/generated/snippets/appengine/apiv1/DomainMappingsClient/UpdateDomainMapping/main.go +++ b/internal/generated/snippets/appengine/apiv1/DomainMappingsClient/UpdateDomainMapping/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/FirewallClient/BatchUpdateIngressRules/main.go b/internal/generated/snippets/appengine/apiv1/FirewallClient/BatchUpdateIngressRules/main.go index 21e92acb672a..2818ba8f172b 100644 --- a/internal/generated/snippets/appengine/apiv1/FirewallClient/BatchUpdateIngressRules/main.go +++ b/internal/generated/snippets/appengine/apiv1/FirewallClient/BatchUpdateIngressRules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/FirewallClient/CreateIngressRule/main.go b/internal/generated/snippets/appengine/apiv1/FirewallClient/CreateIngressRule/main.go index 296fc89a93a3..ee7e457d62f8 100644 --- a/internal/generated/snippets/appengine/apiv1/FirewallClient/CreateIngressRule/main.go +++ b/internal/generated/snippets/appengine/apiv1/FirewallClient/CreateIngressRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/FirewallClient/DeleteIngressRule/main.go b/internal/generated/snippets/appengine/apiv1/FirewallClient/DeleteIngressRule/main.go index 8acb1a5dd972..7eb7229a41af 100644 --- a/internal/generated/snippets/appengine/apiv1/FirewallClient/DeleteIngressRule/main.go +++ b/internal/generated/snippets/appengine/apiv1/FirewallClient/DeleteIngressRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/FirewallClient/GetIngressRule/main.go b/internal/generated/snippets/appengine/apiv1/FirewallClient/GetIngressRule/main.go index 72c31ab40cd7..aacad977c260 100644 --- a/internal/generated/snippets/appengine/apiv1/FirewallClient/GetIngressRule/main.go +++ b/internal/generated/snippets/appengine/apiv1/FirewallClient/GetIngressRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/FirewallClient/ListIngressRules/main.go b/internal/generated/snippets/appengine/apiv1/FirewallClient/ListIngressRules/main.go index 1aa5a60dc6bf..8a50a42a9edc 100644 --- a/internal/generated/snippets/appengine/apiv1/FirewallClient/ListIngressRules/main.go +++ b/internal/generated/snippets/appengine/apiv1/FirewallClient/ListIngressRules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/FirewallClient/UpdateIngressRule/main.go b/internal/generated/snippets/appengine/apiv1/FirewallClient/UpdateIngressRule/main.go index eb66c2de6726..d4cee1b05aaa 100644 --- a/internal/generated/snippets/appengine/apiv1/FirewallClient/UpdateIngressRule/main.go +++ b/internal/generated/snippets/appengine/apiv1/FirewallClient/UpdateIngressRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/InstancesClient/DebugInstance/main.go b/internal/generated/snippets/appengine/apiv1/InstancesClient/DebugInstance/main.go index 9a6990d44a34..8a119408aa6c 100644 --- a/internal/generated/snippets/appengine/apiv1/InstancesClient/DebugInstance/main.go +++ b/internal/generated/snippets/appengine/apiv1/InstancesClient/DebugInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/InstancesClient/DeleteInstance/main.go b/internal/generated/snippets/appengine/apiv1/InstancesClient/DeleteInstance/main.go index 4fd67041aa91..e2be6c995e83 100644 --- a/internal/generated/snippets/appengine/apiv1/InstancesClient/DeleteInstance/main.go +++ b/internal/generated/snippets/appengine/apiv1/InstancesClient/DeleteInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/InstancesClient/GetInstance/main.go b/internal/generated/snippets/appengine/apiv1/InstancesClient/GetInstance/main.go index 8f70ee754c00..561034b8a587 100644 --- a/internal/generated/snippets/appengine/apiv1/InstancesClient/GetInstance/main.go +++ b/internal/generated/snippets/appengine/apiv1/InstancesClient/GetInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/InstancesClient/ListInstances/main.go b/internal/generated/snippets/appengine/apiv1/InstancesClient/ListInstances/main.go index 668ff62dd9c9..49a182a3b7af 100644 --- a/internal/generated/snippets/appengine/apiv1/InstancesClient/ListInstances/main.go +++ b/internal/generated/snippets/appengine/apiv1/InstancesClient/ListInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/ServicesClient/DeleteService/main.go b/internal/generated/snippets/appengine/apiv1/ServicesClient/DeleteService/main.go index 477173c3b62e..ae8cb89e0cfb 100644 --- a/internal/generated/snippets/appengine/apiv1/ServicesClient/DeleteService/main.go +++ b/internal/generated/snippets/appengine/apiv1/ServicesClient/DeleteService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/ServicesClient/GetService/main.go b/internal/generated/snippets/appengine/apiv1/ServicesClient/GetService/main.go index 8026cd1d4785..bd7e18ed633f 100644 --- a/internal/generated/snippets/appengine/apiv1/ServicesClient/GetService/main.go +++ b/internal/generated/snippets/appengine/apiv1/ServicesClient/GetService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/ServicesClient/ListServices/main.go b/internal/generated/snippets/appengine/apiv1/ServicesClient/ListServices/main.go index e47542231f09..5e8b927fe030 100644 --- a/internal/generated/snippets/appengine/apiv1/ServicesClient/ListServices/main.go +++ b/internal/generated/snippets/appengine/apiv1/ServicesClient/ListServices/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/ServicesClient/UpdateService/main.go b/internal/generated/snippets/appengine/apiv1/ServicesClient/UpdateService/main.go index 66c58eec87f9..81465f5dd101 100644 --- a/internal/generated/snippets/appengine/apiv1/ServicesClient/UpdateService/main.go +++ b/internal/generated/snippets/appengine/apiv1/ServicesClient/UpdateService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/VersionsClient/CreateVersion/main.go b/internal/generated/snippets/appengine/apiv1/VersionsClient/CreateVersion/main.go index d20930c1f8ac..602316ea5fb4 100644 --- a/internal/generated/snippets/appengine/apiv1/VersionsClient/CreateVersion/main.go +++ b/internal/generated/snippets/appengine/apiv1/VersionsClient/CreateVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/VersionsClient/DeleteVersion/main.go b/internal/generated/snippets/appengine/apiv1/VersionsClient/DeleteVersion/main.go index 96aeba0fc8c5..66a5976dc550 100644 --- a/internal/generated/snippets/appengine/apiv1/VersionsClient/DeleteVersion/main.go +++ b/internal/generated/snippets/appengine/apiv1/VersionsClient/DeleteVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/VersionsClient/GetVersion/main.go b/internal/generated/snippets/appengine/apiv1/VersionsClient/GetVersion/main.go index 9a13b2b3a301..f4b80501e5d3 100644 --- a/internal/generated/snippets/appengine/apiv1/VersionsClient/GetVersion/main.go +++ b/internal/generated/snippets/appengine/apiv1/VersionsClient/GetVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/VersionsClient/ListVersions/main.go b/internal/generated/snippets/appengine/apiv1/VersionsClient/ListVersions/main.go index 38ce841cd710..9b0ea65f954a 100644 --- a/internal/generated/snippets/appengine/apiv1/VersionsClient/ListVersions/main.go +++ b/internal/generated/snippets/appengine/apiv1/VersionsClient/ListVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/appengine/apiv1/VersionsClient/UpdateVersion/main.go b/internal/generated/snippets/appengine/apiv1/VersionsClient/UpdateVersion/main.go index 30b2e5562814..136a01292173 100644 --- a/internal/generated/snippets/appengine/apiv1/VersionsClient/UpdateVersion/main.go +++ b/internal/generated/snippets/appengine/apiv1/VersionsClient/UpdateVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/apphub/apiv1/Client/CancelOperation/main.go index e88e850cab62..92286c81507e 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/CreateApplication/main.go b/internal/generated/snippets/apphub/apiv1/Client/CreateApplication/main.go index fcbace8f836d..862298f6fddd 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/CreateApplication/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/CreateApplication/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/CreateService/main.go b/internal/generated/snippets/apphub/apiv1/Client/CreateService/main.go index df02dacdd950..617d8ee07006 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/CreateService/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/CreateService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/CreateServiceProjectAttachment/main.go b/internal/generated/snippets/apphub/apiv1/Client/CreateServiceProjectAttachment/main.go index 95cc23db8ce1..f2f24e2e2a71 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/CreateServiceProjectAttachment/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/CreateServiceProjectAttachment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/CreateWorkload/main.go b/internal/generated/snippets/apphub/apiv1/Client/CreateWorkload/main.go index ff8af22e8bf6..4a91d2e228c2 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/CreateWorkload/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/CreateWorkload/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/DeleteApplication/main.go b/internal/generated/snippets/apphub/apiv1/Client/DeleteApplication/main.go index 61e36f848666..b5ca5bb6f3fd 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/DeleteApplication/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/DeleteApplication/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/apphub/apiv1/Client/DeleteOperation/main.go index 151a89836322..5cdedd6ab1c2 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/DeleteService/main.go b/internal/generated/snippets/apphub/apiv1/Client/DeleteService/main.go index c4afbf8ab6c8..de761237afbd 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/DeleteService/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/DeleteService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/DeleteServiceProjectAttachment/main.go b/internal/generated/snippets/apphub/apiv1/Client/DeleteServiceProjectAttachment/main.go index eb2f6fd285a7..d49d8d5d9e41 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/DeleteServiceProjectAttachment/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/DeleteServiceProjectAttachment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/DeleteWorkload/main.go b/internal/generated/snippets/apphub/apiv1/Client/DeleteWorkload/main.go index 64f33ab0f658..92918e860bd7 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/DeleteWorkload/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/DeleteWorkload/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/DetachServiceProjectAttachment/main.go b/internal/generated/snippets/apphub/apiv1/Client/DetachServiceProjectAttachment/main.go index 534ededfb7fa..d91a76ca0d2d 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/DetachServiceProjectAttachment/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/DetachServiceProjectAttachment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/GetApplication/main.go b/internal/generated/snippets/apphub/apiv1/Client/GetApplication/main.go index 9d8903784166..6904cd1a1513 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/GetApplication/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/GetApplication/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/GetDiscoveredService/main.go b/internal/generated/snippets/apphub/apiv1/Client/GetDiscoveredService/main.go index 023d7f6a27a5..d2be35a91396 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/GetDiscoveredService/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/GetDiscoveredService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/GetDiscoveredWorkload/main.go b/internal/generated/snippets/apphub/apiv1/Client/GetDiscoveredWorkload/main.go index a63b0b99bb7c..a47804d7aaea 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/GetDiscoveredWorkload/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/GetDiscoveredWorkload/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/GetIamPolicy/main.go b/internal/generated/snippets/apphub/apiv1/Client/GetIamPolicy/main.go index aafe8c0fb96c..c486da5fece9 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/apphub/apiv1/Client/GetLocation/main.go index b54007a2c6fc..8a8aa30cef63 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/apphub/apiv1/Client/GetOperation/main.go index a70a2e2bc2fd..5d2be3d56090 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/GetService/main.go b/internal/generated/snippets/apphub/apiv1/Client/GetService/main.go index bc8dd4824c23..43da29f5efec 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/GetService/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/GetService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/GetServiceProjectAttachment/main.go b/internal/generated/snippets/apphub/apiv1/Client/GetServiceProjectAttachment/main.go index 52c058c63ece..2f87b7ef95d3 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/GetServiceProjectAttachment/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/GetServiceProjectAttachment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/GetWorkload/main.go b/internal/generated/snippets/apphub/apiv1/Client/GetWorkload/main.go index 1979ffe58ef1..706dc51e29c7 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/GetWorkload/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/GetWorkload/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/ListApplications/main.go b/internal/generated/snippets/apphub/apiv1/Client/ListApplications/main.go index 4485a20e3feb..bb445d6ae2c6 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/ListApplications/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/ListApplications/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/ListDiscoveredServices/main.go b/internal/generated/snippets/apphub/apiv1/Client/ListDiscoveredServices/main.go index e261871c1f4b..99b8222e35d6 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/ListDiscoveredServices/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/ListDiscoveredServices/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/ListDiscoveredWorkloads/main.go b/internal/generated/snippets/apphub/apiv1/Client/ListDiscoveredWorkloads/main.go index 41e9d1e2d7a2..104fc0074ee3 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/ListDiscoveredWorkloads/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/ListDiscoveredWorkloads/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/apphub/apiv1/Client/ListLocations/main.go index ca8c5aec304d..f58c7f676373 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/apphub/apiv1/Client/ListOperations/main.go index 03a2efa9d948..6ccf2c431cf2 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/ListServiceProjectAttachments/main.go b/internal/generated/snippets/apphub/apiv1/Client/ListServiceProjectAttachments/main.go index b720ea351dec..bf227d4e7320 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/ListServiceProjectAttachments/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/ListServiceProjectAttachments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/ListServices/main.go b/internal/generated/snippets/apphub/apiv1/Client/ListServices/main.go index 14e43ca33646..dba4616c4f39 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/ListServices/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/ListServices/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/ListWorkloads/main.go b/internal/generated/snippets/apphub/apiv1/Client/ListWorkloads/main.go index c131cd89541f..fed7e4d1debe 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/ListWorkloads/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/ListWorkloads/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/LookupDiscoveredService/main.go b/internal/generated/snippets/apphub/apiv1/Client/LookupDiscoveredService/main.go index e696ff00ecc5..2081f49583fb 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/LookupDiscoveredService/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/LookupDiscoveredService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/LookupDiscoveredWorkload/main.go b/internal/generated/snippets/apphub/apiv1/Client/LookupDiscoveredWorkload/main.go index a88dced055e1..1844cca4eb72 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/LookupDiscoveredWorkload/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/LookupDiscoveredWorkload/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/LookupServiceProjectAttachment/main.go b/internal/generated/snippets/apphub/apiv1/Client/LookupServiceProjectAttachment/main.go index 8621ebf8e428..bcd22f541723 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/LookupServiceProjectAttachment/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/LookupServiceProjectAttachment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/SetIamPolicy/main.go b/internal/generated/snippets/apphub/apiv1/Client/SetIamPolicy/main.go index b43c7e1ede6e..fed1dec61965 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/TestIamPermissions/main.go b/internal/generated/snippets/apphub/apiv1/Client/TestIamPermissions/main.go index 1c2a29bd536d..81ecc73b6456 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/UpdateApplication/main.go b/internal/generated/snippets/apphub/apiv1/Client/UpdateApplication/main.go index 1350a870091f..a7cfcb1550eb 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/UpdateApplication/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/UpdateApplication/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/UpdateService/main.go b/internal/generated/snippets/apphub/apiv1/Client/UpdateService/main.go index db9fb5c5141b..3f3db0d8f700 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/UpdateService/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/UpdateService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/Client/UpdateWorkload/main.go b/internal/generated/snippets/apphub/apiv1/Client/UpdateWorkload/main.go index 8a3411bd8149..629fa2883f92 100644 --- a/internal/generated/snippets/apphub/apiv1/Client/UpdateWorkload/main.go +++ b/internal/generated/snippets/apphub/apiv1/Client/UpdateWorkload/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apphub/apiv1/snippet_metadata.google.cloud.apphub.v1.json b/internal/generated/snippets/apphub/apiv1/snippet_metadata.google.cloud.apphub.v1.json index 4c7e48f0e3a3..915f2b0c2075 100644 --- a/internal/generated/snippets/apphub/apiv1/snippet_metadata.google.cloud.apphub.v1.json +++ b/internal/generated/snippets/apphub/apiv1/snippet_metadata.google.cloud.apphub.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/apphub/apiv1", - "version": "0.2.2", + "version": "0.2.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/apps/events/subscriptions/apiv1/Client/CreateSubscription/main.go b/internal/generated/snippets/apps/events/subscriptions/apiv1/Client/CreateSubscription/main.go index 9c9345e4a09f..3b56014b102a 100644 --- a/internal/generated/snippets/apps/events/subscriptions/apiv1/Client/CreateSubscription/main.go +++ b/internal/generated/snippets/apps/events/subscriptions/apiv1/Client/CreateSubscription/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/events/subscriptions/apiv1/Client/DeleteSubscription/main.go b/internal/generated/snippets/apps/events/subscriptions/apiv1/Client/DeleteSubscription/main.go index 4c725edb4112..7c6b2467bedd 100644 --- a/internal/generated/snippets/apps/events/subscriptions/apiv1/Client/DeleteSubscription/main.go +++ b/internal/generated/snippets/apps/events/subscriptions/apiv1/Client/DeleteSubscription/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/events/subscriptions/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/apps/events/subscriptions/apiv1/Client/GetOperation/main.go index 19d9f551694a..109351a269b4 100644 --- a/internal/generated/snippets/apps/events/subscriptions/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/apps/events/subscriptions/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/events/subscriptions/apiv1/Client/GetSubscription/main.go b/internal/generated/snippets/apps/events/subscriptions/apiv1/Client/GetSubscription/main.go index dc093cf098a2..48c22cb3edf9 100644 --- a/internal/generated/snippets/apps/events/subscriptions/apiv1/Client/GetSubscription/main.go +++ b/internal/generated/snippets/apps/events/subscriptions/apiv1/Client/GetSubscription/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/events/subscriptions/apiv1/Client/ListSubscriptions/main.go b/internal/generated/snippets/apps/events/subscriptions/apiv1/Client/ListSubscriptions/main.go index 41646949945f..994bb3e92cd3 100644 --- a/internal/generated/snippets/apps/events/subscriptions/apiv1/Client/ListSubscriptions/main.go +++ b/internal/generated/snippets/apps/events/subscriptions/apiv1/Client/ListSubscriptions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/events/subscriptions/apiv1/Client/ReactivateSubscription/main.go b/internal/generated/snippets/apps/events/subscriptions/apiv1/Client/ReactivateSubscription/main.go index 8dd8331aceb1..24b98c004895 100644 --- a/internal/generated/snippets/apps/events/subscriptions/apiv1/Client/ReactivateSubscription/main.go +++ b/internal/generated/snippets/apps/events/subscriptions/apiv1/Client/ReactivateSubscription/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/events/subscriptions/apiv1/Client/UpdateSubscription/main.go b/internal/generated/snippets/apps/events/subscriptions/apiv1/Client/UpdateSubscription/main.go index 0e495b9b6a28..87d3399fdbf8 100644 --- a/internal/generated/snippets/apps/events/subscriptions/apiv1/Client/UpdateSubscription/main.go +++ b/internal/generated/snippets/apps/events/subscriptions/apiv1/Client/UpdateSubscription/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/events/subscriptions/apiv1/snippet_metadata.google.apps.events.subscriptions.v1.json b/internal/generated/snippets/apps/events/subscriptions/apiv1/snippet_metadata.google.apps.events.subscriptions.v1.json index 0e19dee517c7..2dc86844205c 100644 --- a/internal/generated/snippets/apps/events/subscriptions/apiv1/snippet_metadata.google.apps.events.subscriptions.v1.json +++ b/internal/generated/snippets/apps/events/subscriptions/apiv1/snippet_metadata.google.apps.events.subscriptions.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/apps/events/subscriptions/apiv1", - "version": "0.5.2", + "version": "0.5.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/GetConferenceRecord/main.go b/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/GetConferenceRecord/main.go index 3e22fcebcfb5..e9e560f6ee17 100644 --- a/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/GetConferenceRecord/main.go +++ b/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/GetConferenceRecord/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/GetParticipant/main.go b/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/GetParticipant/main.go index 2a554c1e01cc..837a8af3449c 100644 --- a/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/GetParticipant/main.go +++ b/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/GetParticipant/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/GetParticipantSession/main.go b/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/GetParticipantSession/main.go index 04422251c750..3658a14d84e3 100644 --- a/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/GetParticipantSession/main.go +++ b/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/GetParticipantSession/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/GetRecording/main.go b/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/GetRecording/main.go index b3f43660d644..ebc3c87cc043 100644 --- a/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/GetRecording/main.go +++ b/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/GetRecording/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/GetTranscript/main.go b/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/GetTranscript/main.go index 891761b5a642..a3caada26b95 100644 --- a/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/GetTranscript/main.go +++ b/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/GetTranscript/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/GetTranscriptEntry/main.go b/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/GetTranscriptEntry/main.go index f390c5e7efbd..4f78ae3dd909 100644 --- a/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/GetTranscriptEntry/main.go +++ b/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/GetTranscriptEntry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/ListConferenceRecords/main.go b/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/ListConferenceRecords/main.go index 2730649852d9..2df256ba3440 100644 --- a/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/ListConferenceRecords/main.go +++ b/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/ListConferenceRecords/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/ListParticipantSessions/main.go b/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/ListParticipantSessions/main.go index cdd7e3fbb84f..69f0fb9718f6 100644 --- a/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/ListParticipantSessions/main.go +++ b/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/ListParticipantSessions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/ListParticipants/main.go b/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/ListParticipants/main.go index cd5a2acd7f15..ebdb722eb3e9 100644 --- a/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/ListParticipants/main.go +++ b/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/ListParticipants/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/ListRecordings/main.go b/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/ListRecordings/main.go index 2623642e4846..1a9958495b97 100644 --- a/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/ListRecordings/main.go +++ b/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/ListRecordings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/ListTranscriptEntries/main.go b/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/ListTranscriptEntries/main.go index 4c01b2ba399a..088ce2f60e74 100644 --- a/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/ListTranscriptEntries/main.go +++ b/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/ListTranscriptEntries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/ListTranscripts/main.go b/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/ListTranscripts/main.go index 00bcf6619d61..682391ed9094 100644 --- a/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/ListTranscripts/main.go +++ b/internal/generated/snippets/apps/meet/apiv2/ConferenceRecordsClient/ListTranscripts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2/SpacesClient/CreateSpace/main.go b/internal/generated/snippets/apps/meet/apiv2/SpacesClient/CreateSpace/main.go index 166061da2e50..446482ab2724 100644 --- a/internal/generated/snippets/apps/meet/apiv2/SpacesClient/CreateSpace/main.go +++ b/internal/generated/snippets/apps/meet/apiv2/SpacesClient/CreateSpace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2/SpacesClient/EndActiveConference/main.go b/internal/generated/snippets/apps/meet/apiv2/SpacesClient/EndActiveConference/main.go index 6d0683b99b69..94949e1f8317 100644 --- a/internal/generated/snippets/apps/meet/apiv2/SpacesClient/EndActiveConference/main.go +++ b/internal/generated/snippets/apps/meet/apiv2/SpacesClient/EndActiveConference/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2/SpacesClient/GetSpace/main.go b/internal/generated/snippets/apps/meet/apiv2/SpacesClient/GetSpace/main.go index e4bd7e02b95c..c6104bbd307a 100644 --- a/internal/generated/snippets/apps/meet/apiv2/SpacesClient/GetSpace/main.go +++ b/internal/generated/snippets/apps/meet/apiv2/SpacesClient/GetSpace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2/SpacesClient/UpdateSpace/main.go b/internal/generated/snippets/apps/meet/apiv2/SpacesClient/UpdateSpace/main.go index 4b90461079f0..899512c2318f 100644 --- a/internal/generated/snippets/apps/meet/apiv2/SpacesClient/UpdateSpace/main.go +++ b/internal/generated/snippets/apps/meet/apiv2/SpacesClient/UpdateSpace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2/snippet_metadata.google.apps.meet.v2.json b/internal/generated/snippets/apps/meet/apiv2/snippet_metadata.google.apps.meet.v2.json index 6214c570a4d1..368078ef6fea 100644 --- a/internal/generated/snippets/apps/meet/apiv2/snippet_metadata.google.apps.meet.v2.json +++ b/internal/generated/snippets/apps/meet/apiv2/snippet_metadata.google.apps.meet.v2.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/apps/meet/apiv2", - "version": "0.5.2", + "version": "0.5.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/GetConferenceRecord/main.go b/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/GetConferenceRecord/main.go index 480e524db046..15814be82abe 100644 --- a/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/GetConferenceRecord/main.go +++ b/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/GetConferenceRecord/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/GetParticipant/main.go b/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/GetParticipant/main.go index cd39c24555b6..57057174e4d3 100644 --- a/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/GetParticipant/main.go +++ b/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/GetParticipant/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/GetParticipantSession/main.go b/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/GetParticipantSession/main.go index 8a3c643ff97e..cb65a9ae075d 100644 --- a/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/GetParticipantSession/main.go +++ b/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/GetParticipantSession/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/GetRecording/main.go b/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/GetRecording/main.go index 90d61683d47e..63ae64392e1b 100644 --- a/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/GetRecording/main.go +++ b/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/GetRecording/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/GetTranscript/main.go b/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/GetTranscript/main.go index 88fb5f2db4a7..f6a2890b40a0 100644 --- a/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/GetTranscript/main.go +++ b/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/GetTranscript/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/GetTranscriptEntry/main.go b/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/GetTranscriptEntry/main.go index c69b8d418cf9..b431e00dba83 100644 --- a/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/GetTranscriptEntry/main.go +++ b/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/GetTranscriptEntry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/ListConferenceRecords/main.go b/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/ListConferenceRecords/main.go index a0941bed45d8..72d6164be9da 100644 --- a/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/ListConferenceRecords/main.go +++ b/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/ListConferenceRecords/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/ListParticipantSessions/main.go b/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/ListParticipantSessions/main.go index 5a4d7e5472a1..a13bc194d4b4 100644 --- a/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/ListParticipantSessions/main.go +++ b/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/ListParticipantSessions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/ListParticipants/main.go b/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/ListParticipants/main.go index b2aaa45981b8..fc0f10332896 100644 --- a/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/ListParticipants/main.go +++ b/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/ListParticipants/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/ListRecordings/main.go b/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/ListRecordings/main.go index e64f5f0459ad..9ef69486da86 100644 --- a/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/ListRecordings/main.go +++ b/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/ListRecordings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/ListTranscriptEntries/main.go b/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/ListTranscriptEntries/main.go index cd5c8d5d7bf8..e057ec0fd3f5 100644 --- a/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/ListTranscriptEntries/main.go +++ b/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/ListTranscriptEntries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/ListTranscripts/main.go b/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/ListTranscripts/main.go index 30ad10cae0ea..213ecf875371 100644 --- a/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/ListTranscripts/main.go +++ b/internal/generated/snippets/apps/meet/apiv2beta/ConferenceRecordsClient/ListTranscripts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2beta/SpacesClient/CreateSpace/main.go b/internal/generated/snippets/apps/meet/apiv2beta/SpacesClient/CreateSpace/main.go index 3349b62492df..7163c94cc14b 100644 --- a/internal/generated/snippets/apps/meet/apiv2beta/SpacesClient/CreateSpace/main.go +++ b/internal/generated/snippets/apps/meet/apiv2beta/SpacesClient/CreateSpace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2beta/SpacesClient/EndActiveConference/main.go b/internal/generated/snippets/apps/meet/apiv2beta/SpacesClient/EndActiveConference/main.go index a3be396602ee..73b8a07a6322 100644 --- a/internal/generated/snippets/apps/meet/apiv2beta/SpacesClient/EndActiveConference/main.go +++ b/internal/generated/snippets/apps/meet/apiv2beta/SpacesClient/EndActiveConference/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2beta/SpacesClient/GetSpace/main.go b/internal/generated/snippets/apps/meet/apiv2beta/SpacesClient/GetSpace/main.go index 0babc0296166..516a19ddbbdc 100644 --- a/internal/generated/snippets/apps/meet/apiv2beta/SpacesClient/GetSpace/main.go +++ b/internal/generated/snippets/apps/meet/apiv2beta/SpacesClient/GetSpace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2beta/SpacesClient/UpdateSpace/main.go b/internal/generated/snippets/apps/meet/apiv2beta/SpacesClient/UpdateSpace/main.go index 045e00974175..8e8f24794755 100644 --- a/internal/generated/snippets/apps/meet/apiv2beta/SpacesClient/UpdateSpace/main.go +++ b/internal/generated/snippets/apps/meet/apiv2beta/SpacesClient/UpdateSpace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/apps/meet/apiv2beta/snippet_metadata.google.apps.meet.v2beta.json b/internal/generated/snippets/apps/meet/apiv2beta/snippet_metadata.google.apps.meet.v2beta.json index ba204c5fce9d..5b769713b840 100644 --- a/internal/generated/snippets/apps/meet/apiv2beta/snippet_metadata.google.apps.meet.v2beta.json +++ b/internal/generated/snippets/apps/meet/apiv2beta/snippet_metadata.google.apps.meet.v2beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/apps/meet/apiv2beta", - "version": "0.5.2", + "version": "0.5.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/area120/tables/apiv1alpha1/Client/BatchCreateRows/main.go b/internal/generated/snippets/area120/tables/apiv1alpha1/Client/BatchCreateRows/main.go index e970b983d69d..8a7781ae6f3a 100644 --- a/internal/generated/snippets/area120/tables/apiv1alpha1/Client/BatchCreateRows/main.go +++ b/internal/generated/snippets/area120/tables/apiv1alpha1/Client/BatchCreateRows/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/area120/tables/apiv1alpha1/Client/BatchDeleteRows/main.go b/internal/generated/snippets/area120/tables/apiv1alpha1/Client/BatchDeleteRows/main.go index ed1ac153ee34..49a97b75028d 100644 --- a/internal/generated/snippets/area120/tables/apiv1alpha1/Client/BatchDeleteRows/main.go +++ b/internal/generated/snippets/area120/tables/apiv1alpha1/Client/BatchDeleteRows/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/area120/tables/apiv1alpha1/Client/BatchUpdateRows/main.go b/internal/generated/snippets/area120/tables/apiv1alpha1/Client/BatchUpdateRows/main.go index 3dc048a16742..cd26258eeb7a 100644 --- a/internal/generated/snippets/area120/tables/apiv1alpha1/Client/BatchUpdateRows/main.go +++ b/internal/generated/snippets/area120/tables/apiv1alpha1/Client/BatchUpdateRows/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/area120/tables/apiv1alpha1/Client/CreateRow/main.go b/internal/generated/snippets/area120/tables/apiv1alpha1/Client/CreateRow/main.go index 10143771980f..cafd89f4e6e1 100644 --- a/internal/generated/snippets/area120/tables/apiv1alpha1/Client/CreateRow/main.go +++ b/internal/generated/snippets/area120/tables/apiv1alpha1/Client/CreateRow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/area120/tables/apiv1alpha1/Client/DeleteRow/main.go b/internal/generated/snippets/area120/tables/apiv1alpha1/Client/DeleteRow/main.go index d39697bb29c5..c478b2334dc1 100644 --- a/internal/generated/snippets/area120/tables/apiv1alpha1/Client/DeleteRow/main.go +++ b/internal/generated/snippets/area120/tables/apiv1alpha1/Client/DeleteRow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/area120/tables/apiv1alpha1/Client/GetRow/main.go b/internal/generated/snippets/area120/tables/apiv1alpha1/Client/GetRow/main.go index 2764d327a171..ead3c79f69cb 100644 --- a/internal/generated/snippets/area120/tables/apiv1alpha1/Client/GetRow/main.go +++ b/internal/generated/snippets/area120/tables/apiv1alpha1/Client/GetRow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/area120/tables/apiv1alpha1/Client/GetTable/main.go b/internal/generated/snippets/area120/tables/apiv1alpha1/Client/GetTable/main.go index 967d708dfaec..7dcd3f438e21 100644 --- a/internal/generated/snippets/area120/tables/apiv1alpha1/Client/GetTable/main.go +++ b/internal/generated/snippets/area120/tables/apiv1alpha1/Client/GetTable/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/area120/tables/apiv1alpha1/Client/GetWorkspace/main.go b/internal/generated/snippets/area120/tables/apiv1alpha1/Client/GetWorkspace/main.go index fffa54994e42..29dafed9fddf 100644 --- a/internal/generated/snippets/area120/tables/apiv1alpha1/Client/GetWorkspace/main.go +++ b/internal/generated/snippets/area120/tables/apiv1alpha1/Client/GetWorkspace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/area120/tables/apiv1alpha1/Client/ListRows/main.go b/internal/generated/snippets/area120/tables/apiv1alpha1/Client/ListRows/main.go index 2a4e20a2d4c8..be7a3f40b74b 100644 --- a/internal/generated/snippets/area120/tables/apiv1alpha1/Client/ListRows/main.go +++ b/internal/generated/snippets/area120/tables/apiv1alpha1/Client/ListRows/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/area120/tables/apiv1alpha1/Client/ListTables/main.go b/internal/generated/snippets/area120/tables/apiv1alpha1/Client/ListTables/main.go index 747c05080d54..86f52f4980e3 100644 --- a/internal/generated/snippets/area120/tables/apiv1alpha1/Client/ListTables/main.go +++ b/internal/generated/snippets/area120/tables/apiv1alpha1/Client/ListTables/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/area120/tables/apiv1alpha1/Client/ListWorkspaces/main.go b/internal/generated/snippets/area120/tables/apiv1alpha1/Client/ListWorkspaces/main.go index 539b8a70fdcc..e6d6cc1e5fa4 100644 --- a/internal/generated/snippets/area120/tables/apiv1alpha1/Client/ListWorkspaces/main.go +++ b/internal/generated/snippets/area120/tables/apiv1alpha1/Client/ListWorkspaces/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/area120/tables/apiv1alpha1/Client/UpdateRow/main.go b/internal/generated/snippets/area120/tables/apiv1alpha1/Client/UpdateRow/main.go index 83cfcada545e..acca2ae8d761 100644 --- a/internal/generated/snippets/area120/tables/apiv1alpha1/Client/UpdateRow/main.go +++ b/internal/generated/snippets/area120/tables/apiv1alpha1/Client/UpdateRow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/BatchDeleteVersions/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/BatchDeleteVersions/main.go index 95c2cc8e1ce8..24c9ac35b26f 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/BatchDeleteVersions/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/BatchDeleteVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/CreateAttachment/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/CreateAttachment/main.go index 283754d20916..00fc0ccd04bf 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/CreateAttachment/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/CreateAttachment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/CreateRepository/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/CreateRepository/main.go index 55bc84c9b9e0..42c13d9503f4 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/CreateRepository/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/CreateRepository/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/CreateRule/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/CreateRule/main.go index 2739e2e6d550..7b29b38bdeb5 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/CreateRule/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/CreateRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/CreateTag/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/CreateTag/main.go index f130e72445ab..b39252bce319 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/CreateTag/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/CreateTag/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/DeleteAttachment/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/DeleteAttachment/main.go index 13bd60c3dd66..e55aea2663c4 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/DeleteAttachment/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/DeleteAttachment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/DeleteFile/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/DeleteFile/main.go index 22b083eb9a05..1c4432888dab 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/DeleteFile/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/DeleteFile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/DeletePackage/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/DeletePackage/main.go index 7f878778b88d..da95f4d009c6 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/DeletePackage/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/DeletePackage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/DeleteRepository/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/DeleteRepository/main.go index a3de1395b0c5..8e2050b40172 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/DeleteRepository/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/DeleteRepository/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/DeleteRule/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/DeleteRule/main.go index bf76078e2d2d..4e9e53fe9888 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/DeleteRule/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/DeleteRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/DeleteTag/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/DeleteTag/main.go index 23cb7d3444b6..2af51fa069e7 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/DeleteTag/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/DeleteTag/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/DeleteVersion/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/DeleteVersion/main.go index 75a37a2cd592..eb55d7ce9d87 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/DeleteVersion/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/DeleteVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/GetAttachment/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/GetAttachment/main.go index 07a2cc95eb92..b64161040edf 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/GetAttachment/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/GetAttachment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/GetDockerImage/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/GetDockerImage/main.go index dc9147a8b964..82675590a658 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/GetDockerImage/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/GetDockerImage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/GetFile/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/GetFile/main.go index be20318cad6f..4e5e751778e7 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/GetFile/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/GetFile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/GetIamPolicy/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/GetIamPolicy/main.go index ccd042405ef7..10e747cbff2a 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/GetLocation/main.go index ff9b27c178d4..e4303093f72e 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/GetMavenArtifact/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/GetMavenArtifact/main.go index 4bbe6099227c..834fe8d151e0 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/GetMavenArtifact/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/GetMavenArtifact/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/GetNpmPackage/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/GetNpmPackage/main.go index 5b272c93a8c8..799b861097ee 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/GetNpmPackage/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/GetNpmPackage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/GetOperation/main.go index 943a8f09337e..908f40affdb4 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/GetPackage/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/GetPackage/main.go index 2b6c7ebf6221..b4fa24bfb3bf 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/GetPackage/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/GetPackage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/GetProjectSettings/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/GetProjectSettings/main.go index 82a80dca6d1b..1305f6fa6e31 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/GetProjectSettings/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/GetProjectSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/GetPythonPackage/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/GetPythonPackage/main.go index 329e900f1c2c..afb7ba72f069 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/GetPythonPackage/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/GetPythonPackage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/GetRepository/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/GetRepository/main.go index 77d0c346d787..7dd3adec7362 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/GetRepository/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/GetRepository/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/GetRule/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/GetRule/main.go index f7e05af5463a..0664cd1e1b8b 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/GetRule/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/GetRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/GetTag/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/GetTag/main.go index 103dc50565b8..0544dff9a5be 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/GetTag/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/GetTag/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/GetVPCSCConfig/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/GetVPCSCConfig/main.go index 9505ba43da13..f32d06846a64 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/GetVPCSCConfig/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/GetVPCSCConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/GetVersion/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/GetVersion/main.go index e675a0f1b676..bc5fc7b54c81 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/GetVersion/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/GetVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/ImportAptArtifacts/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/ImportAptArtifacts/main.go index 3afcd86b502c..7e1d66f84f21 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/ImportAptArtifacts/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/ImportAptArtifacts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/ImportYumArtifacts/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/ImportYumArtifacts/main.go index b884feae495a..43ca6645f518 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/ImportYumArtifacts/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/ImportYumArtifacts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/ListAttachments/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/ListAttachments/main.go index 8a72d3369ffb..28a53f46ec9d 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/ListAttachments/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/ListAttachments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/ListDockerImages/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/ListDockerImages/main.go index 1a98a597289d..672e959dbbc3 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/ListDockerImages/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/ListDockerImages/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/ListFiles/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/ListFiles/main.go index fac11c00b7d6..8c883675a541 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/ListFiles/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/ListFiles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/ListLocations/main.go index 3d73a975036d..8619681a08ce 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/ListMavenArtifacts/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/ListMavenArtifacts/main.go index 6c95fd25bd18..9146dd9b6b4d 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/ListMavenArtifacts/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/ListMavenArtifacts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/ListNpmPackages/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/ListNpmPackages/main.go index b211ea4bd5e1..de06172ad8f3 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/ListNpmPackages/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/ListNpmPackages/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/ListPackages/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/ListPackages/main.go index 6fa3582c4cbd..213cec68bb82 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/ListPackages/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/ListPackages/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/ListPythonPackages/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/ListPythonPackages/main.go index 5510674ed7b3..f72ede9d43ea 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/ListPythonPackages/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/ListPythonPackages/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/ListRepositories/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/ListRepositories/main.go index 0a468aba17f4..199bb6c13792 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/ListRepositories/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/ListRepositories/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/ListRules/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/ListRules/main.go index 11361f19de2f..653518f9b48e 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/ListRules/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/ListRules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/ListTags/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/ListTags/main.go index 1b0ef3efc076..6e6e28fd2557 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/ListTags/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/ListTags/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/ListVersions/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/ListVersions/main.go index 8e17e3c5b5e4..dd74b6ae706d 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/ListVersions/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/ListVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/SetIamPolicy/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/SetIamPolicy/main.go index 8fb03c70ccc8..a568f904f94f 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/TestIamPermissions/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/TestIamPermissions/main.go index 82a3792568d9..34e7de8caeec 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/UpdateFile/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/UpdateFile/main.go index fd1b93922539..7fbf9f6904d3 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/UpdateFile/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/UpdateFile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/UpdatePackage/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/UpdatePackage/main.go index 697357b4e99e..d20269b61cdb 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/UpdatePackage/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/UpdatePackage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/UpdateProjectSettings/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/UpdateProjectSettings/main.go index 566d47e56d2b..037045e8c25f 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/UpdateProjectSettings/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/UpdateProjectSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/UpdateRepository/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/UpdateRepository/main.go index be3a9f45d339..ff6af9477378 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/UpdateRepository/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/UpdateRepository/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/UpdateRule/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/UpdateRule/main.go index ca02a6fca935..4a1b0d6d0a31 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/UpdateRule/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/UpdateRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/UpdateTag/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/UpdateTag/main.go index d39fecd16803..ba61d4acdea0 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/UpdateTag/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/UpdateTag/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/UpdateVPCSCConfig/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/UpdateVPCSCConfig/main.go index c5ca023d8411..8d2d9ecc466e 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/UpdateVPCSCConfig/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/UpdateVPCSCConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1/Client/UpdateVersion/main.go b/internal/generated/snippets/artifactregistry/apiv1/Client/UpdateVersion/main.go index 91b7074cbee5..e1ed78c64afb 100644 --- a/internal/generated/snippets/artifactregistry/apiv1/Client/UpdateVersion/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1/Client/UpdateVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/CreateRepository/main.go b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/CreateRepository/main.go index 53a20844ebd3..7603c281df24 100644 --- a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/CreateRepository/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/CreateRepository/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/CreateTag/main.go b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/CreateTag/main.go index 407c08997cea..9580f7ebca03 100644 --- a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/CreateTag/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/CreateTag/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/DeletePackage/main.go b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/DeletePackage/main.go index 484d1545fc39..2233d6767929 100644 --- a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/DeletePackage/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/DeletePackage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/DeleteRepository/main.go b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/DeleteRepository/main.go index 87786621b80b..b528c19d1c6d 100644 --- a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/DeleteRepository/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/DeleteRepository/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/DeleteTag/main.go b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/DeleteTag/main.go index f4285f12ce78..65df0c8dfce3 100644 --- a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/DeleteTag/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/DeleteTag/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/DeleteVersion/main.go b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/DeleteVersion/main.go index 1c2b22423b24..5ca73531af13 100644 --- a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/DeleteVersion/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/DeleteVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetFile/main.go b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetFile/main.go index e6cfbe624126..b67a05ec1bed 100644 --- a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetFile/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetFile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetIamPolicy/main.go b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetIamPolicy/main.go index 2f601eacf623..b26d20e9ec29 100644 --- a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetLocation/main.go b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetLocation/main.go index aa8d033163c1..dbcfdd363e6c 100644 --- a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetLocation/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetPackage/main.go b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetPackage/main.go index 490059a568b0..4786f8b5e37d 100644 --- a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetPackage/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetPackage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetProjectSettings/main.go b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetProjectSettings/main.go index 5c62a652cce3..8c079baf542a 100644 --- a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetProjectSettings/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetProjectSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetRepository/main.go b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetRepository/main.go index ca8f6ca2d639..b48eaaccbf12 100644 --- a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetRepository/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetRepository/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetTag/main.go b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetTag/main.go index 348341291e3b..ff3adf2ad66f 100644 --- a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetTag/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetTag/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetVersion/main.go b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetVersion/main.go index be0dc2491caf..4603b075a860 100644 --- a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetVersion/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/GetVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ImportAptArtifacts/main.go b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ImportAptArtifacts/main.go index a52a63834f0f..ebf2b77859c6 100644 --- a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ImportAptArtifacts/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ImportAptArtifacts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ImportYumArtifacts/main.go b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ImportYumArtifacts/main.go index cf792008e2d1..f5b23e12ed29 100644 --- a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ImportYumArtifacts/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ImportYumArtifacts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ListFiles/main.go b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ListFiles/main.go index 9934425d7ca8..56a7fb4ea6a3 100644 --- a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ListFiles/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ListFiles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ListLocations/main.go b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ListLocations/main.go index a9738a15011e..f9f2f6df950c 100644 --- a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ListLocations/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ListPackages/main.go b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ListPackages/main.go index 80cbe258b21e..b40ea9599fe4 100644 --- a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ListPackages/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ListPackages/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ListRepositories/main.go b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ListRepositories/main.go index bee0f2d71a04..293388166d9e 100644 --- a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ListRepositories/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ListRepositories/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ListTags/main.go b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ListTags/main.go index ad0683121129..9eabf379497a 100644 --- a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ListTags/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ListTags/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ListVersions/main.go b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ListVersions/main.go index 9c1f97aef126..abc23f2823f0 100644 --- a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ListVersions/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/ListVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/SetIamPolicy/main.go b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/SetIamPolicy/main.go index cc9f59e385bc..c2b4dc618468 100644 --- a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/TestIamPermissions/main.go b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/TestIamPermissions/main.go index 81169e501b50..d1d991e3882a 100644 --- a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/UpdateProjectSettings/main.go b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/UpdateProjectSettings/main.go index ed92588d08e2..649890da2709 100644 --- a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/UpdateProjectSettings/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/UpdateProjectSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/UpdateRepository/main.go b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/UpdateRepository/main.go index 226fd9148906..eef5a5f49975 100644 --- a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/UpdateRepository/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/UpdateRepository/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/UpdateTag/main.go b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/UpdateTag/main.go index bdd461b6c3ff..8e13ddde83c5 100644 --- a/internal/generated/snippets/artifactregistry/apiv1beta2/Client/UpdateTag/main.go +++ b/internal/generated/snippets/artifactregistry/apiv1beta2/Client/UpdateTag/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1/Client/AnalyzeIamPolicy/main.go b/internal/generated/snippets/asset/apiv1/Client/AnalyzeIamPolicy/main.go index f4839cbb2762..14493e7fc864 100644 --- a/internal/generated/snippets/asset/apiv1/Client/AnalyzeIamPolicy/main.go +++ b/internal/generated/snippets/asset/apiv1/Client/AnalyzeIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1/Client/AnalyzeIamPolicyLongrunning/main.go b/internal/generated/snippets/asset/apiv1/Client/AnalyzeIamPolicyLongrunning/main.go index f80d5904f5ce..e51b54c8e07a 100644 --- a/internal/generated/snippets/asset/apiv1/Client/AnalyzeIamPolicyLongrunning/main.go +++ b/internal/generated/snippets/asset/apiv1/Client/AnalyzeIamPolicyLongrunning/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1/Client/AnalyzeMove/main.go b/internal/generated/snippets/asset/apiv1/Client/AnalyzeMove/main.go index 6f45775c6a49..96ebcbd11c5b 100644 --- a/internal/generated/snippets/asset/apiv1/Client/AnalyzeMove/main.go +++ b/internal/generated/snippets/asset/apiv1/Client/AnalyzeMove/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1/Client/AnalyzeOrgPolicies/main.go b/internal/generated/snippets/asset/apiv1/Client/AnalyzeOrgPolicies/main.go index 0abc5157411a..61e3a94d84c0 100644 --- a/internal/generated/snippets/asset/apiv1/Client/AnalyzeOrgPolicies/main.go +++ b/internal/generated/snippets/asset/apiv1/Client/AnalyzeOrgPolicies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1/Client/AnalyzeOrgPolicyGovernedAssets/main.go b/internal/generated/snippets/asset/apiv1/Client/AnalyzeOrgPolicyGovernedAssets/main.go index d84a69cb20f7..db7b892af33e 100644 --- a/internal/generated/snippets/asset/apiv1/Client/AnalyzeOrgPolicyGovernedAssets/main.go +++ b/internal/generated/snippets/asset/apiv1/Client/AnalyzeOrgPolicyGovernedAssets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1/Client/AnalyzeOrgPolicyGovernedContainers/main.go b/internal/generated/snippets/asset/apiv1/Client/AnalyzeOrgPolicyGovernedContainers/main.go index 0d4dc5b2f791..0ae529e98fa4 100644 --- a/internal/generated/snippets/asset/apiv1/Client/AnalyzeOrgPolicyGovernedContainers/main.go +++ b/internal/generated/snippets/asset/apiv1/Client/AnalyzeOrgPolicyGovernedContainers/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1/Client/BatchGetAssetsHistory/main.go b/internal/generated/snippets/asset/apiv1/Client/BatchGetAssetsHistory/main.go index 195b79ef414b..4d844c2f23f2 100644 --- a/internal/generated/snippets/asset/apiv1/Client/BatchGetAssetsHistory/main.go +++ b/internal/generated/snippets/asset/apiv1/Client/BatchGetAssetsHistory/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1/Client/BatchGetEffectiveIamPolicies/main.go b/internal/generated/snippets/asset/apiv1/Client/BatchGetEffectiveIamPolicies/main.go index e79090d8a481..a428ce13c790 100644 --- a/internal/generated/snippets/asset/apiv1/Client/BatchGetEffectiveIamPolicies/main.go +++ b/internal/generated/snippets/asset/apiv1/Client/BatchGetEffectiveIamPolicies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1/Client/CreateFeed/main.go b/internal/generated/snippets/asset/apiv1/Client/CreateFeed/main.go index 394a77b4e92a..75495440509e 100644 --- a/internal/generated/snippets/asset/apiv1/Client/CreateFeed/main.go +++ b/internal/generated/snippets/asset/apiv1/Client/CreateFeed/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1/Client/CreateSavedQuery/main.go b/internal/generated/snippets/asset/apiv1/Client/CreateSavedQuery/main.go index 3e50557c561f..ac2724c2cd70 100644 --- a/internal/generated/snippets/asset/apiv1/Client/CreateSavedQuery/main.go +++ b/internal/generated/snippets/asset/apiv1/Client/CreateSavedQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1/Client/DeleteFeed/main.go b/internal/generated/snippets/asset/apiv1/Client/DeleteFeed/main.go index fa7237b39e2c..a675671103fd 100644 --- a/internal/generated/snippets/asset/apiv1/Client/DeleteFeed/main.go +++ b/internal/generated/snippets/asset/apiv1/Client/DeleteFeed/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1/Client/DeleteSavedQuery/main.go b/internal/generated/snippets/asset/apiv1/Client/DeleteSavedQuery/main.go index fdcae2b9929d..78fad2d6e25c 100644 --- a/internal/generated/snippets/asset/apiv1/Client/DeleteSavedQuery/main.go +++ b/internal/generated/snippets/asset/apiv1/Client/DeleteSavedQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1/Client/ExportAssets/main.go b/internal/generated/snippets/asset/apiv1/Client/ExportAssets/main.go index 6a40ccb4830b..8965824956dc 100644 --- a/internal/generated/snippets/asset/apiv1/Client/ExportAssets/main.go +++ b/internal/generated/snippets/asset/apiv1/Client/ExportAssets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1/Client/GetFeed/main.go b/internal/generated/snippets/asset/apiv1/Client/GetFeed/main.go index d3dc7657f87d..899eb968b4ee 100644 --- a/internal/generated/snippets/asset/apiv1/Client/GetFeed/main.go +++ b/internal/generated/snippets/asset/apiv1/Client/GetFeed/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/asset/apiv1/Client/GetOperation/main.go index 9363305472d3..c9baf3626526 100644 --- a/internal/generated/snippets/asset/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/asset/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1/Client/GetSavedQuery/main.go b/internal/generated/snippets/asset/apiv1/Client/GetSavedQuery/main.go index 8eb69a1a7720..94b501708640 100644 --- a/internal/generated/snippets/asset/apiv1/Client/GetSavedQuery/main.go +++ b/internal/generated/snippets/asset/apiv1/Client/GetSavedQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1/Client/ListAssets/main.go b/internal/generated/snippets/asset/apiv1/Client/ListAssets/main.go index 691894aa1a34..e241ee504565 100644 --- a/internal/generated/snippets/asset/apiv1/Client/ListAssets/main.go +++ b/internal/generated/snippets/asset/apiv1/Client/ListAssets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1/Client/ListFeeds/main.go b/internal/generated/snippets/asset/apiv1/Client/ListFeeds/main.go index 76182f27373c..2cab2f68c687 100644 --- a/internal/generated/snippets/asset/apiv1/Client/ListFeeds/main.go +++ b/internal/generated/snippets/asset/apiv1/Client/ListFeeds/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1/Client/ListSavedQueries/main.go b/internal/generated/snippets/asset/apiv1/Client/ListSavedQueries/main.go index 075b797fd027..3d1e46dfe190 100644 --- a/internal/generated/snippets/asset/apiv1/Client/ListSavedQueries/main.go +++ b/internal/generated/snippets/asset/apiv1/Client/ListSavedQueries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1/Client/QueryAssets/main.go b/internal/generated/snippets/asset/apiv1/Client/QueryAssets/main.go index ad2229e6ec28..a2b79c0b9df2 100644 --- a/internal/generated/snippets/asset/apiv1/Client/QueryAssets/main.go +++ b/internal/generated/snippets/asset/apiv1/Client/QueryAssets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1/Client/SearchAllIamPolicies/main.go b/internal/generated/snippets/asset/apiv1/Client/SearchAllIamPolicies/main.go index 9ffc89ee3157..bc9bfc19fe0c 100644 --- a/internal/generated/snippets/asset/apiv1/Client/SearchAllIamPolicies/main.go +++ b/internal/generated/snippets/asset/apiv1/Client/SearchAllIamPolicies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1/Client/SearchAllResources/main.go b/internal/generated/snippets/asset/apiv1/Client/SearchAllResources/main.go index a07609097970..2fba3410320e 100644 --- a/internal/generated/snippets/asset/apiv1/Client/SearchAllResources/main.go +++ b/internal/generated/snippets/asset/apiv1/Client/SearchAllResources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1/Client/UpdateFeed/main.go b/internal/generated/snippets/asset/apiv1/Client/UpdateFeed/main.go index e795e6d0195d..c69cccf95de7 100644 --- a/internal/generated/snippets/asset/apiv1/Client/UpdateFeed/main.go +++ b/internal/generated/snippets/asset/apiv1/Client/UpdateFeed/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1/Client/UpdateSavedQuery/main.go b/internal/generated/snippets/asset/apiv1/Client/UpdateSavedQuery/main.go index d3672d69bf20..add8e1954d35 100644 --- a/internal/generated/snippets/asset/apiv1/Client/UpdateSavedQuery/main.go +++ b/internal/generated/snippets/asset/apiv1/Client/UpdateSavedQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1/snippet_metadata.google.cloud.asset.v1.json b/internal/generated/snippets/asset/apiv1/snippet_metadata.google.cloud.asset.v1.json index a81cd84c8b2b..9fd1c3d730bf 100644 --- a/internal/generated/snippets/asset/apiv1/snippet_metadata.google.cloud.asset.v1.json +++ b/internal/generated/snippets/asset/apiv1/snippet_metadata.google.cloud.asset.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/asset/apiv1", - "version": "1.20.3", + "version": "1.20.4", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/asset/apiv1p2beta1/Client/CreateFeed/main.go b/internal/generated/snippets/asset/apiv1p2beta1/Client/CreateFeed/main.go index 33cc06df11b0..94571d9a4536 100644 --- a/internal/generated/snippets/asset/apiv1p2beta1/Client/CreateFeed/main.go +++ b/internal/generated/snippets/asset/apiv1p2beta1/Client/CreateFeed/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1p2beta1/Client/DeleteFeed/main.go b/internal/generated/snippets/asset/apiv1p2beta1/Client/DeleteFeed/main.go index fa63025595be..7f27cc3731e1 100644 --- a/internal/generated/snippets/asset/apiv1p2beta1/Client/DeleteFeed/main.go +++ b/internal/generated/snippets/asset/apiv1p2beta1/Client/DeleteFeed/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1p2beta1/Client/GetFeed/main.go b/internal/generated/snippets/asset/apiv1p2beta1/Client/GetFeed/main.go index e8f68b08b262..37f84ce17f05 100644 --- a/internal/generated/snippets/asset/apiv1p2beta1/Client/GetFeed/main.go +++ b/internal/generated/snippets/asset/apiv1p2beta1/Client/GetFeed/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1p2beta1/Client/GetOperation/main.go b/internal/generated/snippets/asset/apiv1p2beta1/Client/GetOperation/main.go index e5a794e10f57..6b2142dc0fab 100644 --- a/internal/generated/snippets/asset/apiv1p2beta1/Client/GetOperation/main.go +++ b/internal/generated/snippets/asset/apiv1p2beta1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1p2beta1/Client/ListFeeds/main.go b/internal/generated/snippets/asset/apiv1p2beta1/Client/ListFeeds/main.go index 5501a2bb6d74..af0153e3f73f 100644 --- a/internal/generated/snippets/asset/apiv1p2beta1/Client/ListFeeds/main.go +++ b/internal/generated/snippets/asset/apiv1p2beta1/Client/ListFeeds/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1p2beta1/Client/UpdateFeed/main.go b/internal/generated/snippets/asset/apiv1p2beta1/Client/UpdateFeed/main.go index 538fc714446f..f9cb6947158a 100644 --- a/internal/generated/snippets/asset/apiv1p2beta1/Client/UpdateFeed/main.go +++ b/internal/generated/snippets/asset/apiv1p2beta1/Client/UpdateFeed/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1p2beta1/snippet_metadata.google.cloud.asset.v1p2beta1.json b/internal/generated/snippets/asset/apiv1p2beta1/snippet_metadata.google.cloud.asset.v1p2beta1.json index 21b0b8c8ba3f..41d6bad6bcc8 100644 --- a/internal/generated/snippets/asset/apiv1p2beta1/snippet_metadata.google.cloud.asset.v1p2beta1.json +++ b/internal/generated/snippets/asset/apiv1p2beta1/snippet_metadata.google.cloud.asset.v1p2beta1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/asset/apiv1p2beta1", - "version": "1.20.3", + "version": "1.20.4", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/asset/apiv1p5beta1/Client/ListAssets/main.go b/internal/generated/snippets/asset/apiv1p5beta1/Client/ListAssets/main.go index cf2ab8183bfd..44d4f4803597 100644 --- a/internal/generated/snippets/asset/apiv1p5beta1/Client/ListAssets/main.go +++ b/internal/generated/snippets/asset/apiv1p5beta1/Client/ListAssets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/asset/apiv1p5beta1/snippet_metadata.google.cloud.asset.v1p5beta1.json b/internal/generated/snippets/asset/apiv1p5beta1/snippet_metadata.google.cloud.asset.v1p5beta1.json index e0e204e32edd..1e1ebf0ed94e 100644 --- a/internal/generated/snippets/asset/apiv1p5beta1/snippet_metadata.google.cloud.asset.v1p5beta1.json +++ b/internal/generated/snippets/asset/apiv1p5beta1/snippet_metadata.google.cloud.asset.v1p5beta1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/asset/apiv1p5beta1", - "version": "1.20.3", + "version": "1.20.4", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/assuredworkloads/apiv1/Client/AcknowledgeViolation/main.go b/internal/generated/snippets/assuredworkloads/apiv1/Client/AcknowledgeViolation/main.go index 9e38189f46f5..3ffeb33460ec 100644 --- a/internal/generated/snippets/assuredworkloads/apiv1/Client/AcknowledgeViolation/main.go +++ b/internal/generated/snippets/assuredworkloads/apiv1/Client/AcknowledgeViolation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/assuredworkloads/apiv1/Client/CreateWorkload/main.go b/internal/generated/snippets/assuredworkloads/apiv1/Client/CreateWorkload/main.go index 2f2a895f57a5..b2635867fcde 100644 --- a/internal/generated/snippets/assuredworkloads/apiv1/Client/CreateWorkload/main.go +++ b/internal/generated/snippets/assuredworkloads/apiv1/Client/CreateWorkload/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/assuredworkloads/apiv1/Client/DeleteWorkload/main.go b/internal/generated/snippets/assuredworkloads/apiv1/Client/DeleteWorkload/main.go index 786d837c5bd6..81fb8810cc95 100644 --- a/internal/generated/snippets/assuredworkloads/apiv1/Client/DeleteWorkload/main.go +++ b/internal/generated/snippets/assuredworkloads/apiv1/Client/DeleteWorkload/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/assuredworkloads/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/assuredworkloads/apiv1/Client/GetOperation/main.go index f8576daf8b09..8c6d5a8b1272 100644 --- a/internal/generated/snippets/assuredworkloads/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/assuredworkloads/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/assuredworkloads/apiv1/Client/GetViolation/main.go b/internal/generated/snippets/assuredworkloads/apiv1/Client/GetViolation/main.go index 66acf1817c26..0f34256ad7e4 100644 --- a/internal/generated/snippets/assuredworkloads/apiv1/Client/GetViolation/main.go +++ b/internal/generated/snippets/assuredworkloads/apiv1/Client/GetViolation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/assuredworkloads/apiv1/Client/GetWorkload/main.go b/internal/generated/snippets/assuredworkloads/apiv1/Client/GetWorkload/main.go index 2f24889a3fdc..115b69b9a5de 100644 --- a/internal/generated/snippets/assuredworkloads/apiv1/Client/GetWorkload/main.go +++ b/internal/generated/snippets/assuredworkloads/apiv1/Client/GetWorkload/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/assuredworkloads/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/assuredworkloads/apiv1/Client/ListOperations/main.go index 855022a0eae9..12f4ca49f036 100644 --- a/internal/generated/snippets/assuredworkloads/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/assuredworkloads/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/assuredworkloads/apiv1/Client/ListViolations/main.go b/internal/generated/snippets/assuredworkloads/apiv1/Client/ListViolations/main.go index 57c21d17e477..4781d37eb26d 100644 --- a/internal/generated/snippets/assuredworkloads/apiv1/Client/ListViolations/main.go +++ b/internal/generated/snippets/assuredworkloads/apiv1/Client/ListViolations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/assuredworkloads/apiv1/Client/ListWorkloads/main.go b/internal/generated/snippets/assuredworkloads/apiv1/Client/ListWorkloads/main.go index d9fb056891c1..6442f18d60d5 100644 --- a/internal/generated/snippets/assuredworkloads/apiv1/Client/ListWorkloads/main.go +++ b/internal/generated/snippets/assuredworkloads/apiv1/Client/ListWorkloads/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/assuredworkloads/apiv1/Client/RestrictAllowedResources/main.go b/internal/generated/snippets/assuredworkloads/apiv1/Client/RestrictAllowedResources/main.go index 0cfbb6f4f14a..25f2148f8361 100644 --- a/internal/generated/snippets/assuredworkloads/apiv1/Client/RestrictAllowedResources/main.go +++ b/internal/generated/snippets/assuredworkloads/apiv1/Client/RestrictAllowedResources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/assuredworkloads/apiv1/Client/UpdateWorkload/main.go b/internal/generated/snippets/assuredworkloads/apiv1/Client/UpdateWorkload/main.go index c936be20f8df..7d5e2c2261bf 100644 --- a/internal/generated/snippets/assuredworkloads/apiv1/Client/UpdateWorkload/main.go +++ b/internal/generated/snippets/assuredworkloads/apiv1/Client/UpdateWorkload/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/AnalyzeWorkloadMove/main.go b/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/AnalyzeWorkloadMove/main.go index fa6d2c455e38..b7091d3d2b6c 100644 --- a/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/AnalyzeWorkloadMove/main.go +++ b/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/AnalyzeWorkloadMove/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/CreateWorkload/main.go b/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/CreateWorkload/main.go index 8efbe4cded8a..c36a9f7d5af7 100644 --- a/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/CreateWorkload/main.go +++ b/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/CreateWorkload/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/DeleteWorkload/main.go b/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/DeleteWorkload/main.go index 5eba07eab413..60a5ae835d6b 100644 --- a/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/DeleteWorkload/main.go +++ b/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/DeleteWorkload/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/GetOperation/main.go b/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/GetOperation/main.go index 982552f94d6e..f98eef5ee19d 100644 --- a/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/GetOperation/main.go +++ b/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/GetWorkload/main.go b/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/GetWorkload/main.go index 1559b65977fe..197486b86d90 100644 --- a/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/GetWorkload/main.go +++ b/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/GetWorkload/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/ListOperations/main.go b/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/ListOperations/main.go index 47ad65e2c054..6331295fc7fe 100644 --- a/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/ListOperations/main.go +++ b/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/ListWorkloads/main.go b/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/ListWorkloads/main.go index 0f65d6446dd8..3e01a0cfe1c1 100644 --- a/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/ListWorkloads/main.go +++ b/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/ListWorkloads/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/RestrictAllowedResources/main.go b/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/RestrictAllowedResources/main.go index 189816d8998f..97553d767316 100644 --- a/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/RestrictAllowedResources/main.go +++ b/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/RestrictAllowedResources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/UpdateWorkload/main.go b/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/UpdateWorkload/main.go index 6f80c54c586d..727295ed4d1b 100644 --- a/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/UpdateWorkload/main.go +++ b/internal/generated/snippets/assuredworkloads/apiv1beta1/Client/UpdateWorkload/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1/Client/CreateDataset/main.go b/internal/generated/snippets/automl/apiv1/Client/CreateDataset/main.go index 957d045272c3..c9fcec2cf26c 100644 --- a/internal/generated/snippets/automl/apiv1/Client/CreateDataset/main.go +++ b/internal/generated/snippets/automl/apiv1/Client/CreateDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1/Client/CreateModel/main.go b/internal/generated/snippets/automl/apiv1/Client/CreateModel/main.go index 7892a8dc3dc5..8df20347a1f9 100644 --- a/internal/generated/snippets/automl/apiv1/Client/CreateModel/main.go +++ b/internal/generated/snippets/automl/apiv1/Client/CreateModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1/Client/DeleteDataset/main.go b/internal/generated/snippets/automl/apiv1/Client/DeleteDataset/main.go index 23bb9adbab44..94e277dbdc30 100644 --- a/internal/generated/snippets/automl/apiv1/Client/DeleteDataset/main.go +++ b/internal/generated/snippets/automl/apiv1/Client/DeleteDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1/Client/DeleteModel/main.go b/internal/generated/snippets/automl/apiv1/Client/DeleteModel/main.go index 390fc8972f04..fdf54c109d84 100644 --- a/internal/generated/snippets/automl/apiv1/Client/DeleteModel/main.go +++ b/internal/generated/snippets/automl/apiv1/Client/DeleteModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1/Client/DeployModel/main.go b/internal/generated/snippets/automl/apiv1/Client/DeployModel/main.go index dde9ab7edcd2..ab8ba8d6084d 100644 --- a/internal/generated/snippets/automl/apiv1/Client/DeployModel/main.go +++ b/internal/generated/snippets/automl/apiv1/Client/DeployModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1/Client/ExportData/main.go b/internal/generated/snippets/automl/apiv1/Client/ExportData/main.go index 67f1a96eec5c..3f29444cf0d5 100644 --- a/internal/generated/snippets/automl/apiv1/Client/ExportData/main.go +++ b/internal/generated/snippets/automl/apiv1/Client/ExportData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1/Client/ExportModel/main.go b/internal/generated/snippets/automl/apiv1/Client/ExportModel/main.go index a72cf73ac15a..bb5d7f1629c4 100644 --- a/internal/generated/snippets/automl/apiv1/Client/ExportModel/main.go +++ b/internal/generated/snippets/automl/apiv1/Client/ExportModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1/Client/GetAnnotationSpec/main.go b/internal/generated/snippets/automl/apiv1/Client/GetAnnotationSpec/main.go index f9cdd5e6f270..38cb41b54028 100644 --- a/internal/generated/snippets/automl/apiv1/Client/GetAnnotationSpec/main.go +++ b/internal/generated/snippets/automl/apiv1/Client/GetAnnotationSpec/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1/Client/GetDataset/main.go b/internal/generated/snippets/automl/apiv1/Client/GetDataset/main.go index f35af131e549..40f1dc2c5d1d 100644 --- a/internal/generated/snippets/automl/apiv1/Client/GetDataset/main.go +++ b/internal/generated/snippets/automl/apiv1/Client/GetDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1/Client/GetModel/main.go b/internal/generated/snippets/automl/apiv1/Client/GetModel/main.go index cec35e67e970..59e1b403a29b 100644 --- a/internal/generated/snippets/automl/apiv1/Client/GetModel/main.go +++ b/internal/generated/snippets/automl/apiv1/Client/GetModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1/Client/GetModelEvaluation/main.go b/internal/generated/snippets/automl/apiv1/Client/GetModelEvaluation/main.go index 255d35d236af..08e5eb97715d 100644 --- a/internal/generated/snippets/automl/apiv1/Client/GetModelEvaluation/main.go +++ b/internal/generated/snippets/automl/apiv1/Client/GetModelEvaluation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1/Client/ImportData/main.go b/internal/generated/snippets/automl/apiv1/Client/ImportData/main.go index 9bedd53404e4..f938afcac38b 100644 --- a/internal/generated/snippets/automl/apiv1/Client/ImportData/main.go +++ b/internal/generated/snippets/automl/apiv1/Client/ImportData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1/Client/ListDatasets/main.go b/internal/generated/snippets/automl/apiv1/Client/ListDatasets/main.go index 5ff640c1ab55..799df1ef55d4 100644 --- a/internal/generated/snippets/automl/apiv1/Client/ListDatasets/main.go +++ b/internal/generated/snippets/automl/apiv1/Client/ListDatasets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1/Client/ListModelEvaluations/main.go b/internal/generated/snippets/automl/apiv1/Client/ListModelEvaluations/main.go index 1fbef1c12890..4cb1e709ed76 100644 --- a/internal/generated/snippets/automl/apiv1/Client/ListModelEvaluations/main.go +++ b/internal/generated/snippets/automl/apiv1/Client/ListModelEvaluations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1/Client/ListModels/main.go b/internal/generated/snippets/automl/apiv1/Client/ListModels/main.go index 695ca0ac377f..3f480a788dc5 100644 --- a/internal/generated/snippets/automl/apiv1/Client/ListModels/main.go +++ b/internal/generated/snippets/automl/apiv1/Client/ListModels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1/Client/UndeployModel/main.go b/internal/generated/snippets/automl/apiv1/Client/UndeployModel/main.go index bf9b583e6316..fc4ab85a9447 100644 --- a/internal/generated/snippets/automl/apiv1/Client/UndeployModel/main.go +++ b/internal/generated/snippets/automl/apiv1/Client/UndeployModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1/Client/UpdateDataset/main.go b/internal/generated/snippets/automl/apiv1/Client/UpdateDataset/main.go index 9b1a21eb6345..d71594c0bc23 100644 --- a/internal/generated/snippets/automl/apiv1/Client/UpdateDataset/main.go +++ b/internal/generated/snippets/automl/apiv1/Client/UpdateDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1/Client/UpdateModel/main.go b/internal/generated/snippets/automl/apiv1/Client/UpdateModel/main.go index 2c80f31a04d9..72105634e629 100644 --- a/internal/generated/snippets/automl/apiv1/Client/UpdateModel/main.go +++ b/internal/generated/snippets/automl/apiv1/Client/UpdateModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1/PredictionClient/BatchPredict/main.go b/internal/generated/snippets/automl/apiv1/PredictionClient/BatchPredict/main.go index 4bc751d773f1..7a537deb3e6f 100644 --- a/internal/generated/snippets/automl/apiv1/PredictionClient/BatchPredict/main.go +++ b/internal/generated/snippets/automl/apiv1/PredictionClient/BatchPredict/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1/PredictionClient/Predict/main.go b/internal/generated/snippets/automl/apiv1/PredictionClient/Predict/main.go index 430854235bee..db7f8669154e 100644 --- a/internal/generated/snippets/automl/apiv1/PredictionClient/Predict/main.go +++ b/internal/generated/snippets/automl/apiv1/PredictionClient/Predict/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1beta1/Client/CreateDataset/main.go b/internal/generated/snippets/automl/apiv1beta1/Client/CreateDataset/main.go index 8a0f8902353a..14987463e4cc 100644 --- a/internal/generated/snippets/automl/apiv1beta1/Client/CreateDataset/main.go +++ b/internal/generated/snippets/automl/apiv1beta1/Client/CreateDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1beta1/Client/CreateModel/main.go b/internal/generated/snippets/automl/apiv1beta1/Client/CreateModel/main.go index 0638190fc180..f09b7bcd9cde 100644 --- a/internal/generated/snippets/automl/apiv1beta1/Client/CreateModel/main.go +++ b/internal/generated/snippets/automl/apiv1beta1/Client/CreateModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1beta1/Client/DeleteDataset/main.go b/internal/generated/snippets/automl/apiv1beta1/Client/DeleteDataset/main.go index 44a1f1bec8ea..3fb00508d39b 100644 --- a/internal/generated/snippets/automl/apiv1beta1/Client/DeleteDataset/main.go +++ b/internal/generated/snippets/automl/apiv1beta1/Client/DeleteDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1beta1/Client/DeleteModel/main.go b/internal/generated/snippets/automl/apiv1beta1/Client/DeleteModel/main.go index 72d77dbdbbd7..18cbc72cdacf 100644 --- a/internal/generated/snippets/automl/apiv1beta1/Client/DeleteModel/main.go +++ b/internal/generated/snippets/automl/apiv1beta1/Client/DeleteModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1beta1/Client/DeployModel/main.go b/internal/generated/snippets/automl/apiv1beta1/Client/DeployModel/main.go index 1bd173d86c14..7ae011a8fd90 100644 --- a/internal/generated/snippets/automl/apiv1beta1/Client/DeployModel/main.go +++ b/internal/generated/snippets/automl/apiv1beta1/Client/DeployModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1beta1/Client/ExportData/main.go b/internal/generated/snippets/automl/apiv1beta1/Client/ExportData/main.go index 8b59ba7802af..a59f93f73b62 100644 --- a/internal/generated/snippets/automl/apiv1beta1/Client/ExportData/main.go +++ b/internal/generated/snippets/automl/apiv1beta1/Client/ExportData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1beta1/Client/ExportEvaluatedExamples/main.go b/internal/generated/snippets/automl/apiv1beta1/Client/ExportEvaluatedExamples/main.go index 25dda05986a2..3be8dec61715 100644 --- a/internal/generated/snippets/automl/apiv1beta1/Client/ExportEvaluatedExamples/main.go +++ b/internal/generated/snippets/automl/apiv1beta1/Client/ExportEvaluatedExamples/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1beta1/Client/ExportModel/main.go b/internal/generated/snippets/automl/apiv1beta1/Client/ExportModel/main.go index 074ee4c25732..2d317954b83c 100644 --- a/internal/generated/snippets/automl/apiv1beta1/Client/ExportModel/main.go +++ b/internal/generated/snippets/automl/apiv1beta1/Client/ExportModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1beta1/Client/GetAnnotationSpec/main.go b/internal/generated/snippets/automl/apiv1beta1/Client/GetAnnotationSpec/main.go index 1cff634af8de..549ee72190d5 100644 --- a/internal/generated/snippets/automl/apiv1beta1/Client/GetAnnotationSpec/main.go +++ b/internal/generated/snippets/automl/apiv1beta1/Client/GetAnnotationSpec/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1beta1/Client/GetColumnSpec/main.go b/internal/generated/snippets/automl/apiv1beta1/Client/GetColumnSpec/main.go index 80d05940e6ef..ef75eae053c1 100644 --- a/internal/generated/snippets/automl/apiv1beta1/Client/GetColumnSpec/main.go +++ b/internal/generated/snippets/automl/apiv1beta1/Client/GetColumnSpec/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1beta1/Client/GetDataset/main.go b/internal/generated/snippets/automl/apiv1beta1/Client/GetDataset/main.go index 24403e44bdd0..b0e75526c92d 100644 --- a/internal/generated/snippets/automl/apiv1beta1/Client/GetDataset/main.go +++ b/internal/generated/snippets/automl/apiv1beta1/Client/GetDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1beta1/Client/GetModel/main.go b/internal/generated/snippets/automl/apiv1beta1/Client/GetModel/main.go index ce75bec4b2bf..edf3897b9253 100644 --- a/internal/generated/snippets/automl/apiv1beta1/Client/GetModel/main.go +++ b/internal/generated/snippets/automl/apiv1beta1/Client/GetModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1beta1/Client/GetModelEvaluation/main.go b/internal/generated/snippets/automl/apiv1beta1/Client/GetModelEvaluation/main.go index 186f6b5ffef0..00987b6f7ead 100644 --- a/internal/generated/snippets/automl/apiv1beta1/Client/GetModelEvaluation/main.go +++ b/internal/generated/snippets/automl/apiv1beta1/Client/GetModelEvaluation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1beta1/Client/GetTableSpec/main.go b/internal/generated/snippets/automl/apiv1beta1/Client/GetTableSpec/main.go index 46f19c1720f9..4535eef37c00 100644 --- a/internal/generated/snippets/automl/apiv1beta1/Client/GetTableSpec/main.go +++ b/internal/generated/snippets/automl/apiv1beta1/Client/GetTableSpec/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1beta1/Client/ImportData/main.go b/internal/generated/snippets/automl/apiv1beta1/Client/ImportData/main.go index b1e217ee0626..e0b31c095aa9 100644 --- a/internal/generated/snippets/automl/apiv1beta1/Client/ImportData/main.go +++ b/internal/generated/snippets/automl/apiv1beta1/Client/ImportData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1beta1/Client/ListColumnSpecs/main.go b/internal/generated/snippets/automl/apiv1beta1/Client/ListColumnSpecs/main.go index 1332fd56a0aa..1bf59ee0a7cd 100644 --- a/internal/generated/snippets/automl/apiv1beta1/Client/ListColumnSpecs/main.go +++ b/internal/generated/snippets/automl/apiv1beta1/Client/ListColumnSpecs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1beta1/Client/ListDatasets/main.go b/internal/generated/snippets/automl/apiv1beta1/Client/ListDatasets/main.go index b4514776b279..36ac58536afe 100644 --- a/internal/generated/snippets/automl/apiv1beta1/Client/ListDatasets/main.go +++ b/internal/generated/snippets/automl/apiv1beta1/Client/ListDatasets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1beta1/Client/ListModelEvaluations/main.go b/internal/generated/snippets/automl/apiv1beta1/Client/ListModelEvaluations/main.go index e3276cb045d9..752f127e54b2 100644 --- a/internal/generated/snippets/automl/apiv1beta1/Client/ListModelEvaluations/main.go +++ b/internal/generated/snippets/automl/apiv1beta1/Client/ListModelEvaluations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1beta1/Client/ListModels/main.go b/internal/generated/snippets/automl/apiv1beta1/Client/ListModels/main.go index c7115a71ae7d..8a1da9b53d23 100644 --- a/internal/generated/snippets/automl/apiv1beta1/Client/ListModels/main.go +++ b/internal/generated/snippets/automl/apiv1beta1/Client/ListModels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1beta1/Client/ListTableSpecs/main.go b/internal/generated/snippets/automl/apiv1beta1/Client/ListTableSpecs/main.go index 94403d8b3a00..90ea69164d89 100644 --- a/internal/generated/snippets/automl/apiv1beta1/Client/ListTableSpecs/main.go +++ b/internal/generated/snippets/automl/apiv1beta1/Client/ListTableSpecs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1beta1/Client/UndeployModel/main.go b/internal/generated/snippets/automl/apiv1beta1/Client/UndeployModel/main.go index 519d89cccba2..65e95ef10e9e 100644 --- a/internal/generated/snippets/automl/apiv1beta1/Client/UndeployModel/main.go +++ b/internal/generated/snippets/automl/apiv1beta1/Client/UndeployModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1beta1/Client/UpdateColumnSpec/main.go b/internal/generated/snippets/automl/apiv1beta1/Client/UpdateColumnSpec/main.go index ab525c20f628..579b049819ca 100644 --- a/internal/generated/snippets/automl/apiv1beta1/Client/UpdateColumnSpec/main.go +++ b/internal/generated/snippets/automl/apiv1beta1/Client/UpdateColumnSpec/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1beta1/Client/UpdateDataset/main.go b/internal/generated/snippets/automl/apiv1beta1/Client/UpdateDataset/main.go index 93d0be09934d..c591ef97c163 100644 --- a/internal/generated/snippets/automl/apiv1beta1/Client/UpdateDataset/main.go +++ b/internal/generated/snippets/automl/apiv1beta1/Client/UpdateDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1beta1/Client/UpdateTableSpec/main.go b/internal/generated/snippets/automl/apiv1beta1/Client/UpdateTableSpec/main.go index 1c6bbe150840..c0654305607b 100644 --- a/internal/generated/snippets/automl/apiv1beta1/Client/UpdateTableSpec/main.go +++ b/internal/generated/snippets/automl/apiv1beta1/Client/UpdateTableSpec/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1beta1/PredictionClient/BatchPredict/main.go b/internal/generated/snippets/automl/apiv1beta1/PredictionClient/BatchPredict/main.go index 974c1a08a27b..9c6d1efbe83f 100644 --- a/internal/generated/snippets/automl/apiv1beta1/PredictionClient/BatchPredict/main.go +++ b/internal/generated/snippets/automl/apiv1beta1/PredictionClient/BatchPredict/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/automl/apiv1beta1/PredictionClient/Predict/main.go b/internal/generated/snippets/automl/apiv1beta1/PredictionClient/Predict/main.go index a1e7d404ca79..de0e0340820e 100644 --- a/internal/generated/snippets/automl/apiv1beta1/PredictionClient/Predict/main.go +++ b/internal/generated/snippets/automl/apiv1beta1/PredictionClient/Predict/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/backupdr/apiv1/Client/CancelOperation/main.go index 494d31199406..216bd5fd7aa7 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/CreateBackupPlan/main.go b/internal/generated/snippets/backupdr/apiv1/Client/CreateBackupPlan/main.go index 8f24df95e251..0e8c289a4aa6 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/CreateBackupPlan/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/CreateBackupPlan/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/CreateBackupPlanAssociation/main.go b/internal/generated/snippets/backupdr/apiv1/Client/CreateBackupPlanAssociation/main.go index 090d70e2a58b..c50ec53adc25 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/CreateBackupPlanAssociation/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/CreateBackupPlanAssociation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/CreateBackupVault/main.go b/internal/generated/snippets/backupdr/apiv1/Client/CreateBackupVault/main.go index dbe5a8c07059..9c45be4da6c8 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/CreateBackupVault/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/CreateBackupVault/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/CreateManagementServer/main.go b/internal/generated/snippets/backupdr/apiv1/Client/CreateManagementServer/main.go index 1d91a5ae1264..bb220e45939b 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/CreateManagementServer/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/CreateManagementServer/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/DeleteBackup/main.go b/internal/generated/snippets/backupdr/apiv1/Client/DeleteBackup/main.go index 97e4315945b5..c370d8345183 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/DeleteBackup/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/DeleteBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/DeleteBackupPlan/main.go b/internal/generated/snippets/backupdr/apiv1/Client/DeleteBackupPlan/main.go index 4747142d3075..126a4d8ca550 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/DeleteBackupPlan/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/DeleteBackupPlan/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/DeleteBackupPlanAssociation/main.go b/internal/generated/snippets/backupdr/apiv1/Client/DeleteBackupPlanAssociation/main.go index 930018cdcc75..7a9d4abc9b4d 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/DeleteBackupPlanAssociation/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/DeleteBackupPlanAssociation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/DeleteBackupVault/main.go b/internal/generated/snippets/backupdr/apiv1/Client/DeleteBackupVault/main.go index 256dd0aac82f..e8163cc2f33d 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/DeleteBackupVault/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/DeleteBackupVault/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/DeleteManagementServer/main.go b/internal/generated/snippets/backupdr/apiv1/Client/DeleteManagementServer/main.go index f4d60d276140..f720da1b9300 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/DeleteManagementServer/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/DeleteManagementServer/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/backupdr/apiv1/Client/DeleteOperation/main.go index 56fe962d8087..9d3e46ae7168 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/FetchUsableBackupVaults/main.go b/internal/generated/snippets/backupdr/apiv1/Client/FetchUsableBackupVaults/main.go index 73798e07867a..6aff6df1cc36 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/FetchUsableBackupVaults/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/FetchUsableBackupVaults/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/GetBackup/main.go b/internal/generated/snippets/backupdr/apiv1/Client/GetBackup/main.go index e7a2f27d7988..dab684cb9b20 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/GetBackup/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/GetBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/GetBackupPlan/main.go b/internal/generated/snippets/backupdr/apiv1/Client/GetBackupPlan/main.go index 2037569041ad..d66ebdb6e966 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/GetBackupPlan/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/GetBackupPlan/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/GetBackupPlanAssociation/main.go b/internal/generated/snippets/backupdr/apiv1/Client/GetBackupPlanAssociation/main.go index e9f474d0a678..9c84ca067311 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/GetBackupPlanAssociation/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/GetBackupPlanAssociation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/GetBackupVault/main.go b/internal/generated/snippets/backupdr/apiv1/Client/GetBackupVault/main.go index 43512c2c823a..54962b74f7c0 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/GetBackupVault/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/GetBackupVault/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/GetDataSource/main.go b/internal/generated/snippets/backupdr/apiv1/Client/GetDataSource/main.go index 2262ad05a4b0..e8e95344be1b 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/GetDataSource/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/GetDataSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/GetIamPolicy/main.go b/internal/generated/snippets/backupdr/apiv1/Client/GetIamPolicy/main.go index b2ab240d0721..8b5fdd2eb9db 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/backupdr/apiv1/Client/GetLocation/main.go index 6fde44f23aac..dc9977e7bf10 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/GetManagementServer/main.go b/internal/generated/snippets/backupdr/apiv1/Client/GetManagementServer/main.go index c1de362f69af..0cf5b5c2e4fd 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/GetManagementServer/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/GetManagementServer/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/backupdr/apiv1/Client/GetOperation/main.go index 8452a2017734..23b69786eac5 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/ListBackupPlanAssociations/main.go b/internal/generated/snippets/backupdr/apiv1/Client/ListBackupPlanAssociations/main.go index 3077c3a9e6cf..626ecc0d1b68 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/ListBackupPlanAssociations/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/ListBackupPlanAssociations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/ListBackupPlans/main.go b/internal/generated/snippets/backupdr/apiv1/Client/ListBackupPlans/main.go index f43a8854d148..ab984a653581 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/ListBackupPlans/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/ListBackupPlans/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/ListBackupVaults/main.go b/internal/generated/snippets/backupdr/apiv1/Client/ListBackupVaults/main.go index e1440a3e7ad5..8d5603c87dd6 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/ListBackupVaults/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/ListBackupVaults/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/ListBackups/main.go b/internal/generated/snippets/backupdr/apiv1/Client/ListBackups/main.go index b72e7dea7f8f..9ee5981a65fe 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/ListBackups/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/ListBackups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/ListDataSources/main.go b/internal/generated/snippets/backupdr/apiv1/Client/ListDataSources/main.go index da948cceb528..7e42b3dd6c76 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/ListDataSources/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/ListDataSources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/backupdr/apiv1/Client/ListLocations/main.go index 45a5491efa58..1d4c109dc8f3 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/ListManagementServers/main.go b/internal/generated/snippets/backupdr/apiv1/Client/ListManagementServers/main.go index 7c669f7f8c70..7bf34221eff4 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/ListManagementServers/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/ListManagementServers/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/backupdr/apiv1/Client/ListOperations/main.go index 2491cfe560fd..a605213ea89f 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/RestoreBackup/main.go b/internal/generated/snippets/backupdr/apiv1/Client/RestoreBackup/main.go index 90e2fa4f1d0b..9243cb7b52a8 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/RestoreBackup/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/RestoreBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/SetIamPolicy/main.go b/internal/generated/snippets/backupdr/apiv1/Client/SetIamPolicy/main.go index e3589292f747..51ffa1b6e858 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/TestIamPermissions/main.go b/internal/generated/snippets/backupdr/apiv1/Client/TestIamPermissions/main.go index 9fe89b95b6d2..90ab78520fe9 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/TriggerBackup/main.go b/internal/generated/snippets/backupdr/apiv1/Client/TriggerBackup/main.go index d75ac4550e69..bdcd7a732374 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/TriggerBackup/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/TriggerBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/UpdateBackup/main.go b/internal/generated/snippets/backupdr/apiv1/Client/UpdateBackup/main.go index 63a150792a51..ee4ff1b08787 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/UpdateBackup/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/UpdateBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/UpdateBackupVault/main.go b/internal/generated/snippets/backupdr/apiv1/Client/UpdateBackupVault/main.go index 64adad067c47..1de8746db98c 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/UpdateBackupVault/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/UpdateBackupVault/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/Client/UpdateDataSource/main.go b/internal/generated/snippets/backupdr/apiv1/Client/UpdateDataSource/main.go index 2157a270324a..b0361ea8e78b 100644 --- a/internal/generated/snippets/backupdr/apiv1/Client/UpdateDataSource/main.go +++ b/internal/generated/snippets/backupdr/apiv1/Client/UpdateDataSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/backupdr/apiv1/snippet_metadata.google.cloud.backupdr.v1.json b/internal/generated/snippets/backupdr/apiv1/snippet_metadata.google.cloud.backupdr.v1.json index 6ea0109c1832..7c92b7b06e78 100644 --- a/internal/generated/snippets/backupdr/apiv1/snippet_metadata.google.cloud.backupdr.v1.json +++ b/internal/generated/snippets/backupdr/apiv1/snippet_metadata.google.cloud.backupdr.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/backupdr/apiv1", - "version": "1.2.1", + "version": "1.2.2", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/CreateNfsShare/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/CreateNfsShare/main.go index 9ec37cbabe54..4271891fea9f 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/CreateNfsShare/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/CreateNfsShare/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/CreateProvisioningConfig/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/CreateProvisioningConfig/main.go index 39a0fb534bca..fb1cebf02d7d 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/CreateProvisioningConfig/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/CreateProvisioningConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/CreateSSHKey/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/CreateSSHKey/main.go index 8adb75366eac..21f43132d359 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/CreateSSHKey/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/CreateSSHKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/CreateVolumeSnapshot/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/CreateVolumeSnapshot/main.go index f470441be268..cdcbef1b30eb 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/CreateVolumeSnapshot/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/CreateVolumeSnapshot/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/DeleteNfsShare/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/DeleteNfsShare/main.go index 2cf5b35cf760..30f532d14a2e 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/DeleteNfsShare/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/DeleteNfsShare/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/DeleteSSHKey/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/DeleteSSHKey/main.go index c8793d4ae0d9..2976a769b5c3 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/DeleteSSHKey/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/DeleteSSHKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/DeleteVolumeSnapshot/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/DeleteVolumeSnapshot/main.go index f8395dcda304..893e4db35c4c 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/DeleteVolumeSnapshot/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/DeleteVolumeSnapshot/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/DetachLun/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/DetachLun/main.go index ab44f8113429..d59f14b48863 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/DetachLun/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/DetachLun/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/DisableInteractiveSerialConsole/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/DisableInteractiveSerialConsole/main.go index 4f4328f84a49..c61bfcb93d70 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/DisableInteractiveSerialConsole/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/DisableInteractiveSerialConsole/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/EnableInteractiveSerialConsole/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/EnableInteractiveSerialConsole/main.go index c885b99ff2ef..ae50b6f65520 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/EnableInteractiveSerialConsole/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/EnableInteractiveSerialConsole/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/EvictLun/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/EvictLun/main.go index 12920f23e839..eabc23e069d8 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/EvictLun/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/EvictLun/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/EvictVolume/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/EvictVolume/main.go index e75fc8ea936f..6793dbdcc796 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/EvictVolume/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/EvictVolume/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/GetInstance/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/GetInstance/main.go index 7ae8f8ff0625..dba2c28dccfd 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/GetInstance/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/GetInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/GetLocation/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/GetLocation/main.go index 09ab84b33c48..8b6cdbbe3b5d 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/GetLocation/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/GetLun/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/GetLun/main.go index 4e9d146d313e..6fefbeccbe42 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/GetLun/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/GetLun/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/GetNetwork/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/GetNetwork/main.go index 085a05e8d06b..2fdc632b9d7f 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/GetNetwork/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/GetNetwork/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/GetNfsShare/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/GetNfsShare/main.go index 325527caf17e..b28c895ec701 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/GetNfsShare/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/GetNfsShare/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/GetProvisioningConfig/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/GetProvisioningConfig/main.go index 46cea11d3cc4..2e82637309ee 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/GetProvisioningConfig/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/GetProvisioningConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/GetVolume/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/GetVolume/main.go index dd98df5929fb..c085ad3003f2 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/GetVolume/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/GetVolume/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/GetVolumeSnapshot/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/GetVolumeSnapshot/main.go index efc1e2dd4afb..98f0124fdb79 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/GetVolumeSnapshot/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/GetVolumeSnapshot/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/ListInstances/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/ListInstances/main.go index 46759285df68..0ed073dde7e8 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/ListInstances/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/ListInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/ListLocations/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/ListLocations/main.go index 86a60b6fdc57..6ed8461b7a9d 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/ListLocations/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/ListLuns/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/ListLuns/main.go index 1e1cfabaf15b..0aaf9e565cfa 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/ListLuns/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/ListLuns/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/ListNetworkUsage/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/ListNetworkUsage/main.go index c1bc848c1406..ede83365bd00 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/ListNetworkUsage/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/ListNetworkUsage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/ListNetworks/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/ListNetworks/main.go index 94dded1af6f2..5c14c97fcd21 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/ListNetworks/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/ListNetworks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/ListNfsShares/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/ListNfsShares/main.go index 4244a275512a..0da245365ebf 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/ListNfsShares/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/ListNfsShares/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/ListOSImages/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/ListOSImages/main.go index d9fa5f13a700..932debe53441 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/ListOSImages/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/ListOSImages/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/ListProvisioningQuotas/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/ListProvisioningQuotas/main.go index b281292a470b..d28902846424 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/ListProvisioningQuotas/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/ListProvisioningQuotas/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/ListSSHKeys/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/ListSSHKeys/main.go index b646c6032d55..cd7a7d0277fd 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/ListSSHKeys/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/ListSSHKeys/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/ListVolumeSnapshots/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/ListVolumeSnapshots/main.go index 84fbbd0e4638..987e7dc29000 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/ListVolumeSnapshots/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/ListVolumeSnapshots/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/ListVolumes/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/ListVolumes/main.go index 170d8a9dd10e..722b25925913 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/ListVolumes/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/ListVolumes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/RenameInstance/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/RenameInstance/main.go index 966c7cb08ce6..c366859242f1 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/RenameInstance/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/RenameInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/RenameNetwork/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/RenameNetwork/main.go index 75bdf184d7b2..5b8e62582ada 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/RenameNetwork/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/RenameNetwork/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/RenameNfsShare/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/RenameNfsShare/main.go index 9a92130c5e20..d29cff20193f 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/RenameNfsShare/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/RenameNfsShare/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/RenameVolume/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/RenameVolume/main.go index 25259eaf720a..4d7bfd6083f0 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/RenameVolume/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/RenameVolume/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/ResetInstance/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/ResetInstance/main.go index 21d9c6f11efb..d2f122275897 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/ResetInstance/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/ResetInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/ResizeVolume/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/ResizeVolume/main.go index 6fc8175db029..ace9923dc153 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/ResizeVolume/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/ResizeVolume/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/RestoreVolumeSnapshot/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/RestoreVolumeSnapshot/main.go index 8464114c5455..0dd0ca53ede6 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/RestoreVolumeSnapshot/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/RestoreVolumeSnapshot/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/StartInstance/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/StartInstance/main.go index f52513f12a57..0175c5381c0a 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/StartInstance/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/StartInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/StopInstance/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/StopInstance/main.go index 2a004484f098..8dbd1177b3dc 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/StopInstance/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/StopInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/SubmitProvisioningConfig/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/SubmitProvisioningConfig/main.go index e4dd7afa75e0..189b4c9d66f3 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/SubmitProvisioningConfig/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/SubmitProvisioningConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/UpdateInstance/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/UpdateInstance/main.go index 5e5405283465..19b25632d91a 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/UpdateInstance/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/UpdateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/UpdateNetwork/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/UpdateNetwork/main.go index 1e7d922be2e0..a9e707efd049 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/UpdateNetwork/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/UpdateNetwork/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/UpdateNfsShare/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/UpdateNfsShare/main.go index 3a53d50a16f8..6fb3de2a330d 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/UpdateNfsShare/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/UpdateNfsShare/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/UpdateProvisioningConfig/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/UpdateProvisioningConfig/main.go index a947340fc94f..0059d8554f5e 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/UpdateProvisioningConfig/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/UpdateProvisioningConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/baremetalsolution/apiv2/Client/UpdateVolume/main.go b/internal/generated/snippets/baremetalsolution/apiv2/Client/UpdateVolume/main.go index 89727571f6df..8c4b60066076 100644 --- a/internal/generated/snippets/baremetalsolution/apiv2/Client/UpdateVolume/main.go +++ b/internal/generated/snippets/baremetalsolution/apiv2/Client/UpdateVolume/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/batch/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/batch/apiv1/Client/CancelOperation/main.go index fdd68c9183d3..7deb293f4a67 100644 --- a/internal/generated/snippets/batch/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/batch/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/batch/apiv1/Client/CreateJob/main.go b/internal/generated/snippets/batch/apiv1/Client/CreateJob/main.go index fbf87283b30a..e4763663b6f1 100644 --- a/internal/generated/snippets/batch/apiv1/Client/CreateJob/main.go +++ b/internal/generated/snippets/batch/apiv1/Client/CreateJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/batch/apiv1/Client/DeleteJob/main.go b/internal/generated/snippets/batch/apiv1/Client/DeleteJob/main.go index 84e9d73f3340..832ce69a3009 100644 --- a/internal/generated/snippets/batch/apiv1/Client/DeleteJob/main.go +++ b/internal/generated/snippets/batch/apiv1/Client/DeleteJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/batch/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/batch/apiv1/Client/DeleteOperation/main.go index 834da5b2877b..207b481c41dd 100644 --- a/internal/generated/snippets/batch/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/batch/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/batch/apiv1/Client/GetJob/main.go b/internal/generated/snippets/batch/apiv1/Client/GetJob/main.go index fe264dbaea97..07fa83cde639 100644 --- a/internal/generated/snippets/batch/apiv1/Client/GetJob/main.go +++ b/internal/generated/snippets/batch/apiv1/Client/GetJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/batch/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/batch/apiv1/Client/GetLocation/main.go index ab0c9b6945d3..e240b5308271 100644 --- a/internal/generated/snippets/batch/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/batch/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/batch/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/batch/apiv1/Client/GetOperation/main.go index 4601542f2f5b..a6096021d930 100644 --- a/internal/generated/snippets/batch/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/batch/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/batch/apiv1/Client/GetTask/main.go b/internal/generated/snippets/batch/apiv1/Client/GetTask/main.go index 6fc9401e9550..9de0680adec2 100644 --- a/internal/generated/snippets/batch/apiv1/Client/GetTask/main.go +++ b/internal/generated/snippets/batch/apiv1/Client/GetTask/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/batch/apiv1/Client/ListJobs/main.go b/internal/generated/snippets/batch/apiv1/Client/ListJobs/main.go index dbfb7c0bca4d..d0bfe3577e7e 100644 --- a/internal/generated/snippets/batch/apiv1/Client/ListJobs/main.go +++ b/internal/generated/snippets/batch/apiv1/Client/ListJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/batch/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/batch/apiv1/Client/ListLocations/main.go index e0f661039623..035ad42405e5 100644 --- a/internal/generated/snippets/batch/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/batch/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/batch/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/batch/apiv1/Client/ListOperations/main.go index c7fe6030f412..96b5b49788b9 100644 --- a/internal/generated/snippets/batch/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/batch/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/batch/apiv1/Client/ListTasks/main.go b/internal/generated/snippets/batch/apiv1/Client/ListTasks/main.go index 807b76028767..9040ee9ec0aa 100644 --- a/internal/generated/snippets/batch/apiv1/Client/ListTasks/main.go +++ b/internal/generated/snippets/batch/apiv1/Client/ListTasks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/batch/apiv1/snippet_metadata.google.cloud.batch.v1.json b/internal/generated/snippets/batch/apiv1/snippet_metadata.google.cloud.batch.v1.json index d5164fadfc7c..98ab8b4ad623 100644 --- a/internal/generated/snippets/batch/apiv1/snippet_metadata.google.cloud.batch.v1.json +++ b/internal/generated/snippets/batch/apiv1/snippet_metadata.google.cloud.batch.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/batch/apiv1", - "version": "1.11.4", + "version": "1.11.5", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/CancelOperation/main.go index 4da4c87a5730..df56fd1f652f 100644 --- a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/CreateAppConnection/main.go b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/CreateAppConnection/main.go index dc1cb171385d..5fb2a73871d3 100644 --- a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/CreateAppConnection/main.go +++ b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/CreateAppConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/DeleteAppConnection/main.go b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/DeleteAppConnection/main.go index 1f10410f42e0..2bb7fb14b0b8 100644 --- a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/DeleteAppConnection/main.go +++ b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/DeleteAppConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/DeleteOperation/main.go index f2c85a5f6730..1f0d286f2984 100644 --- a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/GetAppConnection/main.go b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/GetAppConnection/main.go index 52564cf15223..f96edfa7ddba 100644 --- a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/GetAppConnection/main.go +++ b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/GetAppConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/GetIamPolicy/main.go b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/GetIamPolicy/main.go index e82a1ce40a46..6769de875607 100644 --- a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/GetLocation/main.go index 51f33ceb32cd..b753bc8eb86b 100644 --- a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/GetOperation/main.go index 04d03ed2467e..e7b332e7d7ae 100644 --- a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/ListAppConnections/main.go b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/ListAppConnections/main.go index d617e064efa4..42b89ca83b39 100644 --- a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/ListAppConnections/main.go +++ b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/ListAppConnections/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/ListLocations/main.go index fe53b0229c7f..476b9cd2410f 100644 --- a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/ListOperations/main.go index 1a26d1c51ef2..7040976b847a 100644 --- a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/ResolveAppConnections/main.go b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/ResolveAppConnections/main.go index 5e86cb4e4f62..3ed1a018fb19 100644 --- a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/ResolveAppConnections/main.go +++ b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/ResolveAppConnections/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/SetIamPolicy/main.go b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/SetIamPolicy/main.go index d34abe571829..f693f7d259a5 100644 --- a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/TestIamPermissions/main.go b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/TestIamPermissions/main.go index f46fb036c961..f098218afbbc 100644 --- a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/UpdateAppConnection/main.go b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/UpdateAppConnection/main.go index 2f2f8a61e4b9..763bf772be5b 100644 --- a/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/UpdateAppConnection/main.go +++ b/internal/generated/snippets/beyondcorp/appconnections/apiv1/Client/UpdateAppConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/CancelOperation/main.go index 941c2f954e37..7a58f13afbad 100644 --- a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/CreateAppConnector/main.go b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/CreateAppConnector/main.go index b1807e619b88..1a7433b9c90e 100644 --- a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/CreateAppConnector/main.go +++ b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/CreateAppConnector/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/DeleteAppConnector/main.go b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/DeleteAppConnector/main.go index fdb00d6f9335..e105171433c1 100644 --- a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/DeleteAppConnector/main.go +++ b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/DeleteAppConnector/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/DeleteOperation/main.go index 2d2ecc781d3a..5ed6ba492d59 100644 --- a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/GetAppConnector/main.go b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/GetAppConnector/main.go index ec9ff28025cd..49e394877317 100644 --- a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/GetAppConnector/main.go +++ b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/GetAppConnector/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/GetIamPolicy/main.go b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/GetIamPolicy/main.go index 7f49488d9274..fa4b6a7daddc 100644 --- a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/GetLocation/main.go index f63da80bb648..79d450720ff9 100644 --- a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/GetOperation/main.go index e946ca044c97..b571fba534bc 100644 --- a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/ListAppConnectors/main.go b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/ListAppConnectors/main.go index d5b5debf6c1a..744cd605209b 100644 --- a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/ListAppConnectors/main.go +++ b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/ListAppConnectors/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/ListLocations/main.go index cab818e4f0e8..0e131218a320 100644 --- a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/ListOperations/main.go index 1c22744ee773..66b8ef552238 100644 --- a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/ReportStatus/main.go b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/ReportStatus/main.go index 18d92d486230..58c40b0b351d 100644 --- a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/ReportStatus/main.go +++ b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/ReportStatus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/SetIamPolicy/main.go b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/SetIamPolicy/main.go index fd30a90f7573..909d97e4d347 100644 --- a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/TestIamPermissions/main.go b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/TestIamPermissions/main.go index 1d6bdb6d606d..ba4afbcdaca5 100644 --- a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/UpdateAppConnector/main.go b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/UpdateAppConnector/main.go index fa51aeb21da3..8976c18f48ef 100644 --- a/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/UpdateAppConnector/main.go +++ b/internal/generated/snippets/beyondcorp/appconnectors/apiv1/Client/UpdateAppConnector/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/CancelOperation/main.go index d77544955269..0da5e23b1a0b 100644 --- a/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/CreateAppGateway/main.go b/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/CreateAppGateway/main.go index 6bf03ed83485..f9f6f5e98870 100644 --- a/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/CreateAppGateway/main.go +++ b/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/CreateAppGateway/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/DeleteAppGateway/main.go b/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/DeleteAppGateway/main.go index 1bd5b82b8d43..fa5329783318 100644 --- a/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/DeleteAppGateway/main.go +++ b/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/DeleteAppGateway/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/DeleteOperation/main.go index f3d25e69e1f7..1134a7eb845b 100644 --- a/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/GetAppGateway/main.go b/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/GetAppGateway/main.go index aa5cb1722ace..534f97b234af 100644 --- a/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/GetAppGateway/main.go +++ b/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/GetAppGateway/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/GetIamPolicy/main.go b/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/GetIamPolicy/main.go index 86a61ef43413..1b3a2e538b37 100644 --- a/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/GetLocation/main.go index 2cc578ab4229..f7fd43c32df4 100644 --- a/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/GetOperation/main.go index 02bd26604b52..cfad6c24c849 100644 --- a/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/ListAppGateways/main.go b/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/ListAppGateways/main.go index cfb8a1a13f0e..d99294e9d893 100644 --- a/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/ListAppGateways/main.go +++ b/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/ListAppGateways/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/ListLocations/main.go index 23bed92800d5..53b7430d14a6 100644 --- a/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/ListOperations/main.go index 101a0e3002b2..0ca170846811 100644 --- a/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/SetIamPolicy/main.go b/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/SetIamPolicy/main.go index 32ba32979802..32ef875a71c1 100644 --- a/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/TestIamPermissions/main.go b/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/TestIamPermissions/main.go index c36a93136905..c6dcc626076e 100644 --- a/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/beyondcorp/appgateways/apiv1/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/CancelOperation/main.go index 3985d1ccb397..4b260e34e7b6 100644 --- a/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/CreateClientConnectorService/main.go b/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/CreateClientConnectorService/main.go index eeec0c7c4306..d784c630cb68 100644 --- a/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/CreateClientConnectorService/main.go +++ b/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/CreateClientConnectorService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/DeleteClientConnectorService/main.go b/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/DeleteClientConnectorService/main.go index 2d798c783c4f..6a32dcf604da 100644 --- a/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/DeleteClientConnectorService/main.go +++ b/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/DeleteClientConnectorService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/DeleteOperation/main.go index e31c19eaf4f8..9609c796a6fa 100644 --- a/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/GetClientConnectorService/main.go b/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/GetClientConnectorService/main.go index a83daf4db729..2d334e43c9db 100644 --- a/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/GetClientConnectorService/main.go +++ b/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/GetClientConnectorService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/GetIamPolicy/main.go b/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/GetIamPolicy/main.go index 9512b280e21d..77931f44de74 100644 --- a/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/GetLocation/main.go index 4fba0c85197b..747c83bf583e 100644 --- a/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/GetOperation/main.go index ff17eafb6879..d4ba4ee994d2 100644 --- a/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/ListClientConnectorServices/main.go b/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/ListClientConnectorServices/main.go index 21437e7ca479..8aa71be63f90 100644 --- a/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/ListClientConnectorServices/main.go +++ b/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/ListClientConnectorServices/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/ListLocations/main.go index fb8a52066637..04674b90abd3 100644 --- a/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/ListOperations/main.go index 791105d67397..84be5dd0d132 100644 --- a/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/SetIamPolicy/main.go b/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/SetIamPolicy/main.go index 965bc319498a..0e1c1735a56f 100644 --- a/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/TestIamPermissions/main.go b/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/TestIamPermissions/main.go index 811645b45ef6..986c80e77eb4 100644 --- a/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/UpdateClientConnectorService/main.go b/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/UpdateClientConnectorService/main.go index 0d7fbdb2de49..25da06db77ff 100644 --- a/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/UpdateClientConnectorService/main.go +++ b/internal/generated/snippets/beyondcorp/clientconnectorservices/apiv1/Client/UpdateClientConnectorService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/CancelOperation/main.go index 36b693bc4af0..4941174ffa7d 100644 --- a/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/CreateClientGateway/main.go b/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/CreateClientGateway/main.go index e5961e714829..8e20002e91c0 100644 --- a/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/CreateClientGateway/main.go +++ b/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/CreateClientGateway/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/DeleteClientGateway/main.go b/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/DeleteClientGateway/main.go index e0ff5ad06317..a38b82d0717d 100644 --- a/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/DeleteClientGateway/main.go +++ b/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/DeleteClientGateway/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/DeleteOperation/main.go index 98582cba8e7c..2a34fdb3af48 100644 --- a/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/GetClientGateway/main.go b/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/GetClientGateway/main.go index 5318fad15681..743a7802f01a 100644 --- a/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/GetClientGateway/main.go +++ b/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/GetClientGateway/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/GetIamPolicy/main.go b/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/GetIamPolicy/main.go index 6f30413849ea..9d250420425b 100644 --- a/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/GetLocation/main.go index 1d0db2436c0b..acf2640c4be1 100644 --- a/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/GetOperation/main.go index 850cfeac36ff..989cddf80e5f 100644 --- a/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/ListClientGateways/main.go b/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/ListClientGateways/main.go index 445c7a8f7a0a..237657d7774d 100644 --- a/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/ListClientGateways/main.go +++ b/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/ListClientGateways/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/ListLocations/main.go index 059b481f873c..ee9bdb65dc96 100644 --- a/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/ListOperations/main.go index 2aa51ca56622..3d482e722073 100644 --- a/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/SetIamPolicy/main.go b/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/SetIamPolicy/main.go index 2409a6c2498f..1dbe8f7ab2e2 100644 --- a/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/TestIamPermissions/main.go b/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/TestIamPermissions/main.go index b895e7bbcb50..66fb57b211c2 100644 --- a/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/beyondcorp/clientgateways/apiv1/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/CreateDataExchange/main.go b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/CreateDataExchange/main.go index 4825af66abd0..afaed2791499 100644 --- a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/CreateDataExchange/main.go +++ b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/CreateDataExchange/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/CreateListing/main.go b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/CreateListing/main.go index 3c014a443484..6b79b4a21787 100644 --- a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/CreateListing/main.go +++ b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/CreateListing/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/DeleteDataExchange/main.go b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/DeleteDataExchange/main.go index 8b8c7890bece..769d386912de 100644 --- a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/DeleteDataExchange/main.go +++ b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/DeleteDataExchange/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/DeleteListing/main.go b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/DeleteListing/main.go index 4639cc3b78a8..6af0adc9a9b1 100644 --- a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/DeleteListing/main.go +++ b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/DeleteListing/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/DeleteSubscription/main.go b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/DeleteSubscription/main.go index 61c41b37629f..07fdae9d6bd6 100644 --- a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/DeleteSubscription/main.go +++ b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/DeleteSubscription/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/GetDataExchange/main.go b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/GetDataExchange/main.go index 410ce265e7c5..e9111a0840ca 100644 --- a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/GetDataExchange/main.go +++ b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/GetDataExchange/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/GetIamPolicy/main.go b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/GetIamPolicy/main.go index e92e4544632c..72e5ea7b1a28 100644 --- a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/GetListing/main.go b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/GetListing/main.go index cc2784da61bb..324faab083e1 100644 --- a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/GetListing/main.go +++ b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/GetListing/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/GetSubscription/main.go b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/GetSubscription/main.go index 78dd7f2fc401..5176cff413fa 100644 --- a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/GetSubscription/main.go +++ b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/GetSubscription/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/ListDataExchanges/main.go b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/ListDataExchanges/main.go index 379e06ed62ea..c9191f05e938 100644 --- a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/ListDataExchanges/main.go +++ b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/ListDataExchanges/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/ListListings/main.go b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/ListListings/main.go index 2123c50641e6..8c735bf202df 100644 --- a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/ListListings/main.go +++ b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/ListListings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/ListOrgDataExchanges/main.go b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/ListOrgDataExchanges/main.go index e3ad9ee7590d..4457aed9c57d 100644 --- a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/ListOrgDataExchanges/main.go +++ b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/ListOrgDataExchanges/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/ListSharedResourceSubscriptions/main.go b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/ListSharedResourceSubscriptions/main.go index f0e54507a17a..7b40d1df2ab7 100644 --- a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/ListSharedResourceSubscriptions/main.go +++ b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/ListSharedResourceSubscriptions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/ListSubscriptions/main.go b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/ListSubscriptions/main.go index 24ba03cfd1d9..e55bbd5064cd 100644 --- a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/ListSubscriptions/main.go +++ b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/ListSubscriptions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/RefreshSubscription/main.go b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/RefreshSubscription/main.go index 66f625005c30..d0827b07a1a6 100644 --- a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/RefreshSubscription/main.go +++ b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/RefreshSubscription/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/RevokeSubscription/main.go b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/RevokeSubscription/main.go index 0248bbff0c81..362ba132ff85 100644 --- a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/RevokeSubscription/main.go +++ b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/RevokeSubscription/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/SetIamPolicy/main.go b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/SetIamPolicy/main.go index 42794958dd78..9aeeadbdfaaa 100644 --- a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/SubscribeDataExchange/main.go b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/SubscribeDataExchange/main.go index 91524783161a..deea028cb3c4 100644 --- a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/SubscribeDataExchange/main.go +++ b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/SubscribeDataExchange/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/SubscribeListing/main.go b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/SubscribeListing/main.go index de6a044f1cab..7d42d7a8bf5a 100644 --- a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/SubscribeListing/main.go +++ b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/SubscribeListing/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/TestIamPermissions/main.go b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/TestIamPermissions/main.go index f4b1b5aac488..ff1cb5fb9b41 100644 --- a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/UpdateDataExchange/main.go b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/UpdateDataExchange/main.go index edbbe3ae4da8..548182212bf5 100644 --- a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/UpdateDataExchange/main.go +++ b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/UpdateDataExchange/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/UpdateListing/main.go b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/UpdateListing/main.go index f57d47030fb4..6fc22823ff8a 100644 --- a/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/UpdateListing/main.go +++ b/internal/generated/snippets/bigquery/analyticshub/apiv1/Client/UpdateListing/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/CreateCatalog/main.go b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/CreateCatalog/main.go index 4ec59db5b930..5357ad2c3ad4 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/CreateCatalog/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/CreateCatalog/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/CreateDatabase/main.go b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/CreateDatabase/main.go index f9eedd554f99..92375162a932 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/CreateDatabase/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/CreateDatabase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/CreateTable/main.go b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/CreateTable/main.go index 20761a07cc90..91e8661ed4b2 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/CreateTable/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/CreateTable/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/DeleteCatalog/main.go b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/DeleteCatalog/main.go index 1a0a7eb79e75..09ffe9dc0e6c 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/DeleteCatalog/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/DeleteCatalog/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/DeleteDatabase/main.go b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/DeleteDatabase/main.go index 024cde20d18a..dc9d6f0bfa00 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/DeleteDatabase/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/DeleteDatabase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/DeleteTable/main.go b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/DeleteTable/main.go index 22b90ed851ff..daa4d4e0cb08 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/DeleteTable/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/DeleteTable/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/GetCatalog/main.go b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/GetCatalog/main.go index 2e5cf77c0d20..57f1636ec42e 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/GetCatalog/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/GetCatalog/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/GetDatabase/main.go b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/GetDatabase/main.go index 29eed28500aa..3d4329978e3c 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/GetDatabase/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/GetDatabase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/GetTable/main.go b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/GetTable/main.go index 0e1ad35bfe4d..c3ab2388e2fc 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/GetTable/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/GetTable/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/ListCatalogs/main.go b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/ListCatalogs/main.go index d160bff6e345..4962922ad82b 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/ListCatalogs/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/ListCatalogs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/ListDatabases/main.go b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/ListDatabases/main.go index efcf8b7b13a8..750c86ff29ac 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/ListDatabases/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/ListDatabases/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/ListTables/main.go b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/ListTables/main.go index 34cdb1a6ab5e..7efb21f2da8c 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/ListTables/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/ListTables/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/RenameTable/main.go b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/RenameTable/main.go index 4c31d89ae86b..f585e4be92e4 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/RenameTable/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/RenameTable/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/UpdateDatabase/main.go b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/UpdateDatabase/main.go index b394a7ceefaf..3fa34c2e047c 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/UpdateDatabase/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/UpdateDatabase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/UpdateTable/main.go b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/UpdateTable/main.go index 0852330051fb..713a271ebdd0 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/UpdateTable/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1/MetastoreClient/UpdateTable/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/CheckLock/main.go b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/CheckLock/main.go index af1c13035b05..79bb9d30cf7b 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/CheckLock/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/CheckLock/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/CreateCatalog/main.go b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/CreateCatalog/main.go index a3768c2167ce..d8f650c1e7b0 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/CreateCatalog/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/CreateCatalog/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/CreateDatabase/main.go b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/CreateDatabase/main.go index 87e6dc6ed9d9..f2cbda541ece 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/CreateDatabase/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/CreateDatabase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/CreateLock/main.go b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/CreateLock/main.go index eac85e4cc236..6028d672853c 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/CreateLock/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/CreateLock/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/CreateTable/main.go b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/CreateTable/main.go index 670618234fba..3c03fbbf5d5d 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/CreateTable/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/CreateTable/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/DeleteCatalog/main.go b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/DeleteCatalog/main.go index 1ebe1a3b9aea..4211d417a443 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/DeleteCatalog/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/DeleteCatalog/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/DeleteDatabase/main.go b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/DeleteDatabase/main.go index d24c78127dae..367b3567cfec 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/DeleteDatabase/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/DeleteDatabase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/DeleteLock/main.go b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/DeleteLock/main.go index f61e437a4a2e..9e6ae9eef59a 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/DeleteLock/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/DeleteLock/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/DeleteTable/main.go b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/DeleteTable/main.go index 757964ef97f2..dd382de1a477 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/DeleteTable/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/DeleteTable/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/GetCatalog/main.go b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/GetCatalog/main.go index 372ec699cd86..f1dd74618a2d 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/GetCatalog/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/GetCatalog/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/GetDatabase/main.go b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/GetDatabase/main.go index fbde15b28497..445c2b551507 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/GetDatabase/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/GetDatabase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/GetTable/main.go b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/GetTable/main.go index 1982f99cecdc..10ac94109d92 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/GetTable/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/GetTable/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/ListCatalogs/main.go b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/ListCatalogs/main.go index fb2c5ba91131..f614d66410cb 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/ListCatalogs/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/ListCatalogs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/ListDatabases/main.go b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/ListDatabases/main.go index 8a4977c04ac8..197a3164810f 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/ListDatabases/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/ListDatabases/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/ListLocks/main.go b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/ListLocks/main.go index a36860350d0e..7d0d2c050f10 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/ListLocks/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/ListLocks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/ListTables/main.go b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/ListTables/main.go index 6ac83bc8b6b4..67d4ef7fbfcc 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/ListTables/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/ListTables/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/RenameTable/main.go b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/RenameTable/main.go index 6280aba010e3..7b35c3f0b55d 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/RenameTable/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/RenameTable/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/UpdateDatabase/main.go b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/UpdateDatabase/main.go index ba9ac4e65f60..491341590eb9 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/UpdateDatabase/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/UpdateDatabase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/UpdateTable/main.go b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/UpdateTable/main.go index f610e79ecb25..9c3e36c4e5f4 100644 --- a/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/UpdateTable/main.go +++ b/internal/generated/snippets/bigquery/biglake/apiv1alpha1/MetastoreClient/UpdateTable/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/connection/apiv1/Client/CreateConnection/main.go b/internal/generated/snippets/bigquery/connection/apiv1/Client/CreateConnection/main.go index 28d84685881a..c264f044fdec 100644 --- a/internal/generated/snippets/bigquery/connection/apiv1/Client/CreateConnection/main.go +++ b/internal/generated/snippets/bigquery/connection/apiv1/Client/CreateConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/connection/apiv1/Client/DeleteConnection/main.go b/internal/generated/snippets/bigquery/connection/apiv1/Client/DeleteConnection/main.go index fd722f81fbfc..eb00d9f31307 100644 --- a/internal/generated/snippets/bigquery/connection/apiv1/Client/DeleteConnection/main.go +++ b/internal/generated/snippets/bigquery/connection/apiv1/Client/DeleteConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/connection/apiv1/Client/GetConnection/main.go b/internal/generated/snippets/bigquery/connection/apiv1/Client/GetConnection/main.go index 874459379c14..59fbe9122883 100644 --- a/internal/generated/snippets/bigquery/connection/apiv1/Client/GetConnection/main.go +++ b/internal/generated/snippets/bigquery/connection/apiv1/Client/GetConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/connection/apiv1/Client/GetIamPolicy/main.go b/internal/generated/snippets/bigquery/connection/apiv1/Client/GetIamPolicy/main.go index fa3433a46779..4a1c7ef12a88 100644 --- a/internal/generated/snippets/bigquery/connection/apiv1/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/bigquery/connection/apiv1/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/connection/apiv1/Client/ListConnections/main.go b/internal/generated/snippets/bigquery/connection/apiv1/Client/ListConnections/main.go index 3b2e3d2c6ab5..42f48fd83441 100644 --- a/internal/generated/snippets/bigquery/connection/apiv1/Client/ListConnections/main.go +++ b/internal/generated/snippets/bigquery/connection/apiv1/Client/ListConnections/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/connection/apiv1/Client/SetIamPolicy/main.go b/internal/generated/snippets/bigquery/connection/apiv1/Client/SetIamPolicy/main.go index 239ab12d09bc..bcf2477e4618 100644 --- a/internal/generated/snippets/bigquery/connection/apiv1/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/bigquery/connection/apiv1/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/connection/apiv1/Client/TestIamPermissions/main.go b/internal/generated/snippets/bigquery/connection/apiv1/Client/TestIamPermissions/main.go index ce3a07f3df72..c091fee12b5e 100644 --- a/internal/generated/snippets/bigquery/connection/apiv1/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/bigquery/connection/apiv1/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/connection/apiv1/Client/UpdateConnection/main.go b/internal/generated/snippets/bigquery/connection/apiv1/Client/UpdateConnection/main.go index 487afea39706..f034bbc4d66c 100644 --- a/internal/generated/snippets/bigquery/connection/apiv1/Client/UpdateConnection/main.go +++ b/internal/generated/snippets/bigquery/connection/apiv1/Client/UpdateConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/CreateConnection/main.go b/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/CreateConnection/main.go index 7e9e579f97e3..e67ac8789dec 100644 --- a/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/CreateConnection/main.go +++ b/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/CreateConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/DeleteConnection/main.go b/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/DeleteConnection/main.go index ff040e3d8875..20052a2b00a2 100644 --- a/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/DeleteConnection/main.go +++ b/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/DeleteConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/GetConnection/main.go b/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/GetConnection/main.go index 667299e7e314..e9660eb9e2e8 100644 --- a/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/GetConnection/main.go +++ b/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/GetConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/GetIamPolicy/main.go b/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/GetIamPolicy/main.go index a5f8cdff8213..4d9f4d7ab19c 100644 --- a/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/ListConnections/main.go b/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/ListConnections/main.go index e8f41e100a22..6dac52f768a3 100644 --- a/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/ListConnections/main.go +++ b/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/ListConnections/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/SetIamPolicy/main.go b/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/SetIamPolicy/main.go index 683a903e8daf..92d263a7155f 100644 --- a/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/TestIamPermissions/main.go b/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/TestIamPermissions/main.go index 37cbcf02e2d4..b25f59d8dac2 100644 --- a/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/UpdateConnection/main.go b/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/UpdateConnection/main.go index e0b36e036238..1956fae2370c 100644 --- a/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/UpdateConnection/main.go +++ b/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/UpdateConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/UpdateConnectionCredential/main.go b/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/UpdateConnectionCredential/main.go index 3c9929e9ccae..2517df461af3 100644 --- a/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/UpdateConnectionCredential/main.go +++ b/internal/generated/snippets/bigquery/connection/apiv1beta1/Client/UpdateConnectionCredential/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/CreateDataExchange/main.go b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/CreateDataExchange/main.go index 862cd4f97a5f..701402a5b149 100644 --- a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/CreateDataExchange/main.go +++ b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/CreateDataExchange/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/CreateListing/main.go b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/CreateListing/main.go index bf020b303aaf..167994223886 100644 --- a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/CreateListing/main.go +++ b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/CreateListing/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/DeleteDataExchange/main.go b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/DeleteDataExchange/main.go index 91bf2c2a968c..d8ea2a6cd888 100644 --- a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/DeleteDataExchange/main.go +++ b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/DeleteDataExchange/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/DeleteListing/main.go b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/DeleteListing/main.go index 90806ec2203e..3a43928ca5aa 100644 --- a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/DeleteListing/main.go +++ b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/DeleteListing/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/GetDataExchange/main.go b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/GetDataExchange/main.go index 7d5b9900235b..a92001d24c44 100644 --- a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/GetDataExchange/main.go +++ b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/GetDataExchange/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/GetIamPolicy/main.go b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/GetIamPolicy/main.go index 2bfa9399cbf8..30ba68588f9a 100644 --- a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/GetListing/main.go b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/GetListing/main.go index c8ef7efa09b2..5ad99516f968 100644 --- a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/GetListing/main.go +++ b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/GetListing/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/GetLocation/main.go b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/GetLocation/main.go index abf0b27865a0..894742832c62 100644 --- a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/GetLocation/main.go +++ b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/ListDataExchanges/main.go b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/ListDataExchanges/main.go index 627e26ea5748..95ac5b1e14a3 100644 --- a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/ListDataExchanges/main.go +++ b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/ListDataExchanges/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/ListListings/main.go b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/ListListings/main.go index 3fd98722a5ef..28bce174724a 100644 --- a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/ListListings/main.go +++ b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/ListListings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/ListLocations/main.go b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/ListLocations/main.go index 6014ee23f9ba..e033f130dc16 100644 --- a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/ListLocations/main.go +++ b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/ListOrgDataExchanges/main.go b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/ListOrgDataExchanges/main.go index 36545c32b888..3e62ba198a8c 100644 --- a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/ListOrgDataExchanges/main.go +++ b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/ListOrgDataExchanges/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/SetIamPolicy/main.go b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/SetIamPolicy/main.go index 35f4e7bfcb12..438066397825 100644 --- a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/SubscribeListing/main.go b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/SubscribeListing/main.go index b298c0c39f83..dce9308b8ae9 100644 --- a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/SubscribeListing/main.go +++ b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/SubscribeListing/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/TestIamPermissions/main.go b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/TestIamPermissions/main.go index 43de1be1e55e..0bbaf72be7d6 100644 --- a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/UpdateDataExchange/main.go b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/UpdateDataExchange/main.go index 617cc616d7f6..db04725e7085 100644 --- a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/UpdateDataExchange/main.go +++ b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/UpdateDataExchange/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/UpdateListing/main.go b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/UpdateListing/main.go index 7d176d354baa..f28ba431ef53 100644 --- a/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/UpdateListing/main.go +++ b/internal/generated/snippets/bigquery/dataexchange/apiv1beta1/AnalyticsHubClient/UpdateListing/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/CreateDataPolicy/main.go b/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/CreateDataPolicy/main.go index f551a7137abb..440bdd3c76ad 100644 --- a/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/CreateDataPolicy/main.go +++ b/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/CreateDataPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/DeleteDataPolicy/main.go b/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/DeleteDataPolicy/main.go index eb265b066e42..7425b23a287e 100644 --- a/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/DeleteDataPolicy/main.go +++ b/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/DeleteDataPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/GetDataPolicy/main.go b/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/GetDataPolicy/main.go index ba8ac678b931..8f265334d82c 100644 --- a/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/GetDataPolicy/main.go +++ b/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/GetDataPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/GetIamPolicy/main.go b/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/GetIamPolicy/main.go index 47355e9ff544..01b7a6709684 100644 --- a/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/ListDataPolicies/main.go b/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/ListDataPolicies/main.go index df306c4c5e88..a9ec378eaa54 100644 --- a/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/ListDataPolicies/main.go +++ b/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/ListDataPolicies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/RenameDataPolicy/main.go b/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/RenameDataPolicy/main.go index 39078f8f07f6..8b2f4b3bdf69 100644 --- a/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/RenameDataPolicy/main.go +++ b/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/RenameDataPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/SetIamPolicy/main.go b/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/SetIamPolicy/main.go index d716c1fdf421..4abceb00395c 100644 --- a/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/TestIamPermissions/main.go b/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/TestIamPermissions/main.go index 0bbf3850064b..6538e5948153 100644 --- a/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/UpdateDataPolicy/main.go b/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/UpdateDataPolicy/main.go index e666c021d5c1..1aa1fc82079d 100644 --- a/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/UpdateDataPolicy/main.go +++ b/internal/generated/snippets/bigquery/datapolicies/apiv1/DataPolicyClient/UpdateDataPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/CreateDataPolicy/main.go b/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/CreateDataPolicy/main.go index ed323b0caff8..a40ade3fa578 100644 --- a/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/CreateDataPolicy/main.go +++ b/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/CreateDataPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/DeleteDataPolicy/main.go b/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/DeleteDataPolicy/main.go index 6b86906a08b7..4bca0ad5a6f2 100644 --- a/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/DeleteDataPolicy/main.go +++ b/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/DeleteDataPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/GetDataPolicy/main.go b/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/GetDataPolicy/main.go index 0d5797536dd2..11f3f58656bb 100644 --- a/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/GetDataPolicy/main.go +++ b/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/GetDataPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/GetIamPolicy/main.go b/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/GetIamPolicy/main.go index 4c1921e8d9cb..d29497d8cff8 100644 --- a/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/ListDataPolicies/main.go b/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/ListDataPolicies/main.go index 9b14d8090816..ede32602d05a 100644 --- a/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/ListDataPolicies/main.go +++ b/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/ListDataPolicies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/SetIamPolicy/main.go b/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/SetIamPolicy/main.go index 58092b90b4b3..d45eb04796f9 100644 --- a/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/TestIamPermissions/main.go b/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/TestIamPermissions/main.go index ad0bc89ac563..099598b71d6c 100644 --- a/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/UpdateDataPolicy/main.go b/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/UpdateDataPolicy/main.go index 9570e39f5308..d90d58b21259 100644 --- a/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/UpdateDataPolicy/main.go +++ b/internal/generated/snippets/bigquery/datapolicies/apiv1beta1/DataPolicyClient/UpdateDataPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/CheckValidCreds/main.go b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/CheckValidCreds/main.go index 86bcd175ac80..9b602b7e6b69 100644 --- a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/CheckValidCreds/main.go +++ b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/CheckValidCreds/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/CreateTransferConfig/main.go b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/CreateTransferConfig/main.go index 83552e90b969..7133cfb63d0c 100644 --- a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/CreateTransferConfig/main.go +++ b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/CreateTransferConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/DeleteTransferConfig/main.go b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/DeleteTransferConfig/main.go index e86aee659d10..d640444c3605 100644 --- a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/DeleteTransferConfig/main.go +++ b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/DeleteTransferConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/DeleteTransferRun/main.go b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/DeleteTransferRun/main.go index bac5d906af2e..cdade203fb12 100644 --- a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/DeleteTransferRun/main.go +++ b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/DeleteTransferRun/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/EnrollDataSources/main.go b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/EnrollDataSources/main.go index cf7710d02aad..43c159584185 100644 --- a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/EnrollDataSources/main.go +++ b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/EnrollDataSources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/GetDataSource/main.go b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/GetDataSource/main.go index 1649d2986287..9e07e68aaf30 100644 --- a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/GetDataSource/main.go +++ b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/GetDataSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/GetLocation/main.go index daca1c40aa83..1ace175be10d 100644 --- a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/GetTransferConfig/main.go b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/GetTransferConfig/main.go index 484f7c0f7ed2..c80df245069d 100644 --- a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/GetTransferConfig/main.go +++ b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/GetTransferConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/GetTransferRun/main.go b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/GetTransferRun/main.go index bf19134c1654..203e009e6856 100644 --- a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/GetTransferRun/main.go +++ b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/GetTransferRun/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/ListDataSources/main.go b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/ListDataSources/main.go index d78a4a463f5b..f328e804c91d 100644 --- a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/ListDataSources/main.go +++ b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/ListDataSources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/ListLocations/main.go index fc531350b668..c26d66bc41f8 100644 --- a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/ListTransferConfigs/main.go b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/ListTransferConfigs/main.go index df481c6293f7..ebc5ae3bdfc1 100644 --- a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/ListTransferConfigs/main.go +++ b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/ListTransferConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/ListTransferLogs/main.go b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/ListTransferLogs/main.go index 5223162c5b95..70b2e36d0396 100644 --- a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/ListTransferLogs/main.go +++ b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/ListTransferLogs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/ListTransferRuns/main.go b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/ListTransferRuns/main.go index 8196a95a02b9..9dc3da30ee8d 100644 --- a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/ListTransferRuns/main.go +++ b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/ListTransferRuns/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/ScheduleTransferRuns/main.go b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/ScheduleTransferRuns/main.go index 603ae1d8f629..5f0b6c037006 100644 --- a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/ScheduleTransferRuns/main.go +++ b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/ScheduleTransferRuns/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/StartManualTransferRuns/main.go b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/StartManualTransferRuns/main.go index 99921c0c3291..77e0367965d6 100644 --- a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/StartManualTransferRuns/main.go +++ b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/StartManualTransferRuns/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/UnenrollDataSources/main.go b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/UnenrollDataSources/main.go index fca3c0bea666..c4e1d2178196 100644 --- a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/UnenrollDataSources/main.go +++ b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/UnenrollDataSources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/UpdateTransferConfig/main.go b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/UpdateTransferConfig/main.go index 9494baab991c..5b8add89e3c7 100644 --- a/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/UpdateTransferConfig/main.go +++ b/internal/generated/snippets/bigquery/datatransfer/apiv1/Client/UpdateTransferConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/migration/apiv2/Client/CreateMigrationWorkflow/main.go b/internal/generated/snippets/bigquery/migration/apiv2/Client/CreateMigrationWorkflow/main.go index 19a27bfd9a39..086f86fb4db1 100644 --- a/internal/generated/snippets/bigquery/migration/apiv2/Client/CreateMigrationWorkflow/main.go +++ b/internal/generated/snippets/bigquery/migration/apiv2/Client/CreateMigrationWorkflow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/migration/apiv2/Client/DeleteMigrationWorkflow/main.go b/internal/generated/snippets/bigquery/migration/apiv2/Client/DeleteMigrationWorkflow/main.go index 31867c62710b..7fa65a9a35bb 100644 --- a/internal/generated/snippets/bigquery/migration/apiv2/Client/DeleteMigrationWorkflow/main.go +++ b/internal/generated/snippets/bigquery/migration/apiv2/Client/DeleteMigrationWorkflow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/migration/apiv2/Client/GetMigrationSubtask/main.go b/internal/generated/snippets/bigquery/migration/apiv2/Client/GetMigrationSubtask/main.go index d4b026da8d71..3b28912b2936 100644 --- a/internal/generated/snippets/bigquery/migration/apiv2/Client/GetMigrationSubtask/main.go +++ b/internal/generated/snippets/bigquery/migration/apiv2/Client/GetMigrationSubtask/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/migration/apiv2/Client/GetMigrationWorkflow/main.go b/internal/generated/snippets/bigquery/migration/apiv2/Client/GetMigrationWorkflow/main.go index 94857ef80b41..d854ba7bdd33 100644 --- a/internal/generated/snippets/bigquery/migration/apiv2/Client/GetMigrationWorkflow/main.go +++ b/internal/generated/snippets/bigquery/migration/apiv2/Client/GetMigrationWorkflow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/migration/apiv2/Client/ListMigrationSubtasks/main.go b/internal/generated/snippets/bigquery/migration/apiv2/Client/ListMigrationSubtasks/main.go index 0d7e88040825..1cb417f9c43d 100644 --- a/internal/generated/snippets/bigquery/migration/apiv2/Client/ListMigrationSubtasks/main.go +++ b/internal/generated/snippets/bigquery/migration/apiv2/Client/ListMigrationSubtasks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/migration/apiv2/Client/ListMigrationWorkflows/main.go b/internal/generated/snippets/bigquery/migration/apiv2/Client/ListMigrationWorkflows/main.go index 957f7b807061..91239c101097 100644 --- a/internal/generated/snippets/bigquery/migration/apiv2/Client/ListMigrationWorkflows/main.go +++ b/internal/generated/snippets/bigquery/migration/apiv2/Client/ListMigrationWorkflows/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/migration/apiv2/Client/StartMigrationWorkflow/main.go b/internal/generated/snippets/bigquery/migration/apiv2/Client/StartMigrationWorkflow/main.go index e8684849cb4d..f84698af5df6 100644 --- a/internal/generated/snippets/bigquery/migration/apiv2/Client/StartMigrationWorkflow/main.go +++ b/internal/generated/snippets/bigquery/migration/apiv2/Client/StartMigrationWorkflow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/migration/apiv2alpha/Client/CreateMigrationWorkflow/main.go b/internal/generated/snippets/bigquery/migration/apiv2alpha/Client/CreateMigrationWorkflow/main.go index a81c6a5ec2da..119aefa5cb8e 100644 --- a/internal/generated/snippets/bigquery/migration/apiv2alpha/Client/CreateMigrationWorkflow/main.go +++ b/internal/generated/snippets/bigquery/migration/apiv2alpha/Client/CreateMigrationWorkflow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/migration/apiv2alpha/Client/DeleteMigrationWorkflow/main.go b/internal/generated/snippets/bigquery/migration/apiv2alpha/Client/DeleteMigrationWorkflow/main.go index 722d79d4aa6e..798162510f3e 100644 --- a/internal/generated/snippets/bigquery/migration/apiv2alpha/Client/DeleteMigrationWorkflow/main.go +++ b/internal/generated/snippets/bigquery/migration/apiv2alpha/Client/DeleteMigrationWorkflow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/migration/apiv2alpha/Client/GetMigrationSubtask/main.go b/internal/generated/snippets/bigquery/migration/apiv2alpha/Client/GetMigrationSubtask/main.go index 7f9500bb3a66..52dbab7a7cc8 100644 --- a/internal/generated/snippets/bigquery/migration/apiv2alpha/Client/GetMigrationSubtask/main.go +++ b/internal/generated/snippets/bigquery/migration/apiv2alpha/Client/GetMigrationSubtask/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/migration/apiv2alpha/Client/GetMigrationWorkflow/main.go b/internal/generated/snippets/bigquery/migration/apiv2alpha/Client/GetMigrationWorkflow/main.go index fa44b7922798..2392bd66fdb4 100644 --- a/internal/generated/snippets/bigquery/migration/apiv2alpha/Client/GetMigrationWorkflow/main.go +++ b/internal/generated/snippets/bigquery/migration/apiv2alpha/Client/GetMigrationWorkflow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/migration/apiv2alpha/Client/ListMigrationSubtasks/main.go b/internal/generated/snippets/bigquery/migration/apiv2alpha/Client/ListMigrationSubtasks/main.go index 9349d5f56d5b..569604c705ac 100644 --- a/internal/generated/snippets/bigquery/migration/apiv2alpha/Client/ListMigrationSubtasks/main.go +++ b/internal/generated/snippets/bigquery/migration/apiv2alpha/Client/ListMigrationSubtasks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/migration/apiv2alpha/Client/ListMigrationWorkflows/main.go b/internal/generated/snippets/bigquery/migration/apiv2alpha/Client/ListMigrationWorkflows/main.go index ddc95ba338ec..5f1f0881232f 100644 --- a/internal/generated/snippets/bigquery/migration/apiv2alpha/Client/ListMigrationWorkflows/main.go +++ b/internal/generated/snippets/bigquery/migration/apiv2alpha/Client/ListMigrationWorkflows/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/migration/apiv2alpha/Client/StartMigrationWorkflow/main.go b/internal/generated/snippets/bigquery/migration/apiv2alpha/Client/StartMigrationWorkflow/main.go index 7e2c004e5d01..a7534bfbc21e 100644 --- a/internal/generated/snippets/bigquery/migration/apiv2alpha/Client/StartMigrationWorkflow/main.go +++ b/internal/generated/snippets/bigquery/migration/apiv2alpha/Client/StartMigrationWorkflow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/migration/apiv2alpha/SqlTranslationClient/TranslateQuery/main.go b/internal/generated/snippets/bigquery/migration/apiv2alpha/SqlTranslationClient/TranslateQuery/main.go index c24a6d566855..3722c0e74001 100644 --- a/internal/generated/snippets/bigquery/migration/apiv2alpha/SqlTranslationClient/TranslateQuery/main.go +++ b/internal/generated/snippets/bigquery/migration/apiv2alpha/SqlTranslationClient/TranslateQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/reservation/apiv1/Client/CreateAssignment/main.go b/internal/generated/snippets/bigquery/reservation/apiv1/Client/CreateAssignment/main.go index cbf1779bfe07..05d7ff7de54e 100644 --- a/internal/generated/snippets/bigquery/reservation/apiv1/Client/CreateAssignment/main.go +++ b/internal/generated/snippets/bigquery/reservation/apiv1/Client/CreateAssignment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/reservation/apiv1/Client/CreateCapacityCommitment/main.go b/internal/generated/snippets/bigquery/reservation/apiv1/Client/CreateCapacityCommitment/main.go index 710fc18ced57..3df23024d2ec 100644 --- a/internal/generated/snippets/bigquery/reservation/apiv1/Client/CreateCapacityCommitment/main.go +++ b/internal/generated/snippets/bigquery/reservation/apiv1/Client/CreateCapacityCommitment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/reservation/apiv1/Client/CreateReservation/main.go b/internal/generated/snippets/bigquery/reservation/apiv1/Client/CreateReservation/main.go index befa57e0b925..7db1c0485968 100644 --- a/internal/generated/snippets/bigquery/reservation/apiv1/Client/CreateReservation/main.go +++ b/internal/generated/snippets/bigquery/reservation/apiv1/Client/CreateReservation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/reservation/apiv1/Client/DeleteAssignment/main.go b/internal/generated/snippets/bigquery/reservation/apiv1/Client/DeleteAssignment/main.go index 6f0b7fd61d3b..3b57c6e1dfab 100644 --- a/internal/generated/snippets/bigquery/reservation/apiv1/Client/DeleteAssignment/main.go +++ b/internal/generated/snippets/bigquery/reservation/apiv1/Client/DeleteAssignment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/reservation/apiv1/Client/DeleteCapacityCommitment/main.go b/internal/generated/snippets/bigquery/reservation/apiv1/Client/DeleteCapacityCommitment/main.go index de748e58d48a..9745aa1e14d4 100644 --- a/internal/generated/snippets/bigquery/reservation/apiv1/Client/DeleteCapacityCommitment/main.go +++ b/internal/generated/snippets/bigquery/reservation/apiv1/Client/DeleteCapacityCommitment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/reservation/apiv1/Client/DeleteReservation/main.go b/internal/generated/snippets/bigquery/reservation/apiv1/Client/DeleteReservation/main.go index 43b8ed79f9fc..25c2d8cddf74 100644 --- a/internal/generated/snippets/bigquery/reservation/apiv1/Client/DeleteReservation/main.go +++ b/internal/generated/snippets/bigquery/reservation/apiv1/Client/DeleteReservation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/reservation/apiv1/Client/FailoverReservation/main.go b/internal/generated/snippets/bigquery/reservation/apiv1/Client/FailoverReservation/main.go index 52734237861f..92de0f027928 100644 --- a/internal/generated/snippets/bigquery/reservation/apiv1/Client/FailoverReservation/main.go +++ b/internal/generated/snippets/bigquery/reservation/apiv1/Client/FailoverReservation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/reservation/apiv1/Client/GetBiReservation/main.go b/internal/generated/snippets/bigquery/reservation/apiv1/Client/GetBiReservation/main.go index a697ebc0357f..e65ec2545838 100644 --- a/internal/generated/snippets/bigquery/reservation/apiv1/Client/GetBiReservation/main.go +++ b/internal/generated/snippets/bigquery/reservation/apiv1/Client/GetBiReservation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/reservation/apiv1/Client/GetCapacityCommitment/main.go b/internal/generated/snippets/bigquery/reservation/apiv1/Client/GetCapacityCommitment/main.go index fba2959bf08b..f3c1e17bc69b 100644 --- a/internal/generated/snippets/bigquery/reservation/apiv1/Client/GetCapacityCommitment/main.go +++ b/internal/generated/snippets/bigquery/reservation/apiv1/Client/GetCapacityCommitment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/reservation/apiv1/Client/GetReservation/main.go b/internal/generated/snippets/bigquery/reservation/apiv1/Client/GetReservation/main.go index 00d9ec7d6e6e..202d561d5bdf 100644 --- a/internal/generated/snippets/bigquery/reservation/apiv1/Client/GetReservation/main.go +++ b/internal/generated/snippets/bigquery/reservation/apiv1/Client/GetReservation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/reservation/apiv1/Client/ListAssignments/main.go b/internal/generated/snippets/bigquery/reservation/apiv1/Client/ListAssignments/main.go index 364ab6670aef..6533cc9ec383 100644 --- a/internal/generated/snippets/bigquery/reservation/apiv1/Client/ListAssignments/main.go +++ b/internal/generated/snippets/bigquery/reservation/apiv1/Client/ListAssignments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/reservation/apiv1/Client/ListCapacityCommitments/main.go b/internal/generated/snippets/bigquery/reservation/apiv1/Client/ListCapacityCommitments/main.go index aef4129c1eb6..a3f6775b6488 100644 --- a/internal/generated/snippets/bigquery/reservation/apiv1/Client/ListCapacityCommitments/main.go +++ b/internal/generated/snippets/bigquery/reservation/apiv1/Client/ListCapacityCommitments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/reservation/apiv1/Client/ListReservations/main.go b/internal/generated/snippets/bigquery/reservation/apiv1/Client/ListReservations/main.go index c74eb94e875d..e12f0a8c2c79 100644 --- a/internal/generated/snippets/bigquery/reservation/apiv1/Client/ListReservations/main.go +++ b/internal/generated/snippets/bigquery/reservation/apiv1/Client/ListReservations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/reservation/apiv1/Client/MergeCapacityCommitments/main.go b/internal/generated/snippets/bigquery/reservation/apiv1/Client/MergeCapacityCommitments/main.go index 4d661137c175..e2da6d6591e9 100644 --- a/internal/generated/snippets/bigquery/reservation/apiv1/Client/MergeCapacityCommitments/main.go +++ b/internal/generated/snippets/bigquery/reservation/apiv1/Client/MergeCapacityCommitments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/reservation/apiv1/Client/MoveAssignment/main.go b/internal/generated/snippets/bigquery/reservation/apiv1/Client/MoveAssignment/main.go index 5cff9c9a4b01..cfda31a3e619 100644 --- a/internal/generated/snippets/bigquery/reservation/apiv1/Client/MoveAssignment/main.go +++ b/internal/generated/snippets/bigquery/reservation/apiv1/Client/MoveAssignment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/reservation/apiv1/Client/SearchAllAssignments/main.go b/internal/generated/snippets/bigquery/reservation/apiv1/Client/SearchAllAssignments/main.go index ad000759ceef..2da0feedcecb 100644 --- a/internal/generated/snippets/bigquery/reservation/apiv1/Client/SearchAllAssignments/main.go +++ b/internal/generated/snippets/bigquery/reservation/apiv1/Client/SearchAllAssignments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/reservation/apiv1/Client/SearchAssignments/main.go b/internal/generated/snippets/bigquery/reservation/apiv1/Client/SearchAssignments/main.go index 6ab3aade497a..d4165ea456bb 100644 --- a/internal/generated/snippets/bigquery/reservation/apiv1/Client/SearchAssignments/main.go +++ b/internal/generated/snippets/bigquery/reservation/apiv1/Client/SearchAssignments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/reservation/apiv1/Client/SplitCapacityCommitment/main.go b/internal/generated/snippets/bigquery/reservation/apiv1/Client/SplitCapacityCommitment/main.go index fbcc5eefbb73..6e7baa770c2d 100644 --- a/internal/generated/snippets/bigquery/reservation/apiv1/Client/SplitCapacityCommitment/main.go +++ b/internal/generated/snippets/bigquery/reservation/apiv1/Client/SplitCapacityCommitment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/reservation/apiv1/Client/UpdateAssignment/main.go b/internal/generated/snippets/bigquery/reservation/apiv1/Client/UpdateAssignment/main.go index 7e2206d151a3..553b02f692c9 100644 --- a/internal/generated/snippets/bigquery/reservation/apiv1/Client/UpdateAssignment/main.go +++ b/internal/generated/snippets/bigquery/reservation/apiv1/Client/UpdateAssignment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/reservation/apiv1/Client/UpdateBiReservation/main.go b/internal/generated/snippets/bigquery/reservation/apiv1/Client/UpdateBiReservation/main.go index 7b472c029ebf..c5f2a251a706 100644 --- a/internal/generated/snippets/bigquery/reservation/apiv1/Client/UpdateBiReservation/main.go +++ b/internal/generated/snippets/bigquery/reservation/apiv1/Client/UpdateBiReservation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/reservation/apiv1/Client/UpdateCapacityCommitment/main.go b/internal/generated/snippets/bigquery/reservation/apiv1/Client/UpdateCapacityCommitment/main.go index d94fc408fccb..3bfefa6386f7 100644 --- a/internal/generated/snippets/bigquery/reservation/apiv1/Client/UpdateCapacityCommitment/main.go +++ b/internal/generated/snippets/bigquery/reservation/apiv1/Client/UpdateCapacityCommitment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/reservation/apiv1/Client/UpdateReservation/main.go b/internal/generated/snippets/bigquery/reservation/apiv1/Client/UpdateReservation/main.go index 636396d5bf22..31f08699970b 100644 --- a/internal/generated/snippets/bigquery/reservation/apiv1/Client/UpdateReservation/main.go +++ b/internal/generated/snippets/bigquery/reservation/apiv1/Client/UpdateReservation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/storage/apiv1/BigQueryReadClient/CreateReadSession/main.go b/internal/generated/snippets/bigquery/storage/apiv1/BigQueryReadClient/CreateReadSession/main.go index fdc07436c32a..9a9b7cf41f91 100644 --- a/internal/generated/snippets/bigquery/storage/apiv1/BigQueryReadClient/CreateReadSession/main.go +++ b/internal/generated/snippets/bigquery/storage/apiv1/BigQueryReadClient/CreateReadSession/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/storage/apiv1/BigQueryReadClient/SplitReadStream/main.go b/internal/generated/snippets/bigquery/storage/apiv1/BigQueryReadClient/SplitReadStream/main.go index 3de9d1c4a554..73f3ec3391f7 100644 --- a/internal/generated/snippets/bigquery/storage/apiv1/BigQueryReadClient/SplitReadStream/main.go +++ b/internal/generated/snippets/bigquery/storage/apiv1/BigQueryReadClient/SplitReadStream/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/storage/apiv1/BigQueryWriteClient/AppendRows/main.go b/internal/generated/snippets/bigquery/storage/apiv1/BigQueryWriteClient/AppendRows/main.go index 03b4b4a04ba1..f4f76240618c 100644 --- a/internal/generated/snippets/bigquery/storage/apiv1/BigQueryWriteClient/AppendRows/main.go +++ b/internal/generated/snippets/bigquery/storage/apiv1/BigQueryWriteClient/AppendRows/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/storage/apiv1/BigQueryWriteClient/BatchCommitWriteStreams/main.go b/internal/generated/snippets/bigquery/storage/apiv1/BigQueryWriteClient/BatchCommitWriteStreams/main.go index 449c8470e3a5..603ce561a3d4 100644 --- a/internal/generated/snippets/bigquery/storage/apiv1/BigQueryWriteClient/BatchCommitWriteStreams/main.go +++ b/internal/generated/snippets/bigquery/storage/apiv1/BigQueryWriteClient/BatchCommitWriteStreams/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/storage/apiv1/BigQueryWriteClient/CreateWriteStream/main.go b/internal/generated/snippets/bigquery/storage/apiv1/BigQueryWriteClient/CreateWriteStream/main.go index 075a6d1691c7..fe1392a714b9 100644 --- a/internal/generated/snippets/bigquery/storage/apiv1/BigQueryWriteClient/CreateWriteStream/main.go +++ b/internal/generated/snippets/bigquery/storage/apiv1/BigQueryWriteClient/CreateWriteStream/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/storage/apiv1/BigQueryWriteClient/FinalizeWriteStream/main.go b/internal/generated/snippets/bigquery/storage/apiv1/BigQueryWriteClient/FinalizeWriteStream/main.go index 5c03b03ad7e2..ef9aa0675c7c 100644 --- a/internal/generated/snippets/bigquery/storage/apiv1/BigQueryWriteClient/FinalizeWriteStream/main.go +++ b/internal/generated/snippets/bigquery/storage/apiv1/BigQueryWriteClient/FinalizeWriteStream/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/storage/apiv1/BigQueryWriteClient/FlushRows/main.go b/internal/generated/snippets/bigquery/storage/apiv1/BigQueryWriteClient/FlushRows/main.go index 8a12996dda2c..418c3d7897f6 100644 --- a/internal/generated/snippets/bigquery/storage/apiv1/BigQueryWriteClient/FlushRows/main.go +++ b/internal/generated/snippets/bigquery/storage/apiv1/BigQueryWriteClient/FlushRows/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/storage/apiv1/BigQueryWriteClient/GetWriteStream/main.go b/internal/generated/snippets/bigquery/storage/apiv1/BigQueryWriteClient/GetWriteStream/main.go index 035bedb5c239..87f9e2ce05d8 100644 --- a/internal/generated/snippets/bigquery/storage/apiv1/BigQueryWriteClient/GetWriteStream/main.go +++ b/internal/generated/snippets/bigquery/storage/apiv1/BigQueryWriteClient/GetWriteStream/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/storage/apiv1alpha/MetastorePartitionClient/BatchCreateMetastorePartitions/main.go b/internal/generated/snippets/bigquery/storage/apiv1alpha/MetastorePartitionClient/BatchCreateMetastorePartitions/main.go index 56989df2dcaa..f22e9199f848 100644 --- a/internal/generated/snippets/bigquery/storage/apiv1alpha/MetastorePartitionClient/BatchCreateMetastorePartitions/main.go +++ b/internal/generated/snippets/bigquery/storage/apiv1alpha/MetastorePartitionClient/BatchCreateMetastorePartitions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/storage/apiv1alpha/MetastorePartitionClient/BatchDeleteMetastorePartitions/main.go b/internal/generated/snippets/bigquery/storage/apiv1alpha/MetastorePartitionClient/BatchDeleteMetastorePartitions/main.go index 8497458bd00e..acf7e85b7261 100644 --- a/internal/generated/snippets/bigquery/storage/apiv1alpha/MetastorePartitionClient/BatchDeleteMetastorePartitions/main.go +++ b/internal/generated/snippets/bigquery/storage/apiv1alpha/MetastorePartitionClient/BatchDeleteMetastorePartitions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/storage/apiv1alpha/MetastorePartitionClient/BatchUpdateMetastorePartitions/main.go b/internal/generated/snippets/bigquery/storage/apiv1alpha/MetastorePartitionClient/BatchUpdateMetastorePartitions/main.go index 5e990dcd4c1f..d28303c68f6a 100644 --- a/internal/generated/snippets/bigquery/storage/apiv1alpha/MetastorePartitionClient/BatchUpdateMetastorePartitions/main.go +++ b/internal/generated/snippets/bigquery/storage/apiv1alpha/MetastorePartitionClient/BatchUpdateMetastorePartitions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/storage/apiv1alpha/MetastorePartitionClient/ListMetastorePartitions/main.go b/internal/generated/snippets/bigquery/storage/apiv1alpha/MetastorePartitionClient/ListMetastorePartitions/main.go index 1bd4a495dce5..c2201b973593 100644 --- a/internal/generated/snippets/bigquery/storage/apiv1alpha/MetastorePartitionClient/ListMetastorePartitions/main.go +++ b/internal/generated/snippets/bigquery/storage/apiv1alpha/MetastorePartitionClient/ListMetastorePartitions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/storage/apiv1alpha/MetastorePartitionClient/StreamMetastorePartitions/main.go b/internal/generated/snippets/bigquery/storage/apiv1alpha/MetastorePartitionClient/StreamMetastorePartitions/main.go index 57310bc0bf09..798d3c894269 100644 --- a/internal/generated/snippets/bigquery/storage/apiv1alpha/MetastorePartitionClient/StreamMetastorePartitions/main.go +++ b/internal/generated/snippets/bigquery/storage/apiv1alpha/MetastorePartitionClient/StreamMetastorePartitions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/storage/apiv1beta1/BigQueryStorageClient/BatchCreateReadSessionStreams/main.go b/internal/generated/snippets/bigquery/storage/apiv1beta1/BigQueryStorageClient/BatchCreateReadSessionStreams/main.go index ded9024e64e0..88864ba622eb 100644 --- a/internal/generated/snippets/bigquery/storage/apiv1beta1/BigQueryStorageClient/BatchCreateReadSessionStreams/main.go +++ b/internal/generated/snippets/bigquery/storage/apiv1beta1/BigQueryStorageClient/BatchCreateReadSessionStreams/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/storage/apiv1beta1/BigQueryStorageClient/CreateReadSession/main.go b/internal/generated/snippets/bigquery/storage/apiv1beta1/BigQueryStorageClient/CreateReadSession/main.go index 87487de3a3a5..28f5a18f8649 100644 --- a/internal/generated/snippets/bigquery/storage/apiv1beta1/BigQueryStorageClient/CreateReadSession/main.go +++ b/internal/generated/snippets/bigquery/storage/apiv1beta1/BigQueryStorageClient/CreateReadSession/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/storage/apiv1beta1/BigQueryStorageClient/FinalizeStream/main.go b/internal/generated/snippets/bigquery/storage/apiv1beta1/BigQueryStorageClient/FinalizeStream/main.go index 90e02fe8aed0..7bf570714b64 100644 --- a/internal/generated/snippets/bigquery/storage/apiv1beta1/BigQueryStorageClient/FinalizeStream/main.go +++ b/internal/generated/snippets/bigquery/storage/apiv1beta1/BigQueryStorageClient/FinalizeStream/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/storage/apiv1beta1/BigQueryStorageClient/SplitReadStream/main.go b/internal/generated/snippets/bigquery/storage/apiv1beta1/BigQueryStorageClient/SplitReadStream/main.go index 2b7077076d51..69c9090f1797 100644 --- a/internal/generated/snippets/bigquery/storage/apiv1beta1/BigQueryStorageClient/SplitReadStream/main.go +++ b/internal/generated/snippets/bigquery/storage/apiv1beta1/BigQueryStorageClient/SplitReadStream/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryReadClient/CreateReadSession/main.go b/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryReadClient/CreateReadSession/main.go index 5c7be059e2ef..82a433a0ac55 100644 --- a/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryReadClient/CreateReadSession/main.go +++ b/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryReadClient/CreateReadSession/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryReadClient/SplitReadStream/main.go b/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryReadClient/SplitReadStream/main.go index 2f302d6bea39..37b09c8f854b 100644 --- a/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryReadClient/SplitReadStream/main.go +++ b/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryReadClient/SplitReadStream/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryWriteClient/AppendRows/main.go b/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryWriteClient/AppendRows/main.go index cdb82c0eed7a..8e1b71d32b3d 100644 --- a/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryWriteClient/AppendRows/main.go +++ b/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryWriteClient/AppendRows/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryWriteClient/BatchCommitWriteStreams/main.go b/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryWriteClient/BatchCommitWriteStreams/main.go index 9c509180538b..074c2071e1f9 100644 --- a/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryWriteClient/BatchCommitWriteStreams/main.go +++ b/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryWriteClient/BatchCommitWriteStreams/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryWriteClient/CreateWriteStream/main.go b/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryWriteClient/CreateWriteStream/main.go index 0176bb3d00cd..046eb9b7b9f4 100644 --- a/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryWriteClient/CreateWriteStream/main.go +++ b/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryWriteClient/CreateWriteStream/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryWriteClient/FinalizeWriteStream/main.go b/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryWriteClient/FinalizeWriteStream/main.go index 2278f42bc3e2..b17cb7186e46 100644 --- a/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryWriteClient/FinalizeWriteStream/main.go +++ b/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryWriteClient/FinalizeWriteStream/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryWriteClient/FlushRows/main.go b/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryWriteClient/FlushRows/main.go index d7bfc33a0c3f..c42552cf4329 100644 --- a/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryWriteClient/FlushRows/main.go +++ b/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryWriteClient/FlushRows/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryWriteClient/GetWriteStream/main.go b/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryWriteClient/GetWriteStream/main.go index e238b6707a24..ae5bd9499424 100644 --- a/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryWriteClient/GetWriteStream/main.go +++ b/internal/generated/snippets/bigquery/storage/apiv1beta2/BigQueryWriteClient/GetWriteStream/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/billing/apiv1/CloudBillingClient/CreateBillingAccount/main.go b/internal/generated/snippets/billing/apiv1/CloudBillingClient/CreateBillingAccount/main.go index 3f8b4ffed41d..955bde35b965 100644 --- a/internal/generated/snippets/billing/apiv1/CloudBillingClient/CreateBillingAccount/main.go +++ b/internal/generated/snippets/billing/apiv1/CloudBillingClient/CreateBillingAccount/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/billing/apiv1/CloudBillingClient/GetBillingAccount/main.go b/internal/generated/snippets/billing/apiv1/CloudBillingClient/GetBillingAccount/main.go index 962acfc5d306..357c2f5bbba9 100644 --- a/internal/generated/snippets/billing/apiv1/CloudBillingClient/GetBillingAccount/main.go +++ b/internal/generated/snippets/billing/apiv1/CloudBillingClient/GetBillingAccount/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/billing/apiv1/CloudBillingClient/GetIamPolicy/main.go b/internal/generated/snippets/billing/apiv1/CloudBillingClient/GetIamPolicy/main.go index 27a8fe8a3038..e7901f9ad939 100644 --- a/internal/generated/snippets/billing/apiv1/CloudBillingClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/billing/apiv1/CloudBillingClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/billing/apiv1/CloudBillingClient/GetProjectBillingInfo/main.go b/internal/generated/snippets/billing/apiv1/CloudBillingClient/GetProjectBillingInfo/main.go index 99c945f3c840..686ea5215934 100644 --- a/internal/generated/snippets/billing/apiv1/CloudBillingClient/GetProjectBillingInfo/main.go +++ b/internal/generated/snippets/billing/apiv1/CloudBillingClient/GetProjectBillingInfo/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/billing/apiv1/CloudBillingClient/ListBillingAccounts/main.go b/internal/generated/snippets/billing/apiv1/CloudBillingClient/ListBillingAccounts/main.go index 9bd81d89c764..3abcdbda40ed 100644 --- a/internal/generated/snippets/billing/apiv1/CloudBillingClient/ListBillingAccounts/main.go +++ b/internal/generated/snippets/billing/apiv1/CloudBillingClient/ListBillingAccounts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/billing/apiv1/CloudBillingClient/ListProjectBillingInfo/main.go b/internal/generated/snippets/billing/apiv1/CloudBillingClient/ListProjectBillingInfo/main.go index ba4eb3cef002..f1ea63cdf7b4 100644 --- a/internal/generated/snippets/billing/apiv1/CloudBillingClient/ListProjectBillingInfo/main.go +++ b/internal/generated/snippets/billing/apiv1/CloudBillingClient/ListProjectBillingInfo/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/billing/apiv1/CloudBillingClient/MoveBillingAccount/main.go b/internal/generated/snippets/billing/apiv1/CloudBillingClient/MoveBillingAccount/main.go index dad546abc3be..faa73def42e2 100644 --- a/internal/generated/snippets/billing/apiv1/CloudBillingClient/MoveBillingAccount/main.go +++ b/internal/generated/snippets/billing/apiv1/CloudBillingClient/MoveBillingAccount/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/billing/apiv1/CloudBillingClient/SetIamPolicy/main.go b/internal/generated/snippets/billing/apiv1/CloudBillingClient/SetIamPolicy/main.go index ae60591b9709..62d63181e668 100644 --- a/internal/generated/snippets/billing/apiv1/CloudBillingClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/billing/apiv1/CloudBillingClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/billing/apiv1/CloudBillingClient/TestIamPermissions/main.go b/internal/generated/snippets/billing/apiv1/CloudBillingClient/TestIamPermissions/main.go index becb08a2517b..d1532850999b 100644 --- a/internal/generated/snippets/billing/apiv1/CloudBillingClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/billing/apiv1/CloudBillingClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/billing/apiv1/CloudBillingClient/UpdateBillingAccount/main.go b/internal/generated/snippets/billing/apiv1/CloudBillingClient/UpdateBillingAccount/main.go index 69de90a9ad17..08e4f4dd4655 100644 --- a/internal/generated/snippets/billing/apiv1/CloudBillingClient/UpdateBillingAccount/main.go +++ b/internal/generated/snippets/billing/apiv1/CloudBillingClient/UpdateBillingAccount/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/billing/apiv1/CloudBillingClient/UpdateProjectBillingInfo/main.go b/internal/generated/snippets/billing/apiv1/CloudBillingClient/UpdateProjectBillingInfo/main.go index d902b38d6da0..2af23efec533 100644 --- a/internal/generated/snippets/billing/apiv1/CloudBillingClient/UpdateProjectBillingInfo/main.go +++ b/internal/generated/snippets/billing/apiv1/CloudBillingClient/UpdateProjectBillingInfo/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/billing/apiv1/CloudCatalogClient/ListServices/main.go b/internal/generated/snippets/billing/apiv1/CloudCatalogClient/ListServices/main.go index d723cd629dfe..9c06e6494e43 100644 --- a/internal/generated/snippets/billing/apiv1/CloudCatalogClient/ListServices/main.go +++ b/internal/generated/snippets/billing/apiv1/CloudCatalogClient/ListServices/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/billing/apiv1/CloudCatalogClient/ListSkus/main.go b/internal/generated/snippets/billing/apiv1/CloudCatalogClient/ListSkus/main.go index 3106c4b85b24..2b40be7a8c6e 100644 --- a/internal/generated/snippets/billing/apiv1/CloudCatalogClient/ListSkus/main.go +++ b/internal/generated/snippets/billing/apiv1/CloudCatalogClient/ListSkus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/billing/budgets/apiv1/BudgetClient/CreateBudget/main.go b/internal/generated/snippets/billing/budgets/apiv1/BudgetClient/CreateBudget/main.go index e9cae761ed4b..07b703231409 100644 --- a/internal/generated/snippets/billing/budgets/apiv1/BudgetClient/CreateBudget/main.go +++ b/internal/generated/snippets/billing/budgets/apiv1/BudgetClient/CreateBudget/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/billing/budgets/apiv1/BudgetClient/DeleteBudget/main.go b/internal/generated/snippets/billing/budgets/apiv1/BudgetClient/DeleteBudget/main.go index 6dbdeceb297c..f5d09d2992d5 100644 --- a/internal/generated/snippets/billing/budgets/apiv1/BudgetClient/DeleteBudget/main.go +++ b/internal/generated/snippets/billing/budgets/apiv1/BudgetClient/DeleteBudget/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/billing/budgets/apiv1/BudgetClient/GetBudget/main.go b/internal/generated/snippets/billing/budgets/apiv1/BudgetClient/GetBudget/main.go index b25fba02566c..23063aef69bc 100644 --- a/internal/generated/snippets/billing/budgets/apiv1/BudgetClient/GetBudget/main.go +++ b/internal/generated/snippets/billing/budgets/apiv1/BudgetClient/GetBudget/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/billing/budgets/apiv1/BudgetClient/ListBudgets/main.go b/internal/generated/snippets/billing/budgets/apiv1/BudgetClient/ListBudgets/main.go index c492f72deb94..2ac3f57a72dd 100644 --- a/internal/generated/snippets/billing/budgets/apiv1/BudgetClient/ListBudgets/main.go +++ b/internal/generated/snippets/billing/budgets/apiv1/BudgetClient/ListBudgets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/billing/budgets/apiv1/BudgetClient/UpdateBudget/main.go b/internal/generated/snippets/billing/budgets/apiv1/BudgetClient/UpdateBudget/main.go index 7e0a83f305a3..e83d70d12de5 100644 --- a/internal/generated/snippets/billing/budgets/apiv1/BudgetClient/UpdateBudget/main.go +++ b/internal/generated/snippets/billing/budgets/apiv1/BudgetClient/UpdateBudget/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/billing/budgets/apiv1beta1/BudgetClient/CreateBudget/main.go b/internal/generated/snippets/billing/budgets/apiv1beta1/BudgetClient/CreateBudget/main.go index 548ca7070876..d55c0b99cc16 100644 --- a/internal/generated/snippets/billing/budgets/apiv1beta1/BudgetClient/CreateBudget/main.go +++ b/internal/generated/snippets/billing/budgets/apiv1beta1/BudgetClient/CreateBudget/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/billing/budgets/apiv1beta1/BudgetClient/DeleteBudget/main.go b/internal/generated/snippets/billing/budgets/apiv1beta1/BudgetClient/DeleteBudget/main.go index a88585736ef7..fac0b6d9196d 100644 --- a/internal/generated/snippets/billing/budgets/apiv1beta1/BudgetClient/DeleteBudget/main.go +++ b/internal/generated/snippets/billing/budgets/apiv1beta1/BudgetClient/DeleteBudget/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/billing/budgets/apiv1beta1/BudgetClient/GetBudget/main.go b/internal/generated/snippets/billing/budgets/apiv1beta1/BudgetClient/GetBudget/main.go index 4c6b77b2973c..7e260ee3af4b 100644 --- a/internal/generated/snippets/billing/budgets/apiv1beta1/BudgetClient/GetBudget/main.go +++ b/internal/generated/snippets/billing/budgets/apiv1beta1/BudgetClient/GetBudget/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/billing/budgets/apiv1beta1/BudgetClient/ListBudgets/main.go b/internal/generated/snippets/billing/budgets/apiv1beta1/BudgetClient/ListBudgets/main.go index bc6bf817d760..1462957b8f52 100644 --- a/internal/generated/snippets/billing/budgets/apiv1beta1/BudgetClient/ListBudgets/main.go +++ b/internal/generated/snippets/billing/budgets/apiv1beta1/BudgetClient/ListBudgets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/billing/budgets/apiv1beta1/BudgetClient/UpdateBudget/main.go b/internal/generated/snippets/billing/budgets/apiv1beta1/BudgetClient/UpdateBudget/main.go index 473d7cf4eac4..2aa475e1c5b0 100644 --- a/internal/generated/snippets/billing/budgets/apiv1beta1/BudgetClient/UpdateBudget/main.go +++ b/internal/generated/snippets/billing/budgets/apiv1beta1/BudgetClient/UpdateBudget/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/binaryauthorization/apiv1/BinauthzManagementClient/CreateAttestor/main.go b/internal/generated/snippets/binaryauthorization/apiv1/BinauthzManagementClient/CreateAttestor/main.go index e625f00a8d2f..a10c69d6b236 100644 --- a/internal/generated/snippets/binaryauthorization/apiv1/BinauthzManagementClient/CreateAttestor/main.go +++ b/internal/generated/snippets/binaryauthorization/apiv1/BinauthzManagementClient/CreateAttestor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/binaryauthorization/apiv1/BinauthzManagementClient/DeleteAttestor/main.go b/internal/generated/snippets/binaryauthorization/apiv1/BinauthzManagementClient/DeleteAttestor/main.go index 9cba4b098603..89c8313ed24e 100644 --- a/internal/generated/snippets/binaryauthorization/apiv1/BinauthzManagementClient/DeleteAttestor/main.go +++ b/internal/generated/snippets/binaryauthorization/apiv1/BinauthzManagementClient/DeleteAttestor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/binaryauthorization/apiv1/BinauthzManagementClient/GetAttestor/main.go b/internal/generated/snippets/binaryauthorization/apiv1/BinauthzManagementClient/GetAttestor/main.go index 005fcbb86d6b..29ac9dd308e4 100644 --- a/internal/generated/snippets/binaryauthorization/apiv1/BinauthzManagementClient/GetAttestor/main.go +++ b/internal/generated/snippets/binaryauthorization/apiv1/BinauthzManagementClient/GetAttestor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/binaryauthorization/apiv1/BinauthzManagementClient/GetPolicy/main.go b/internal/generated/snippets/binaryauthorization/apiv1/BinauthzManagementClient/GetPolicy/main.go index 03f577b76408..d04eb49ea683 100644 --- a/internal/generated/snippets/binaryauthorization/apiv1/BinauthzManagementClient/GetPolicy/main.go +++ b/internal/generated/snippets/binaryauthorization/apiv1/BinauthzManagementClient/GetPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/binaryauthorization/apiv1/BinauthzManagementClient/ListAttestors/main.go b/internal/generated/snippets/binaryauthorization/apiv1/BinauthzManagementClient/ListAttestors/main.go index 32efccd956fb..494cabfe7c5f 100644 --- a/internal/generated/snippets/binaryauthorization/apiv1/BinauthzManagementClient/ListAttestors/main.go +++ b/internal/generated/snippets/binaryauthorization/apiv1/BinauthzManagementClient/ListAttestors/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/binaryauthorization/apiv1/BinauthzManagementClient/UpdateAttestor/main.go b/internal/generated/snippets/binaryauthorization/apiv1/BinauthzManagementClient/UpdateAttestor/main.go index c87719a8d27e..9e5729c93024 100644 --- a/internal/generated/snippets/binaryauthorization/apiv1/BinauthzManagementClient/UpdateAttestor/main.go +++ b/internal/generated/snippets/binaryauthorization/apiv1/BinauthzManagementClient/UpdateAttestor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/binaryauthorization/apiv1/BinauthzManagementClient/UpdatePolicy/main.go b/internal/generated/snippets/binaryauthorization/apiv1/BinauthzManagementClient/UpdatePolicy/main.go index 74b43a825b55..503edd1b0758 100644 --- a/internal/generated/snippets/binaryauthorization/apiv1/BinauthzManagementClient/UpdatePolicy/main.go +++ b/internal/generated/snippets/binaryauthorization/apiv1/BinauthzManagementClient/UpdatePolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/binaryauthorization/apiv1/SystemPolicyClient/GetSystemPolicy/main.go b/internal/generated/snippets/binaryauthorization/apiv1/SystemPolicyClient/GetSystemPolicy/main.go index 83c1577b428f..b2914097427a 100644 --- a/internal/generated/snippets/binaryauthorization/apiv1/SystemPolicyClient/GetSystemPolicy/main.go +++ b/internal/generated/snippets/binaryauthorization/apiv1/SystemPolicyClient/GetSystemPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/binaryauthorization/apiv1/ValidationHelperClient/ValidateAttestationOccurrence/main.go b/internal/generated/snippets/binaryauthorization/apiv1/ValidationHelperClient/ValidateAttestationOccurrence/main.go index 1844a237c27f..29d152ca459f 100644 --- a/internal/generated/snippets/binaryauthorization/apiv1/ValidationHelperClient/ValidateAttestationOccurrence/main.go +++ b/internal/generated/snippets/binaryauthorization/apiv1/ValidationHelperClient/ValidateAttestationOccurrence/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/binaryauthorization/apiv1/snippet_metadata.google.cloud.binaryauthorization.v1.json b/internal/generated/snippets/binaryauthorization/apiv1/snippet_metadata.google.cloud.binaryauthorization.v1.json index 21549953212c..5ef2f1c16dad 100644 --- a/internal/generated/snippets/binaryauthorization/apiv1/snippet_metadata.google.cloud.binaryauthorization.v1.json +++ b/internal/generated/snippets/binaryauthorization/apiv1/snippet_metadata.google.cloud.binaryauthorization.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/binaryauthorization/apiv1", - "version": "1.9.2", + "version": "1.9.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/binaryauthorization/apiv1beta1/BinauthzManagementServiceV1Beta1Client/CreateAttestor/main.go b/internal/generated/snippets/binaryauthorization/apiv1beta1/BinauthzManagementServiceV1Beta1Client/CreateAttestor/main.go index 3f5e96c8cb62..566117e232ac 100644 --- a/internal/generated/snippets/binaryauthorization/apiv1beta1/BinauthzManagementServiceV1Beta1Client/CreateAttestor/main.go +++ b/internal/generated/snippets/binaryauthorization/apiv1beta1/BinauthzManagementServiceV1Beta1Client/CreateAttestor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/binaryauthorization/apiv1beta1/BinauthzManagementServiceV1Beta1Client/DeleteAttestor/main.go b/internal/generated/snippets/binaryauthorization/apiv1beta1/BinauthzManagementServiceV1Beta1Client/DeleteAttestor/main.go index 990be5992606..1dd83a509ecf 100644 --- a/internal/generated/snippets/binaryauthorization/apiv1beta1/BinauthzManagementServiceV1Beta1Client/DeleteAttestor/main.go +++ b/internal/generated/snippets/binaryauthorization/apiv1beta1/BinauthzManagementServiceV1Beta1Client/DeleteAttestor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/binaryauthorization/apiv1beta1/BinauthzManagementServiceV1Beta1Client/GetAttestor/main.go b/internal/generated/snippets/binaryauthorization/apiv1beta1/BinauthzManagementServiceV1Beta1Client/GetAttestor/main.go index 0363cd11d2ca..29c27aae7a72 100644 --- a/internal/generated/snippets/binaryauthorization/apiv1beta1/BinauthzManagementServiceV1Beta1Client/GetAttestor/main.go +++ b/internal/generated/snippets/binaryauthorization/apiv1beta1/BinauthzManagementServiceV1Beta1Client/GetAttestor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/binaryauthorization/apiv1beta1/BinauthzManagementServiceV1Beta1Client/GetPolicy/main.go b/internal/generated/snippets/binaryauthorization/apiv1beta1/BinauthzManagementServiceV1Beta1Client/GetPolicy/main.go index 55ed58f25e9a..d72e0cbcf050 100644 --- a/internal/generated/snippets/binaryauthorization/apiv1beta1/BinauthzManagementServiceV1Beta1Client/GetPolicy/main.go +++ b/internal/generated/snippets/binaryauthorization/apiv1beta1/BinauthzManagementServiceV1Beta1Client/GetPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/binaryauthorization/apiv1beta1/BinauthzManagementServiceV1Beta1Client/ListAttestors/main.go b/internal/generated/snippets/binaryauthorization/apiv1beta1/BinauthzManagementServiceV1Beta1Client/ListAttestors/main.go index 94fe3716f326..259f509161b1 100644 --- a/internal/generated/snippets/binaryauthorization/apiv1beta1/BinauthzManagementServiceV1Beta1Client/ListAttestors/main.go +++ b/internal/generated/snippets/binaryauthorization/apiv1beta1/BinauthzManagementServiceV1Beta1Client/ListAttestors/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/binaryauthorization/apiv1beta1/BinauthzManagementServiceV1Beta1Client/UpdateAttestor/main.go b/internal/generated/snippets/binaryauthorization/apiv1beta1/BinauthzManagementServiceV1Beta1Client/UpdateAttestor/main.go index 0da007aeac6a..38a4dfaab167 100644 --- a/internal/generated/snippets/binaryauthorization/apiv1beta1/BinauthzManagementServiceV1Beta1Client/UpdateAttestor/main.go +++ b/internal/generated/snippets/binaryauthorization/apiv1beta1/BinauthzManagementServiceV1Beta1Client/UpdateAttestor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/binaryauthorization/apiv1beta1/BinauthzManagementServiceV1Beta1Client/UpdatePolicy/main.go b/internal/generated/snippets/binaryauthorization/apiv1beta1/BinauthzManagementServiceV1Beta1Client/UpdatePolicy/main.go index d6c67d68cc12..db73a9727d6d 100644 --- a/internal/generated/snippets/binaryauthorization/apiv1beta1/BinauthzManagementServiceV1Beta1Client/UpdatePolicy/main.go +++ b/internal/generated/snippets/binaryauthorization/apiv1beta1/BinauthzManagementServiceV1Beta1Client/UpdatePolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/binaryauthorization/apiv1beta1/SystemPolicyV1Beta1Client/GetSystemPolicy/main.go b/internal/generated/snippets/binaryauthorization/apiv1beta1/SystemPolicyV1Beta1Client/GetSystemPolicy/main.go index b6fd105f3c3c..35467b7f6f23 100644 --- a/internal/generated/snippets/binaryauthorization/apiv1beta1/SystemPolicyV1Beta1Client/GetSystemPolicy/main.go +++ b/internal/generated/snippets/binaryauthorization/apiv1beta1/SystemPolicyV1Beta1Client/GetSystemPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/binaryauthorization/apiv1beta1/snippet_metadata.google.cloud.binaryauthorization.v1beta1.json b/internal/generated/snippets/binaryauthorization/apiv1beta1/snippet_metadata.google.cloud.binaryauthorization.v1beta1.json index 3bc31c3bd6f5..b264087ac617 100644 --- a/internal/generated/snippets/binaryauthorization/apiv1beta1/snippet_metadata.google.cloud.binaryauthorization.v1beta1.json +++ b/internal/generated/snippets/binaryauthorization/apiv1beta1/snippet_metadata.google.cloud.binaryauthorization.v1beta1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/binaryauthorization/apiv1beta1", - "version": "1.9.2", + "version": "1.9.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/CancelOperation/main.go index 9568ecaab106..5ea957ca0d67 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/CreateCertificate/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/CreateCertificate/main.go index d4ba28349ec2..54a40da4b6af 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/CreateCertificate/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/CreateCertificate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/CreateCertificateIssuanceConfig/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/CreateCertificateIssuanceConfig/main.go index 950513d425ee..1efb54a8e5ce 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/CreateCertificateIssuanceConfig/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/CreateCertificateIssuanceConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/CreateCertificateMap/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/CreateCertificateMap/main.go index 6ccefa373626..98c2d8e8fccc 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/CreateCertificateMap/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/CreateCertificateMap/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/CreateCertificateMapEntry/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/CreateCertificateMapEntry/main.go index 73c65ce5f5d8..daf72d4a0f09 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/CreateCertificateMapEntry/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/CreateCertificateMapEntry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/CreateDnsAuthorization/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/CreateDnsAuthorization/main.go index a5bec2ce2634..7c52858e2d70 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/CreateDnsAuthorization/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/CreateDnsAuthorization/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/CreateTrustConfig/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/CreateTrustConfig/main.go index 57153b59abbc..0c0362804258 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/CreateTrustConfig/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/CreateTrustConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/DeleteCertificate/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/DeleteCertificate/main.go index 4c6414be687f..d9897199a90c 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/DeleteCertificate/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/DeleteCertificate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/DeleteCertificateIssuanceConfig/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/DeleteCertificateIssuanceConfig/main.go index 8e3bc5626063..3925107b7712 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/DeleteCertificateIssuanceConfig/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/DeleteCertificateIssuanceConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/DeleteCertificateMap/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/DeleteCertificateMap/main.go index bc6ebdf6c969..5600570c59cd 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/DeleteCertificateMap/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/DeleteCertificateMap/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/DeleteCertificateMapEntry/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/DeleteCertificateMapEntry/main.go index d708c0454e11..fb42608697a7 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/DeleteCertificateMapEntry/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/DeleteCertificateMapEntry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/DeleteDnsAuthorization/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/DeleteDnsAuthorization/main.go index 0a099438ad9d..a3a59c832994 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/DeleteDnsAuthorization/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/DeleteDnsAuthorization/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/DeleteOperation/main.go index f89572c222d9..22c97a509a6c 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/DeleteTrustConfig/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/DeleteTrustConfig/main.go index a9cb7e0e1e3b..51649b1c2c53 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/DeleteTrustConfig/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/DeleteTrustConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/GetCertificate/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/GetCertificate/main.go index 5264ad66d221..00cd1d6f63b5 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/GetCertificate/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/GetCertificate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/GetCertificateIssuanceConfig/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/GetCertificateIssuanceConfig/main.go index aa385464bab1..045989a1bfef 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/GetCertificateIssuanceConfig/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/GetCertificateIssuanceConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/GetCertificateMap/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/GetCertificateMap/main.go index 86f06b4dc8f2..c3387c7e0dd4 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/GetCertificateMap/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/GetCertificateMap/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/GetCertificateMapEntry/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/GetCertificateMapEntry/main.go index 8b277868451f..031b09d85373 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/GetCertificateMapEntry/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/GetCertificateMapEntry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/GetDnsAuthorization/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/GetDnsAuthorization/main.go index a5ac2e485a1b..438ee6e2b422 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/GetDnsAuthorization/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/GetDnsAuthorization/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/GetLocation/main.go index 762d9897d137..5cb698efd244 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/GetOperation/main.go index 0785a005c29a..2be07716e7d0 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/GetTrustConfig/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/GetTrustConfig/main.go index 6528ebe2575a..6531962f127f 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/GetTrustConfig/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/GetTrustConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/ListCertificateIssuanceConfigs/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/ListCertificateIssuanceConfigs/main.go index 01a93be61666..35670910c171 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/ListCertificateIssuanceConfigs/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/ListCertificateIssuanceConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/ListCertificateMapEntries/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/ListCertificateMapEntries/main.go index d3a8ad11b049..14913c182f0c 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/ListCertificateMapEntries/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/ListCertificateMapEntries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/ListCertificateMaps/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/ListCertificateMaps/main.go index bf8b995b97d1..6e92b42ed227 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/ListCertificateMaps/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/ListCertificateMaps/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/ListCertificates/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/ListCertificates/main.go index 0728b7fa16cd..238598ccf941 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/ListCertificates/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/ListCertificates/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/ListDnsAuthorizations/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/ListDnsAuthorizations/main.go index 9f236580e125..cd2c684637af 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/ListDnsAuthorizations/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/ListDnsAuthorizations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/ListLocations/main.go index 3ada56396f73..9de1492f3d7a 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/ListOperations/main.go index f096e49ea231..125b60522616 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/ListTrustConfigs/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/ListTrustConfigs/main.go index f7410f288114..0f05abd25523 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/ListTrustConfigs/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/ListTrustConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/UpdateCertificate/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/UpdateCertificate/main.go index ea9bccc64489..6fd6b8f1dd7c 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/UpdateCertificate/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/UpdateCertificate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/UpdateCertificateMap/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/UpdateCertificateMap/main.go index 16d759925ce3..3c1702137c16 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/UpdateCertificateMap/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/UpdateCertificateMap/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/UpdateCertificateMapEntry/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/UpdateCertificateMapEntry/main.go index deb5accd134b..06b0800e45e8 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/UpdateCertificateMapEntry/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/UpdateCertificateMapEntry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/UpdateDnsAuthorization/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/UpdateDnsAuthorization/main.go index 2469546dcbc3..256ba9039e5c 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/UpdateDnsAuthorization/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/UpdateDnsAuthorization/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/Client/UpdateTrustConfig/main.go b/internal/generated/snippets/certificatemanager/apiv1/Client/UpdateTrustConfig/main.go index 3f1da34e5a87..4a7b0d1a2212 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/Client/UpdateTrustConfig/main.go +++ b/internal/generated/snippets/certificatemanager/apiv1/Client/UpdateTrustConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/certificatemanager/apiv1/snippet_metadata.google.cloud.certificatemanager.v1.json b/internal/generated/snippets/certificatemanager/apiv1/snippet_metadata.google.cloud.certificatemanager.v1.json index fa383069e98b..e6a8b3c9913c 100644 --- a/internal/generated/snippets/certificatemanager/apiv1/snippet_metadata.google.cloud.certificatemanager.v1.json +++ b/internal/generated/snippets/certificatemanager/apiv1/snippet_metadata.google.cloud.certificatemanager.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/certificatemanager/apiv1", - "version": "1.9.2", + "version": "1.9.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ActivateEntitlement/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ActivateEntitlement/main.go index d7a1d0b90f78..c173f25c405c 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ActivateEntitlement/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ActivateEntitlement/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/CancelEntitlement/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/CancelEntitlement/main.go index be7b091ef0da..cbe33c7d978b 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/CancelEntitlement/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/CancelEntitlement/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/CancelOperation/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/CancelOperation/main.go index 758290a582d3..5429dca47093 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/CancelOperation/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ChangeOffer/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ChangeOffer/main.go index ebd2a358d9db..5d29b566402a 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ChangeOffer/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ChangeOffer/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ChangeParameters/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ChangeParameters/main.go index 0f511c45015b..54aa456a5a1a 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ChangeParameters/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ChangeParameters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ChangeRenewalSettings/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ChangeRenewalSettings/main.go index 3a20da39bf33..05832795582e 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ChangeRenewalSettings/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ChangeRenewalSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/CheckCloudIdentityAccountsExist/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/CheckCloudIdentityAccountsExist/main.go index 69e944cd7d68..deb83430617d 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/CheckCloudIdentityAccountsExist/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/CheckCloudIdentityAccountsExist/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/CreateChannelPartnerLink/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/CreateChannelPartnerLink/main.go index 44c7a8a597b1..0c1d18aa8aea 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/CreateChannelPartnerLink/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/CreateChannelPartnerLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/CreateChannelPartnerRepricingConfig/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/CreateChannelPartnerRepricingConfig/main.go index 732360280126..5a06e87dff83 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/CreateChannelPartnerRepricingConfig/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/CreateChannelPartnerRepricingConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/CreateCustomer/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/CreateCustomer/main.go index 277173bc9a14..69c3bccf6e94 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/CreateCustomer/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/CreateCustomer/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/CreateCustomerRepricingConfig/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/CreateCustomerRepricingConfig/main.go index f3bcbdeca377..b7b77f1f942e 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/CreateCustomerRepricingConfig/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/CreateCustomerRepricingConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/CreateEntitlement/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/CreateEntitlement/main.go index 55f1568b91da..e17b2feefbc5 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/CreateEntitlement/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/CreateEntitlement/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/DeleteChannelPartnerRepricingConfig/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/DeleteChannelPartnerRepricingConfig/main.go index f8522e568685..5ba8632b7aa0 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/DeleteChannelPartnerRepricingConfig/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/DeleteChannelPartnerRepricingConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/DeleteCustomer/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/DeleteCustomer/main.go index 35a191051ba1..3571ae8f579c 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/DeleteCustomer/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/DeleteCustomer/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/DeleteCustomerRepricingConfig/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/DeleteCustomerRepricingConfig/main.go index 638b50976096..e140ff13be14 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/DeleteCustomerRepricingConfig/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/DeleteCustomerRepricingConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/DeleteOperation/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/DeleteOperation/main.go index f3b14a78c267..5716fba95836 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/DeleteOperation/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/GetChannelPartnerLink/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/GetChannelPartnerLink/main.go index 20ecdeca1671..fccd62d535f2 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/GetChannelPartnerLink/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/GetChannelPartnerLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/GetChannelPartnerRepricingConfig/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/GetChannelPartnerRepricingConfig/main.go index 24844052341c..274dc2442e11 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/GetChannelPartnerRepricingConfig/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/GetChannelPartnerRepricingConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/GetCustomer/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/GetCustomer/main.go index be1d284793d4..55ac4c748a7c 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/GetCustomer/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/GetCustomer/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/GetCustomerRepricingConfig/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/GetCustomerRepricingConfig/main.go index fea33687a037..970f69bb0e22 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/GetCustomerRepricingConfig/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/GetCustomerRepricingConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/GetEntitlement/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/GetEntitlement/main.go index 5f52fe4ee2e0..396a99476ba9 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/GetEntitlement/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/GetEntitlement/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/GetOperation/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/GetOperation/main.go index 8ef4592443ef..b27b3797d017 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/GetOperation/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ImportCustomer/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ImportCustomer/main.go index 4bdf92ef52a2..83cafddf8e8c 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ImportCustomer/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ImportCustomer/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListChannelPartnerLinks/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListChannelPartnerLinks/main.go index 2cff1b6f2eaf..917b69e33c33 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListChannelPartnerLinks/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListChannelPartnerLinks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListChannelPartnerRepricingConfigs/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListChannelPartnerRepricingConfigs/main.go index de4f93ee3c49..991cf44dfb1e 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListChannelPartnerRepricingConfigs/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListChannelPartnerRepricingConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListCustomerRepricingConfigs/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListCustomerRepricingConfigs/main.go index 63c397f4f9c2..43c31f72d700 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListCustomerRepricingConfigs/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListCustomerRepricingConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListCustomers/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListCustomers/main.go index 076e910da125..26ee0017f055 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListCustomers/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListCustomers/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListEntitlementChanges/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListEntitlementChanges/main.go index 608eccba5ed1..6a09a477858c 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListEntitlementChanges/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListEntitlementChanges/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListEntitlements/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListEntitlements/main.go index 7f64ce2802c8..30448111bfb5 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListEntitlements/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListEntitlements/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListOffers/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListOffers/main.go index 61aa61c55b88..41a73b2d6c5d 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListOffers/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListOffers/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListOperations/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListOperations/main.go index 677483e2219f..49d241b5336d 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListOperations/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListProducts/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListProducts/main.go index 099687d2f2de..96bc2c538334 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListProducts/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListProducts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListPurchasableOffers/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListPurchasableOffers/main.go index f775beafc380..d360dd9e73f2 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListPurchasableOffers/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListPurchasableOffers/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListPurchasableSkus/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListPurchasableSkus/main.go index 44fab54fa26b..282b15661afa 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListPurchasableSkus/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListPurchasableSkus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListSkuGroupBillableSkus/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListSkuGroupBillableSkus/main.go index c028e23f5985..b1affce95f47 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListSkuGroupBillableSkus/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListSkuGroupBillableSkus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListSkuGroups/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListSkuGroups/main.go index 21694889cb7f..552f0593db88 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListSkuGroups/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListSkuGroups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListSkus/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListSkus/main.go index 07787b7140c1..83277dd9b23c 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListSkus/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListSkus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListSubscribers/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListSubscribers/main.go index 7d849d939aa1..02d33a83253f 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListSubscribers/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListSubscribers/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListTransferableOffers/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListTransferableOffers/main.go index 0e19e264f0bd..b7d72bfc45c4 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListTransferableOffers/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListTransferableOffers/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListTransferableSkus/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListTransferableSkus/main.go index 2bc7f196e154..caea4eb08d47 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListTransferableSkus/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ListTransferableSkus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/LookupOffer/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/LookupOffer/main.go index 1f8cc1d06584..ee3c45f1641b 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/LookupOffer/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/LookupOffer/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ProvisionCloudIdentity/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ProvisionCloudIdentity/main.go index 53279a9b09bd..7e3c44d29462 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/ProvisionCloudIdentity/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/ProvisionCloudIdentity/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/QueryEligibleBillingAccounts/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/QueryEligibleBillingAccounts/main.go index 7d3cf7b8401c..1064122f29e6 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/QueryEligibleBillingAccounts/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/QueryEligibleBillingAccounts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/RegisterSubscriber/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/RegisterSubscriber/main.go index e04a3cd9241c..e5e2f937ab61 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/RegisterSubscriber/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/RegisterSubscriber/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/StartPaidService/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/StartPaidService/main.go index 6609999bea60..125e06c0aca8 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/StartPaidService/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/StartPaidService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/SuspendEntitlement/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/SuspendEntitlement/main.go index e1ec6c9edec2..0377109b5557 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/SuspendEntitlement/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/SuspendEntitlement/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/TransferEntitlements/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/TransferEntitlements/main.go index d94192cadd7a..c6e00e20343c 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/TransferEntitlements/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/TransferEntitlements/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/TransferEntitlementsToGoogle/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/TransferEntitlementsToGoogle/main.go index deff0df04189..343f8ab028c2 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/TransferEntitlementsToGoogle/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/TransferEntitlementsToGoogle/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/UnregisterSubscriber/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/UnregisterSubscriber/main.go index 66b559e49a07..e2bed47358f9 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/UnregisterSubscriber/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/UnregisterSubscriber/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/UpdateChannelPartnerLink/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/UpdateChannelPartnerLink/main.go index 2589958d708e..d2d62819fb7d 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/UpdateChannelPartnerLink/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/UpdateChannelPartnerLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/UpdateChannelPartnerRepricingConfig/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/UpdateChannelPartnerRepricingConfig/main.go index 53037f3564a1..2c73f96aac44 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/UpdateChannelPartnerRepricingConfig/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/UpdateChannelPartnerRepricingConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/UpdateCustomer/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/UpdateCustomer/main.go index 0bda7b80c5c7..3a693484943b 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/UpdateCustomer/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/UpdateCustomer/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelClient/UpdateCustomerRepricingConfig/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelClient/UpdateCustomerRepricingConfig/main.go index b529ebf346a0..c7f76491dde6 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelClient/UpdateCustomerRepricingConfig/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelClient/UpdateCustomerRepricingConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelReportsClient/CancelOperation/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelReportsClient/CancelOperation/main.go index 5e42ae65a8f4..28699d429d25 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelReportsClient/CancelOperation/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelReportsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelReportsClient/DeleteOperation/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelReportsClient/DeleteOperation/main.go index 095c897e117e..8b38c4ebfda9 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelReportsClient/DeleteOperation/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelReportsClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelReportsClient/FetchReportResults/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelReportsClient/FetchReportResults/main.go index a851fa2bff6b..d67145652a40 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelReportsClient/FetchReportResults/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelReportsClient/FetchReportResults/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelReportsClient/GetOperation/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelReportsClient/GetOperation/main.go index f01732113d0d..67a4dceba084 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelReportsClient/GetOperation/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelReportsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelReportsClient/ListOperations/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelReportsClient/ListOperations/main.go index 6dcb92329430..18e62eb349b1 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelReportsClient/ListOperations/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelReportsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelReportsClient/ListReports/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelReportsClient/ListReports/main.go index 293f935ecbb1..96cea052cf50 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelReportsClient/ListReports/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelReportsClient/ListReports/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/channel/apiv1/CloudChannelReportsClient/RunReportJob/main.go b/internal/generated/snippets/channel/apiv1/CloudChannelReportsClient/RunReportJob/main.go index a3e03e440a75..0cad82f5ae4a 100644 --- a/internal/generated/snippets/channel/apiv1/CloudChannelReportsClient/RunReportJob/main.go +++ b/internal/generated/snippets/channel/apiv1/CloudChannelReportsClient/RunReportJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/CompleteImportSpace/main.go b/internal/generated/snippets/chat/apiv1/Client/CompleteImportSpace/main.go index 473c46e06964..8048560da0de 100644 --- a/internal/generated/snippets/chat/apiv1/Client/CompleteImportSpace/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/CompleteImportSpace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/CreateMembership/main.go b/internal/generated/snippets/chat/apiv1/Client/CreateMembership/main.go index 1e6a39f7ac76..602e7e17936d 100644 --- a/internal/generated/snippets/chat/apiv1/Client/CreateMembership/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/CreateMembership/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/CreateMessage/main.go b/internal/generated/snippets/chat/apiv1/Client/CreateMessage/main.go index 6831fccb6669..cd82a4a2f8be 100644 --- a/internal/generated/snippets/chat/apiv1/Client/CreateMessage/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/CreateMessage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/CreateReaction/main.go b/internal/generated/snippets/chat/apiv1/Client/CreateReaction/main.go index 0c8c97a4b9fe..439dc21c923a 100644 --- a/internal/generated/snippets/chat/apiv1/Client/CreateReaction/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/CreateReaction/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/CreateSpace/main.go b/internal/generated/snippets/chat/apiv1/Client/CreateSpace/main.go index d425f5868e60..d5dd71f6c5c7 100644 --- a/internal/generated/snippets/chat/apiv1/Client/CreateSpace/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/CreateSpace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/DeleteMembership/main.go b/internal/generated/snippets/chat/apiv1/Client/DeleteMembership/main.go index 8886662de358..0f640d831f13 100644 --- a/internal/generated/snippets/chat/apiv1/Client/DeleteMembership/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/DeleteMembership/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/DeleteMessage/main.go b/internal/generated/snippets/chat/apiv1/Client/DeleteMessage/main.go index 883dd11f6ace..b29d4d4d4e7e 100644 --- a/internal/generated/snippets/chat/apiv1/Client/DeleteMessage/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/DeleteMessage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/DeleteReaction/main.go b/internal/generated/snippets/chat/apiv1/Client/DeleteReaction/main.go index 805f69b9b355..daf16f052a8c 100644 --- a/internal/generated/snippets/chat/apiv1/Client/DeleteReaction/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/DeleteReaction/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/DeleteSpace/main.go b/internal/generated/snippets/chat/apiv1/Client/DeleteSpace/main.go index 7874e560ec6b..2db40fa60921 100644 --- a/internal/generated/snippets/chat/apiv1/Client/DeleteSpace/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/DeleteSpace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/FindDirectMessage/main.go b/internal/generated/snippets/chat/apiv1/Client/FindDirectMessage/main.go index d18573cd1b10..9f0a335d14b6 100644 --- a/internal/generated/snippets/chat/apiv1/Client/FindDirectMessage/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/FindDirectMessage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/GetAttachment/main.go b/internal/generated/snippets/chat/apiv1/Client/GetAttachment/main.go index 2a6f0d7c27eb..ac0c8b9b732c 100644 --- a/internal/generated/snippets/chat/apiv1/Client/GetAttachment/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/GetAttachment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/GetMembership/main.go b/internal/generated/snippets/chat/apiv1/Client/GetMembership/main.go index 3e480c621c4c..be850c3b9d3a 100644 --- a/internal/generated/snippets/chat/apiv1/Client/GetMembership/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/GetMembership/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/GetMessage/main.go b/internal/generated/snippets/chat/apiv1/Client/GetMessage/main.go index 2b8ef0986b92..7c9fa22e40d0 100644 --- a/internal/generated/snippets/chat/apiv1/Client/GetMessage/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/GetMessage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/GetSpace/main.go b/internal/generated/snippets/chat/apiv1/Client/GetSpace/main.go index 3d5aaf119423..6c99e1f0671a 100644 --- a/internal/generated/snippets/chat/apiv1/Client/GetSpace/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/GetSpace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/GetSpaceEvent/main.go b/internal/generated/snippets/chat/apiv1/Client/GetSpaceEvent/main.go index 45223155ab94..db13911590d0 100644 --- a/internal/generated/snippets/chat/apiv1/Client/GetSpaceEvent/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/GetSpaceEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/GetSpaceReadState/main.go b/internal/generated/snippets/chat/apiv1/Client/GetSpaceReadState/main.go index 83bbb3cb589d..da025e109c70 100644 --- a/internal/generated/snippets/chat/apiv1/Client/GetSpaceReadState/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/GetSpaceReadState/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/GetThreadReadState/main.go b/internal/generated/snippets/chat/apiv1/Client/GetThreadReadState/main.go index 7510ca9d686d..920d09579aba 100644 --- a/internal/generated/snippets/chat/apiv1/Client/GetThreadReadState/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/GetThreadReadState/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/ListMemberships/main.go b/internal/generated/snippets/chat/apiv1/Client/ListMemberships/main.go index 27c2a15e1f5d..71113c223952 100644 --- a/internal/generated/snippets/chat/apiv1/Client/ListMemberships/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/ListMemberships/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/ListMessages/main.go b/internal/generated/snippets/chat/apiv1/Client/ListMessages/main.go index 652333194aae..71fd55b1a5ee 100644 --- a/internal/generated/snippets/chat/apiv1/Client/ListMessages/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/ListMessages/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/ListReactions/main.go b/internal/generated/snippets/chat/apiv1/Client/ListReactions/main.go index 565a61ed1008..2d6f6089190a 100644 --- a/internal/generated/snippets/chat/apiv1/Client/ListReactions/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/ListReactions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/ListSpaceEvents/main.go b/internal/generated/snippets/chat/apiv1/Client/ListSpaceEvents/main.go index 830165b881b5..8499b59ec357 100644 --- a/internal/generated/snippets/chat/apiv1/Client/ListSpaceEvents/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/ListSpaceEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/ListSpaces/main.go b/internal/generated/snippets/chat/apiv1/Client/ListSpaces/main.go index f96d36b763d9..d17f2e5ee787 100644 --- a/internal/generated/snippets/chat/apiv1/Client/ListSpaces/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/ListSpaces/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/SearchSpaces/main.go b/internal/generated/snippets/chat/apiv1/Client/SearchSpaces/main.go index bce1090aa3ba..024a9bf4534e 100644 --- a/internal/generated/snippets/chat/apiv1/Client/SearchSpaces/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/SearchSpaces/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/SetUpSpace/main.go b/internal/generated/snippets/chat/apiv1/Client/SetUpSpace/main.go index d412fdcb7f9e..130ac90c00d3 100644 --- a/internal/generated/snippets/chat/apiv1/Client/SetUpSpace/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/SetUpSpace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/UpdateMembership/main.go b/internal/generated/snippets/chat/apiv1/Client/UpdateMembership/main.go index 179ee77acab0..5cb8da72d4d0 100644 --- a/internal/generated/snippets/chat/apiv1/Client/UpdateMembership/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/UpdateMembership/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/UpdateMessage/main.go b/internal/generated/snippets/chat/apiv1/Client/UpdateMessage/main.go index 8831cfe3989a..a9b8859ccde2 100644 --- a/internal/generated/snippets/chat/apiv1/Client/UpdateMessage/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/UpdateMessage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/UpdateSpace/main.go b/internal/generated/snippets/chat/apiv1/Client/UpdateSpace/main.go index 8d0c5741eeb7..b2f70857f47f 100644 --- a/internal/generated/snippets/chat/apiv1/Client/UpdateSpace/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/UpdateSpace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/UpdateSpaceReadState/main.go b/internal/generated/snippets/chat/apiv1/Client/UpdateSpaceReadState/main.go index fd4379c0d777..1d79ddbbc0c5 100644 --- a/internal/generated/snippets/chat/apiv1/Client/UpdateSpaceReadState/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/UpdateSpaceReadState/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/Client/UploadAttachment/main.go b/internal/generated/snippets/chat/apiv1/Client/UploadAttachment/main.go index 935f41ac5750..e7d4bc22e8d0 100644 --- a/internal/generated/snippets/chat/apiv1/Client/UploadAttachment/main.go +++ b/internal/generated/snippets/chat/apiv1/Client/UploadAttachment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/chat/apiv1/snippet_metadata.google.chat.v1.json b/internal/generated/snippets/chat/apiv1/snippet_metadata.google.chat.v1.json index fd3d48b2aac0..c37c4b58656a 100644 --- a/internal/generated/snippets/chat/apiv1/snippet_metadata.google.chat.v1.json +++ b/internal/generated/snippets/chat/apiv1/snippet_metadata.google.chat.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/chat/apiv1", - "version": "0.9.0", + "version": "0.9.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/ApproveBuild/main.go b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/ApproveBuild/main.go index 6659ec90384b..01bf392467bc 100644 --- a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/ApproveBuild/main.go +++ b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/ApproveBuild/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/CancelBuild/main.go b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/CancelBuild/main.go index fbe7afddff25..961ec4d747cf 100644 --- a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/CancelBuild/main.go +++ b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/CancelBuild/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/CreateBuild/main.go b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/CreateBuild/main.go index 03de16179faf..c4ad6ef9419a 100644 --- a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/CreateBuild/main.go +++ b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/CreateBuild/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/CreateBuildTrigger/main.go b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/CreateBuildTrigger/main.go index 7035ac3c0f27..05acba8c7b0a 100644 --- a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/CreateBuildTrigger/main.go +++ b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/CreateBuildTrigger/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/CreateWorkerPool/main.go b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/CreateWorkerPool/main.go index d0f10a183d34..276b696ba637 100644 --- a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/CreateWorkerPool/main.go +++ b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/CreateWorkerPool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/DeleteBuildTrigger/main.go b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/DeleteBuildTrigger/main.go index ef420dea3a83..9667d2b54b89 100644 --- a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/DeleteBuildTrigger/main.go +++ b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/DeleteBuildTrigger/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/DeleteWorkerPool/main.go b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/DeleteWorkerPool/main.go index ffe9df78d2a8..8c32c70a5402 100644 --- a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/DeleteWorkerPool/main.go +++ b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/DeleteWorkerPool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/GetBuild/main.go b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/GetBuild/main.go index 28f43c64745e..4b8cc9769cea 100644 --- a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/GetBuild/main.go +++ b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/GetBuild/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/GetBuildTrigger/main.go b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/GetBuildTrigger/main.go index 1526ec89572e..367be3cec61d 100644 --- a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/GetBuildTrigger/main.go +++ b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/GetBuildTrigger/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/GetWorkerPool/main.go b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/GetWorkerPool/main.go index 312905c6ceac..e3cdaf884f5b 100644 --- a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/GetWorkerPool/main.go +++ b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/GetWorkerPool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/ListBuildTriggers/main.go b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/ListBuildTriggers/main.go index 50955c0aa1c3..44f8a2e614cc 100644 --- a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/ListBuildTriggers/main.go +++ b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/ListBuildTriggers/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/ListBuilds/main.go b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/ListBuilds/main.go index c8a55a7e0f15..a11ebbadf1e2 100644 --- a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/ListBuilds/main.go +++ b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/ListBuilds/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/ListWorkerPools/main.go b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/ListWorkerPools/main.go index db37f64123b5..d767c11666f1 100644 --- a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/ListWorkerPools/main.go +++ b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/ListWorkerPools/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/ReceiveTriggerWebhook/main.go b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/ReceiveTriggerWebhook/main.go index ed690f913e13..dbe21a0e5602 100644 --- a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/ReceiveTriggerWebhook/main.go +++ b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/ReceiveTriggerWebhook/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/RetryBuild/main.go b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/RetryBuild/main.go index 23bef9a4ec8a..094686860d0e 100644 --- a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/RetryBuild/main.go +++ b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/RetryBuild/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/RunBuildTrigger/main.go b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/RunBuildTrigger/main.go index 01050101167f..fe9b35e7f60c 100644 --- a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/RunBuildTrigger/main.go +++ b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/RunBuildTrigger/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/UpdateBuildTrigger/main.go b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/UpdateBuildTrigger/main.go index 704b74b72cc5..317a4a811283 100644 --- a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/UpdateBuildTrigger/main.go +++ b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/UpdateBuildTrigger/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/UpdateWorkerPool/main.go b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/UpdateWorkerPool/main.go index 1a274b30bdd5..30fd7f3a68fe 100644 --- a/internal/generated/snippets/cloudbuild/apiv1/v2/Client/UpdateWorkerPool/main.go +++ b/internal/generated/snippets/cloudbuild/apiv1/v2/Client/UpdateWorkerPool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv1/v2/snippet_metadata.google.devtools.cloudbuild.v1.json b/internal/generated/snippets/cloudbuild/apiv1/v2/snippet_metadata.google.devtools.cloudbuild.v1.json index 97dd3dc527c9..6f810926a610 100644 --- a/internal/generated/snippets/cloudbuild/apiv1/v2/snippet_metadata.google.devtools.cloudbuild.v1.json +++ b/internal/generated/snippets/cloudbuild/apiv1/v2/snippet_metadata.google.devtools.cloudbuild.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/cloudbuild/apiv1/v2", - "version": "1.19.1", + "version": "1.19.2", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/BatchCreateRepositories/main.go b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/BatchCreateRepositories/main.go index 2b2a55453bed..79ec905b0779 100644 --- a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/BatchCreateRepositories/main.go +++ b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/BatchCreateRepositories/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/CancelOperation/main.go b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/CancelOperation/main.go index 8af79c089dd0..0192735ac37b 100644 --- a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/CancelOperation/main.go +++ b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/CreateConnection/main.go b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/CreateConnection/main.go index c34a6299a335..6d469ab9bdf6 100644 --- a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/CreateConnection/main.go +++ b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/CreateConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/CreateRepository/main.go b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/CreateRepository/main.go index 266211a579c0..7871a7cb2c9f 100644 --- a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/CreateRepository/main.go +++ b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/CreateRepository/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/DeleteConnection/main.go b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/DeleteConnection/main.go index 6134e907996d..75c989e296df 100644 --- a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/DeleteConnection/main.go +++ b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/DeleteConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/DeleteRepository/main.go b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/DeleteRepository/main.go index b629fd462f77..ea83a5338ccb 100644 --- a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/DeleteRepository/main.go +++ b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/DeleteRepository/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/FetchGitRefs/main.go b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/FetchGitRefs/main.go index e1f8d3e9c91c..4244fe4c58af 100644 --- a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/FetchGitRefs/main.go +++ b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/FetchGitRefs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/FetchLinkableRepositories/main.go b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/FetchLinkableRepositories/main.go index c3b4a38ac37e..26b2617bdf23 100644 --- a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/FetchLinkableRepositories/main.go +++ b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/FetchLinkableRepositories/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/FetchReadToken/main.go b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/FetchReadToken/main.go index 54531b40ffa2..ca3a801649bc 100644 --- a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/FetchReadToken/main.go +++ b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/FetchReadToken/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/FetchReadWriteToken/main.go b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/FetchReadWriteToken/main.go index 4d1ec7e0e454..6c0aabcf7c62 100644 --- a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/FetchReadWriteToken/main.go +++ b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/FetchReadWriteToken/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/GetConnection/main.go b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/GetConnection/main.go index 53d44c646d04..a985124a175e 100644 --- a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/GetConnection/main.go +++ b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/GetConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/GetIamPolicy/main.go b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/GetIamPolicy/main.go index 90f982102b21..d4b5ffe62390 100644 --- a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/GetOperation/main.go b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/GetOperation/main.go index 55b8a4be16a2..a3b9e683692d 100644 --- a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/GetOperation/main.go +++ b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/GetRepository/main.go b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/GetRepository/main.go index a9d21e2b3c33..9a59efd5cd85 100644 --- a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/GetRepository/main.go +++ b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/GetRepository/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/ListConnections/main.go b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/ListConnections/main.go index 2994e0f9bb31..318377fe8bbc 100644 --- a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/ListConnections/main.go +++ b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/ListConnections/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/ListRepositories/main.go b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/ListRepositories/main.go index 42fbbfe1d153..b22519165b08 100644 --- a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/ListRepositories/main.go +++ b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/ListRepositories/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/SetIamPolicy/main.go b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/SetIamPolicy/main.go index e40f2a4ecb40..109229aaf5d8 100644 --- a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/TestIamPermissions/main.go b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/TestIamPermissions/main.go index 0005f900cd20..bcd5ad662383 100644 --- a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/UpdateConnection/main.go b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/UpdateConnection/main.go index 057cf20d7a24..25ea165e6fbe 100644 --- a/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/UpdateConnection/main.go +++ b/internal/generated/snippets/cloudbuild/apiv2/RepositoryManagerClient/UpdateConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudbuild/apiv2/snippet_metadata.google.devtools.cloudbuild.v2.json b/internal/generated/snippets/cloudbuild/apiv2/snippet_metadata.google.devtools.cloudbuild.v2.json index 31ebeb0f4dc3..9de52154693f 100644 --- a/internal/generated/snippets/cloudbuild/apiv2/snippet_metadata.google.devtools.cloudbuild.v2.json +++ b/internal/generated/snippets/cloudbuild/apiv2/snippet_metadata.google.devtools.cloudbuild.v2.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/cloudbuild/apiv2", - "version": "1.19.1", + "version": "1.19.2", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/GetCustomer/main.go b/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/GetCustomer/main.go index 9b9250d01213..a272768ba9ce 100644 --- a/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/GetCustomer/main.go +++ b/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/GetCustomer/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/GetEkmConnections/main.go b/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/GetEkmConnections/main.go index 8974acb0fee2..f5e441c690a2 100644 --- a/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/GetEkmConnections/main.go +++ b/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/GetEkmConnections/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/GetPartner/main.go b/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/GetPartner/main.go index 406539956869..6b722d220510 100644 --- a/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/GetPartner/main.go +++ b/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/GetPartner/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/GetPartnerPermissions/main.go b/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/GetPartnerPermissions/main.go index 5d274e462d41..14ad85d7e961 100644 --- a/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/GetPartnerPermissions/main.go +++ b/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/GetPartnerPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/GetWorkload/main.go b/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/GetWorkload/main.go index 6a06faceec90..6d00cc5db78d 100644 --- a/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/GetWorkload/main.go +++ b/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/GetWorkload/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/ListAccessApprovalRequests/main.go b/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/ListAccessApprovalRequests/main.go index da0d478d7b1f..5d245c75b792 100644 --- a/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/ListAccessApprovalRequests/main.go +++ b/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/ListAccessApprovalRequests/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/ListCustomers/main.go b/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/ListCustomers/main.go index 26567b8117bf..04f4f0a03b37 100644 --- a/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/ListCustomers/main.go +++ b/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/ListCustomers/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/ListWorkloads/main.go b/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/ListWorkloads/main.go index 352729f50ec9..7e9833d8bebd 100644 --- a/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/ListWorkloads/main.go +++ b/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerCoreClient/ListWorkloads/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerMonitoringClient/GetViolation/main.go b/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerMonitoringClient/GetViolation/main.go index e47f8ac90c73..c2b465bfa679 100644 --- a/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerMonitoringClient/GetViolation/main.go +++ b/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerMonitoringClient/GetViolation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerMonitoringClient/ListViolations/main.go b/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerMonitoringClient/ListViolations/main.go index cbbf9c6c4c86..228860367572 100644 --- a/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerMonitoringClient/ListViolations/main.go +++ b/internal/generated/snippets/cloudcontrolspartner/apiv1/CloudControlsPartnerMonitoringClient/ListViolations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudcontrolspartner/apiv1/snippet_metadata.google.cloud.cloudcontrolspartner.v1.json b/internal/generated/snippets/cloudcontrolspartner/apiv1/snippet_metadata.google.cloud.cloudcontrolspartner.v1.json index aeb1e73782b1..cba2d4b59f71 100644 --- a/internal/generated/snippets/cloudcontrolspartner/apiv1/snippet_metadata.google.cloud.cloudcontrolspartner.v1.json +++ b/internal/generated/snippets/cloudcontrolspartner/apiv1/snippet_metadata.google.cloud.cloudcontrolspartner.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/cloudcontrolspartner/apiv1", - "version": "1.2.1", + "version": "1.2.2", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/GetCustomer/main.go b/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/GetCustomer/main.go index a5c75d095b78..7ccef6ba2121 100644 --- a/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/GetCustomer/main.go +++ b/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/GetCustomer/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/GetEkmConnections/main.go b/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/GetEkmConnections/main.go index c7234e33d4d9..65daf1b35cc0 100644 --- a/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/GetEkmConnections/main.go +++ b/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/GetEkmConnections/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/GetPartner/main.go b/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/GetPartner/main.go index f01d0f738f90..41968bb08529 100644 --- a/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/GetPartner/main.go +++ b/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/GetPartner/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/GetPartnerPermissions/main.go b/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/GetPartnerPermissions/main.go index e05c3e6e6b3d..3f65d49e1152 100644 --- a/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/GetPartnerPermissions/main.go +++ b/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/GetPartnerPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/GetWorkload/main.go b/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/GetWorkload/main.go index 6951f97fb21b..c2459c27fb5d 100644 --- a/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/GetWorkload/main.go +++ b/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/GetWorkload/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/ListAccessApprovalRequests/main.go b/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/ListAccessApprovalRequests/main.go index a571d6501a51..683d3d2112f2 100644 --- a/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/ListAccessApprovalRequests/main.go +++ b/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/ListAccessApprovalRequests/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/ListCustomers/main.go b/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/ListCustomers/main.go index 8ced073e1e15..65fcfa861674 100644 --- a/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/ListCustomers/main.go +++ b/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/ListCustomers/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/ListWorkloads/main.go b/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/ListWorkloads/main.go index 49ed3ccb8d28..e587b950b753 100644 --- a/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/ListWorkloads/main.go +++ b/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerCoreClient/ListWorkloads/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerMonitoringClient/GetViolation/main.go b/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerMonitoringClient/GetViolation/main.go index 0ffda375495c..ae0688e8ad94 100644 --- a/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerMonitoringClient/GetViolation/main.go +++ b/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerMonitoringClient/GetViolation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerMonitoringClient/ListViolations/main.go b/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerMonitoringClient/ListViolations/main.go index ee31a12dddd7..9b6cc0e46240 100644 --- a/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerMonitoringClient/ListViolations/main.go +++ b/internal/generated/snippets/cloudcontrolspartner/apiv1beta/CloudControlsPartnerMonitoringClient/ListViolations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudcontrolspartner/apiv1beta/snippet_metadata.google.cloud.cloudcontrolspartner.v1beta.json b/internal/generated/snippets/cloudcontrolspartner/apiv1beta/snippet_metadata.google.cloud.cloudcontrolspartner.v1beta.json index e24c30559c79..ba04affe51b1 100644 --- a/internal/generated/snippets/cloudcontrolspartner/apiv1beta/snippet_metadata.google.cloud.cloudcontrolspartner.v1beta.json +++ b/internal/generated/snippets/cloudcontrolspartner/apiv1beta/snippet_metadata.google.cloud.cloudcontrolspartner.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/cloudcontrolspartner/apiv1beta", - "version": "1.2.1", + "version": "1.2.2", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ApplyConversionWorkspace/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ApplyConversionWorkspace/main.go index 3640958c2fc4..a9cd7ba23d10 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ApplyConversionWorkspace/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ApplyConversionWorkspace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/CancelOperation/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/CancelOperation/main.go index 86d438843345..50aed08d5002 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/CancelOperation/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/CommitConversionWorkspace/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/CommitConversionWorkspace/main.go index eb269113acec..3f4687779176 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/CommitConversionWorkspace/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/CommitConversionWorkspace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ConvertConversionWorkspace/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ConvertConversionWorkspace/main.go index 1c74b4033660..751fc1fe35ee 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ConvertConversionWorkspace/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ConvertConversionWorkspace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/CreateConnectionProfile/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/CreateConnectionProfile/main.go index 7ac67ec1e762..ec8995f367ae 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/CreateConnectionProfile/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/CreateConnectionProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/CreateConversionWorkspace/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/CreateConversionWorkspace/main.go index bada023094c3..7a73fbfa618b 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/CreateConversionWorkspace/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/CreateConversionWorkspace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/CreateMappingRule/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/CreateMappingRule/main.go index 3c952b357355..3118b726b762 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/CreateMappingRule/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/CreateMappingRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/CreateMigrationJob/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/CreateMigrationJob/main.go index ac332ced50a7..55614f8bd8b8 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/CreateMigrationJob/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/CreateMigrationJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/CreatePrivateConnection/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/CreatePrivateConnection/main.go index c544f2d00567..c830111fc8d6 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/CreatePrivateConnection/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/CreatePrivateConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DeleteConnectionProfile/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DeleteConnectionProfile/main.go index 8b2fa8b22016..22dd2a518481 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DeleteConnectionProfile/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DeleteConnectionProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DeleteConversionWorkspace/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DeleteConversionWorkspace/main.go index 49c8467aaba8..a150c7ce775f 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DeleteConversionWorkspace/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DeleteConversionWorkspace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DeleteMappingRule/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DeleteMappingRule/main.go index 96655457b9e8..210e43b440a2 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DeleteMappingRule/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DeleteMappingRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DeleteMigrationJob/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DeleteMigrationJob/main.go index 2d7873952c43..923e7fcacd5b 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DeleteMigrationJob/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DeleteMigrationJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DeleteOperation/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DeleteOperation/main.go index 0f55ad9fa016..0d20fe843d7f 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DeleteOperation/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DeletePrivateConnection/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DeletePrivateConnection/main.go index b9f7682b0431..cbae12d817e6 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DeletePrivateConnection/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DeletePrivateConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DescribeConversionWorkspaceRevisions/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DescribeConversionWorkspaceRevisions/main.go index cf5bc58f363c..99dd523be038 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DescribeConversionWorkspaceRevisions/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DescribeConversionWorkspaceRevisions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DescribeDatabaseEntities/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DescribeDatabaseEntities/main.go index f7126a6e477d..dbcaf7be9a62 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DescribeDatabaseEntities/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/DescribeDatabaseEntities/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/FetchStaticIps/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/FetchStaticIps/main.go index f9bfe8a7f23c..b2b1cbcfdd91 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/FetchStaticIps/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/FetchStaticIps/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GenerateSshScript/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GenerateSshScript/main.go index 26590d4c0807..e1f09af8a56c 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GenerateSshScript/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GenerateSshScript/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GenerateTcpProxyScript/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GenerateTcpProxyScript/main.go index b4f7b785ae52..56bc9f248849 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GenerateTcpProxyScript/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GenerateTcpProxyScript/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetConnectionProfile/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetConnectionProfile/main.go index 38074b31e354..1d940d4bfb23 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetConnectionProfile/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetConnectionProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetConversionWorkspace/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetConversionWorkspace/main.go index 66119e0d17e5..903e003b5517 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetConversionWorkspace/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetConversionWorkspace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetIamPolicy/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetIamPolicy/main.go index e5e4060ec528..a656a621416d 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetLocation/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetLocation/main.go index 6e66073ffb00..6e0dec06152e 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetLocation/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetMappingRule/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetMappingRule/main.go index 7844429ccf70..7eed8f5ed70a 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetMappingRule/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetMappingRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetMigrationJob/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetMigrationJob/main.go index bd73ac12b747..34b84d8ba63d 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetMigrationJob/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetMigrationJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetOperation/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetOperation/main.go index e413dba75cba..2226941cbf95 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetOperation/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetPrivateConnection/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetPrivateConnection/main.go index de071b90e480..e371aa625e27 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetPrivateConnection/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/GetPrivateConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ImportMappingRules/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ImportMappingRules/main.go index c4fff340623e..3ef3d2da4edd 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ImportMappingRules/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ImportMappingRules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ListConnectionProfiles/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ListConnectionProfiles/main.go index cef4b24a52a6..affb661561ba 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ListConnectionProfiles/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ListConnectionProfiles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ListConversionWorkspaces/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ListConversionWorkspaces/main.go index 97384183e5d6..ee60331a1e83 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ListConversionWorkspaces/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ListConversionWorkspaces/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ListLocations/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ListLocations/main.go index b317131c350a..3dc8acaacf20 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ListLocations/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ListMappingRules/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ListMappingRules/main.go index d900588e13ac..d5109a1d8224 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ListMappingRules/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ListMappingRules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ListMigrationJobs/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ListMigrationJobs/main.go index 442029a2710b..95c9c29048b2 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ListMigrationJobs/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ListMigrationJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ListOperations/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ListOperations/main.go index bc3696830c96..bf1d8d3d26c2 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ListOperations/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ListPrivateConnections/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ListPrivateConnections/main.go index 7d9a678ef20e..2165e4596dbd 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ListPrivateConnections/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ListPrivateConnections/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/PromoteMigrationJob/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/PromoteMigrationJob/main.go index 159a78c95d7e..bea1f0dccfa2 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/PromoteMigrationJob/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/PromoteMigrationJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/RestartMigrationJob/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/RestartMigrationJob/main.go index da29a35d7755..95af434674b2 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/RestartMigrationJob/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/RestartMigrationJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ResumeMigrationJob/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ResumeMigrationJob/main.go index 18f40ab3872a..88a228d5df8c 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ResumeMigrationJob/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/ResumeMigrationJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/RollbackConversionWorkspace/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/RollbackConversionWorkspace/main.go index 6b77314fc5dc..23e478d6556f 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/RollbackConversionWorkspace/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/RollbackConversionWorkspace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/SearchBackgroundJobs/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/SearchBackgroundJobs/main.go index 4b6a7ec508c7..c4c7bcad52cc 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/SearchBackgroundJobs/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/SearchBackgroundJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/SeedConversionWorkspace/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/SeedConversionWorkspace/main.go index e771b08de24f..691a0ad9a5f6 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/SeedConversionWorkspace/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/SeedConversionWorkspace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/SetIamPolicy/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/SetIamPolicy/main.go index 5fc663451a57..77694d1c58e4 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/StartMigrationJob/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/StartMigrationJob/main.go index acb2434302ce..84c51f4d4fab 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/StartMigrationJob/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/StartMigrationJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/StopMigrationJob/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/StopMigrationJob/main.go index 6bef72b5d15c..f0fb863ae229 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/StopMigrationJob/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/StopMigrationJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/TestIamPermissions/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/TestIamPermissions/main.go index 9ce730effaed..65b10398c46a 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/UpdateConnectionProfile/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/UpdateConnectionProfile/main.go index 37bd88b4355f..dc3fafd56a39 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/UpdateConnectionProfile/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/UpdateConnectionProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/UpdateConversionWorkspace/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/UpdateConversionWorkspace/main.go index f72d0dd69405..596288b02189 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/UpdateConversionWorkspace/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/UpdateConversionWorkspace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/UpdateMigrationJob/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/UpdateMigrationJob/main.go index 1f927fcf73d5..4cc79becb084 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/UpdateMigrationJob/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/UpdateMigrationJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/VerifyMigrationJob/main.go b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/VerifyMigrationJob/main.go index 4f7fed921a0e..d4c4fe5c3104 100644 --- a/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/VerifyMigrationJob/main.go +++ b/internal/generated/snippets/clouddms/apiv1/DataMigrationClient/VerifyMigrationJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudprofiler/apiv2/ExportClient/ListProfiles/main.go b/internal/generated/snippets/cloudprofiler/apiv2/ExportClient/ListProfiles/main.go index 6043acf6f491..476f9588209a 100644 --- a/internal/generated/snippets/cloudprofiler/apiv2/ExportClient/ListProfiles/main.go +++ b/internal/generated/snippets/cloudprofiler/apiv2/ExportClient/ListProfiles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudprofiler/apiv2/ProfilerClient/CreateOfflineProfile/main.go b/internal/generated/snippets/cloudprofiler/apiv2/ProfilerClient/CreateOfflineProfile/main.go index 83293f253af3..ad3ec8e33fda 100644 --- a/internal/generated/snippets/cloudprofiler/apiv2/ProfilerClient/CreateOfflineProfile/main.go +++ b/internal/generated/snippets/cloudprofiler/apiv2/ProfilerClient/CreateOfflineProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudprofiler/apiv2/ProfilerClient/CreateProfile/main.go b/internal/generated/snippets/cloudprofiler/apiv2/ProfilerClient/CreateProfile/main.go index e178b89a9c88..e226ac01c088 100644 --- a/internal/generated/snippets/cloudprofiler/apiv2/ProfilerClient/CreateProfile/main.go +++ b/internal/generated/snippets/cloudprofiler/apiv2/ProfilerClient/CreateProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudprofiler/apiv2/ProfilerClient/UpdateProfile/main.go b/internal/generated/snippets/cloudprofiler/apiv2/ProfilerClient/UpdateProfile/main.go index c70f4f9b4b95..c6ff46bc5c56 100644 --- a/internal/generated/snippets/cloudprofiler/apiv2/ProfilerClient/UpdateProfile/main.go +++ b/internal/generated/snippets/cloudprofiler/apiv2/ProfilerClient/UpdateProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudprofiler/apiv2/snippet_metadata.google.devtools.cloudprofiler.v2.json b/internal/generated/snippets/cloudprofiler/apiv2/snippet_metadata.google.devtools.cloudprofiler.v2.json index 4847a218d35e..6532f9d8c80f 100644 --- a/internal/generated/snippets/cloudprofiler/apiv2/snippet_metadata.google.devtools.cloudprofiler.v2.json +++ b/internal/generated/snippets/cloudprofiler/apiv2/snippet_metadata.google.devtools.cloudprofiler.v2.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/cloudprofiler/apiv2", - "version": "0.4.2", + "version": "0.4.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/cloudquotas/apiv1/Client/CreateQuotaPreference/main.go b/internal/generated/snippets/cloudquotas/apiv1/Client/CreateQuotaPreference/main.go index 1880c2892fb2..5c1e9020da9a 100644 --- a/internal/generated/snippets/cloudquotas/apiv1/Client/CreateQuotaPreference/main.go +++ b/internal/generated/snippets/cloudquotas/apiv1/Client/CreateQuotaPreference/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudquotas/apiv1/Client/GetQuotaInfo/main.go b/internal/generated/snippets/cloudquotas/apiv1/Client/GetQuotaInfo/main.go index 7a6b53f42c27..89ff8c565b88 100644 --- a/internal/generated/snippets/cloudquotas/apiv1/Client/GetQuotaInfo/main.go +++ b/internal/generated/snippets/cloudquotas/apiv1/Client/GetQuotaInfo/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudquotas/apiv1/Client/GetQuotaPreference/main.go b/internal/generated/snippets/cloudquotas/apiv1/Client/GetQuotaPreference/main.go index 7cef52239859..8247f6a7488b 100644 --- a/internal/generated/snippets/cloudquotas/apiv1/Client/GetQuotaPreference/main.go +++ b/internal/generated/snippets/cloudquotas/apiv1/Client/GetQuotaPreference/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudquotas/apiv1/Client/ListQuotaInfos/main.go b/internal/generated/snippets/cloudquotas/apiv1/Client/ListQuotaInfos/main.go index b4edcacf8dbb..22460e8d32c8 100644 --- a/internal/generated/snippets/cloudquotas/apiv1/Client/ListQuotaInfos/main.go +++ b/internal/generated/snippets/cloudquotas/apiv1/Client/ListQuotaInfos/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudquotas/apiv1/Client/ListQuotaPreferences/main.go b/internal/generated/snippets/cloudquotas/apiv1/Client/ListQuotaPreferences/main.go index cd4e802e8d7b..5bdb36536f7f 100644 --- a/internal/generated/snippets/cloudquotas/apiv1/Client/ListQuotaPreferences/main.go +++ b/internal/generated/snippets/cloudquotas/apiv1/Client/ListQuotaPreferences/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudquotas/apiv1/Client/UpdateQuotaPreference/main.go b/internal/generated/snippets/cloudquotas/apiv1/Client/UpdateQuotaPreference/main.go index 7c1e99ddfa72..7def6012c4e6 100644 --- a/internal/generated/snippets/cloudquotas/apiv1/Client/UpdateQuotaPreference/main.go +++ b/internal/generated/snippets/cloudquotas/apiv1/Client/UpdateQuotaPreference/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudquotas/apiv1/snippet_metadata.google.api.cloudquotas.v1.json b/internal/generated/snippets/cloudquotas/apiv1/snippet_metadata.google.api.cloudquotas.v1.json index edbfd6f9cca9..daa46ed7b3af 100644 --- a/internal/generated/snippets/cloudquotas/apiv1/snippet_metadata.google.api.cloudquotas.v1.json +++ b/internal/generated/snippets/cloudquotas/apiv1/snippet_metadata.google.api.cloudquotas.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/cloudquotas/apiv1", - "version": "1.2.0", + "version": "1.2.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/cloudtasks/apiv2/Client/CreateQueue/main.go b/internal/generated/snippets/cloudtasks/apiv2/Client/CreateQueue/main.go index 866e5f16782b..66c351a6c0a5 100644 --- a/internal/generated/snippets/cloudtasks/apiv2/Client/CreateQueue/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2/Client/CreateQueue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2/Client/CreateTask/main.go b/internal/generated/snippets/cloudtasks/apiv2/Client/CreateTask/main.go index 5a3ab6f1771a..b1a3ae103f10 100644 --- a/internal/generated/snippets/cloudtasks/apiv2/Client/CreateTask/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2/Client/CreateTask/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2/Client/DeleteQueue/main.go b/internal/generated/snippets/cloudtasks/apiv2/Client/DeleteQueue/main.go index ee3024926b1e..28819df75f9a 100644 --- a/internal/generated/snippets/cloudtasks/apiv2/Client/DeleteQueue/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2/Client/DeleteQueue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2/Client/DeleteTask/main.go b/internal/generated/snippets/cloudtasks/apiv2/Client/DeleteTask/main.go index d1c261e1bec1..8bec9033f1ab 100644 --- a/internal/generated/snippets/cloudtasks/apiv2/Client/DeleteTask/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2/Client/DeleteTask/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2/Client/GetIamPolicy/main.go b/internal/generated/snippets/cloudtasks/apiv2/Client/GetIamPolicy/main.go index 485a83a2768f..71bbf06c1cea 100644 --- a/internal/generated/snippets/cloudtasks/apiv2/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2/Client/GetLocation/main.go b/internal/generated/snippets/cloudtasks/apiv2/Client/GetLocation/main.go index 8bbec9976ee6..03ad26b88e1c 100644 --- a/internal/generated/snippets/cloudtasks/apiv2/Client/GetLocation/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2/Client/GetQueue/main.go b/internal/generated/snippets/cloudtasks/apiv2/Client/GetQueue/main.go index 351445a8e3c0..6f829ba96e69 100644 --- a/internal/generated/snippets/cloudtasks/apiv2/Client/GetQueue/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2/Client/GetQueue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2/Client/GetTask/main.go b/internal/generated/snippets/cloudtasks/apiv2/Client/GetTask/main.go index b51ac0bfdfa7..9df9f884a162 100644 --- a/internal/generated/snippets/cloudtasks/apiv2/Client/GetTask/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2/Client/GetTask/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2/Client/ListLocations/main.go b/internal/generated/snippets/cloudtasks/apiv2/Client/ListLocations/main.go index 930f59df369e..303fad58fd65 100644 --- a/internal/generated/snippets/cloudtasks/apiv2/Client/ListLocations/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2/Client/ListQueues/main.go b/internal/generated/snippets/cloudtasks/apiv2/Client/ListQueues/main.go index 54658a746f0c..48fc0f498d80 100644 --- a/internal/generated/snippets/cloudtasks/apiv2/Client/ListQueues/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2/Client/ListQueues/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2/Client/ListTasks/main.go b/internal/generated/snippets/cloudtasks/apiv2/Client/ListTasks/main.go index e8734ffd8bd9..594757627cba 100644 --- a/internal/generated/snippets/cloudtasks/apiv2/Client/ListTasks/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2/Client/ListTasks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2/Client/PauseQueue/main.go b/internal/generated/snippets/cloudtasks/apiv2/Client/PauseQueue/main.go index f9cff1bc78d7..2bf3909ef2a8 100644 --- a/internal/generated/snippets/cloudtasks/apiv2/Client/PauseQueue/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2/Client/PauseQueue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2/Client/PurgeQueue/main.go b/internal/generated/snippets/cloudtasks/apiv2/Client/PurgeQueue/main.go index cf24b1ea551b..2d119be48164 100644 --- a/internal/generated/snippets/cloudtasks/apiv2/Client/PurgeQueue/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2/Client/PurgeQueue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2/Client/ResumeQueue/main.go b/internal/generated/snippets/cloudtasks/apiv2/Client/ResumeQueue/main.go index 4e61dd549e15..060156998037 100644 --- a/internal/generated/snippets/cloudtasks/apiv2/Client/ResumeQueue/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2/Client/ResumeQueue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2/Client/RunTask/main.go b/internal/generated/snippets/cloudtasks/apiv2/Client/RunTask/main.go index 528a18ba1855..5244773ecc86 100644 --- a/internal/generated/snippets/cloudtasks/apiv2/Client/RunTask/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2/Client/RunTask/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2/Client/SetIamPolicy/main.go b/internal/generated/snippets/cloudtasks/apiv2/Client/SetIamPolicy/main.go index 9ab76bd7747f..f94070352220 100644 --- a/internal/generated/snippets/cloudtasks/apiv2/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2/Client/TestIamPermissions/main.go b/internal/generated/snippets/cloudtasks/apiv2/Client/TestIamPermissions/main.go index dfc1bc730864..6c82afb2dc33 100644 --- a/internal/generated/snippets/cloudtasks/apiv2/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2/Client/UpdateQueue/main.go b/internal/generated/snippets/cloudtasks/apiv2/Client/UpdateQueue/main.go index 79387ba32d4b..8941cb69b140 100644 --- a/internal/generated/snippets/cloudtasks/apiv2/Client/UpdateQueue/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2/Client/UpdateQueue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/AcknowledgeTask/main.go b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/AcknowledgeTask/main.go index 2563643719d2..bb1170d2b0d5 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/AcknowledgeTask/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/AcknowledgeTask/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/CancelLease/main.go b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/CancelLease/main.go index a8249cc60f28..cb5d6eb11681 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/CancelLease/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/CancelLease/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/CreateQueue/main.go b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/CreateQueue/main.go index 40806de00b2a..f6d8e54af546 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/CreateQueue/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/CreateQueue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/CreateTask/main.go b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/CreateTask/main.go index 03a10d681ac0..f0820a78f653 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/CreateTask/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/CreateTask/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/DeleteQueue/main.go b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/DeleteQueue/main.go index 6dcef33ca266..e3d4a5f15ef7 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/DeleteQueue/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/DeleteQueue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/DeleteTask/main.go b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/DeleteTask/main.go index a60ad72027ad..bd95770da60c 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/DeleteTask/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/DeleteTask/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/GetIamPolicy/main.go b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/GetIamPolicy/main.go index e912fcf2d592..06d9cb344ca5 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/GetLocation/main.go b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/GetLocation/main.go index b5f42e7aa176..7013121726ad 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/GetLocation/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/GetQueue/main.go b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/GetQueue/main.go index d182c92b971a..c8a9dbedeb42 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/GetQueue/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/GetQueue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/GetTask/main.go b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/GetTask/main.go index ffe5ce521332..b9abc26e8f72 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/GetTask/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/GetTask/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/LeaseTasks/main.go b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/LeaseTasks/main.go index c9cb9169d7f7..17d245f62ace 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/LeaseTasks/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/LeaseTasks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/ListLocations/main.go b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/ListLocations/main.go index 557e4c6aae17..0f7a8bec4bba 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/ListLocations/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/ListQueues/main.go b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/ListQueues/main.go index 12f50580377b..1259d8852e2c 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/ListQueues/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/ListQueues/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/ListTasks/main.go b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/ListTasks/main.go index 406dd903b2b4..231ed046a9f5 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/ListTasks/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/ListTasks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/PauseQueue/main.go b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/PauseQueue/main.go index 615bf3b31926..7d5aecc1563e 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/PauseQueue/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/PauseQueue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/PurgeQueue/main.go b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/PurgeQueue/main.go index 62fc62aff8ec..a758a9ca26ff 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/PurgeQueue/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/PurgeQueue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/RenewLease/main.go b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/RenewLease/main.go index 88b398a86499..dae9f05d7945 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/RenewLease/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/RenewLease/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/ResumeQueue/main.go b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/ResumeQueue/main.go index 7d21a960efd0..e561dc3a8d53 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/ResumeQueue/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/ResumeQueue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/RunTask/main.go b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/RunTask/main.go index 64d1b8ee14e5..d5b2a47347d0 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/RunTask/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/RunTask/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/SetIamPolicy/main.go b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/SetIamPolicy/main.go index 3fec3c2d741b..f227b94aa110 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/TestIamPermissions/main.go b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/TestIamPermissions/main.go index 129e9e9f529a..15b096732241 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/UpdateQueue/main.go b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/UpdateQueue/main.go index 7074735f8b6f..640715ac95c6 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/UpdateQueue/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/UpdateQueue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/UploadQueueYaml/main.go b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/UploadQueueYaml/main.go index f8bc6cf60491..4f82e799f0ef 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta2/Client/UploadQueueYaml/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta2/Client/UploadQueueYaml/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/CreateQueue/main.go b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/CreateQueue/main.go index 7ea675058563..533bc4915f41 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/CreateQueue/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/CreateQueue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/CreateTask/main.go b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/CreateTask/main.go index c4d00a51f9ee..ac0946ba976e 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/CreateTask/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/CreateTask/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/DeleteQueue/main.go b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/DeleteQueue/main.go index b1b7dcae995c..fd9c198202c6 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/DeleteQueue/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/DeleteQueue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/DeleteTask/main.go b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/DeleteTask/main.go index d852ad2e23ae..1d91b05f732b 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/DeleteTask/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/DeleteTask/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/GetIamPolicy/main.go b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/GetIamPolicy/main.go index c9c77bbc020b..9d8027ac95c7 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/GetLocation/main.go b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/GetLocation/main.go index 217525491b78..df13881e92f9 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/GetLocation/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/GetQueue/main.go b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/GetQueue/main.go index e32d1f3017b6..894fa096553c 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/GetQueue/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/GetQueue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/GetTask/main.go b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/GetTask/main.go index d65dadf1f215..7e038c95a9b9 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/GetTask/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/GetTask/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/ListLocations/main.go b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/ListLocations/main.go index 5f175853b29e..0a51807d3172 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/ListLocations/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/ListQueues/main.go b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/ListQueues/main.go index 1e5468e45294..2c5218e16eff 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/ListQueues/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/ListQueues/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/ListTasks/main.go b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/ListTasks/main.go index 7d49c66f0f1e..f91fc5d774d8 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/ListTasks/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/ListTasks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/PauseQueue/main.go b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/PauseQueue/main.go index 073db7de21f4..ad62d1556d40 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/PauseQueue/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/PauseQueue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/PurgeQueue/main.go b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/PurgeQueue/main.go index 56b29ca2f8eb..37244068b38b 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/PurgeQueue/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/PurgeQueue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/ResumeQueue/main.go b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/ResumeQueue/main.go index e2e28d098647..68282db77139 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/ResumeQueue/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/ResumeQueue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/RunTask/main.go b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/RunTask/main.go index 8fa19dbf4cfa..191551dfcb23 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/RunTask/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/RunTask/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/SetIamPolicy/main.go b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/SetIamPolicy/main.go index f395d37988f0..e4a88833859c 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/TestIamPermissions/main.go b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/TestIamPermissions/main.go index 7c6d8f76d604..0874c4518aff 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/UpdateQueue/main.go b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/UpdateQueue/main.go index a722805e0f78..debef61b1400 100644 --- a/internal/generated/snippets/cloudtasks/apiv2beta3/Client/UpdateQueue/main.go +++ b/internal/generated/snippets/cloudtasks/apiv2beta3/Client/UpdateQueue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/commerce/consumer/procurement/apiv1/ConsumerProcurementClient/CancelOrder/main.go b/internal/generated/snippets/commerce/consumer/procurement/apiv1/ConsumerProcurementClient/CancelOrder/main.go index c4b5027b8c0d..70d0309c12bb 100644 --- a/internal/generated/snippets/commerce/consumer/procurement/apiv1/ConsumerProcurementClient/CancelOrder/main.go +++ b/internal/generated/snippets/commerce/consumer/procurement/apiv1/ConsumerProcurementClient/CancelOrder/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/commerce/consumer/procurement/apiv1/ConsumerProcurementClient/GetOperation/main.go b/internal/generated/snippets/commerce/consumer/procurement/apiv1/ConsumerProcurementClient/GetOperation/main.go index 0ff1f1085f5f..84941489a79d 100644 --- a/internal/generated/snippets/commerce/consumer/procurement/apiv1/ConsumerProcurementClient/GetOperation/main.go +++ b/internal/generated/snippets/commerce/consumer/procurement/apiv1/ConsumerProcurementClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/commerce/consumer/procurement/apiv1/ConsumerProcurementClient/GetOrder/main.go b/internal/generated/snippets/commerce/consumer/procurement/apiv1/ConsumerProcurementClient/GetOrder/main.go index 1b3e1ba4b632..cd0b34fbeffb 100644 --- a/internal/generated/snippets/commerce/consumer/procurement/apiv1/ConsumerProcurementClient/GetOrder/main.go +++ b/internal/generated/snippets/commerce/consumer/procurement/apiv1/ConsumerProcurementClient/GetOrder/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/commerce/consumer/procurement/apiv1/ConsumerProcurementClient/ListOrders/main.go b/internal/generated/snippets/commerce/consumer/procurement/apiv1/ConsumerProcurementClient/ListOrders/main.go index e3c66cf82319..28ceda15aa7a 100644 --- a/internal/generated/snippets/commerce/consumer/procurement/apiv1/ConsumerProcurementClient/ListOrders/main.go +++ b/internal/generated/snippets/commerce/consumer/procurement/apiv1/ConsumerProcurementClient/ListOrders/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/commerce/consumer/procurement/apiv1/ConsumerProcurementClient/ModifyOrder/main.go b/internal/generated/snippets/commerce/consumer/procurement/apiv1/ConsumerProcurementClient/ModifyOrder/main.go index de40c6c4bd01..8ea45942dadd 100644 --- a/internal/generated/snippets/commerce/consumer/procurement/apiv1/ConsumerProcurementClient/ModifyOrder/main.go +++ b/internal/generated/snippets/commerce/consumer/procurement/apiv1/ConsumerProcurementClient/ModifyOrder/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/commerce/consumer/procurement/apiv1/ConsumerProcurementClient/PlaceOrder/main.go b/internal/generated/snippets/commerce/consumer/procurement/apiv1/ConsumerProcurementClient/PlaceOrder/main.go index e7e6945843d5..523ba8826a50 100644 --- a/internal/generated/snippets/commerce/consumer/procurement/apiv1/ConsumerProcurementClient/PlaceOrder/main.go +++ b/internal/generated/snippets/commerce/consumer/procurement/apiv1/ConsumerProcurementClient/PlaceOrder/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/commerce/consumer/procurement/apiv1/LicenseManagementClient/Assign/main.go b/internal/generated/snippets/commerce/consumer/procurement/apiv1/LicenseManagementClient/Assign/main.go index e108fde6ad70..e1741e5df38b 100644 --- a/internal/generated/snippets/commerce/consumer/procurement/apiv1/LicenseManagementClient/Assign/main.go +++ b/internal/generated/snippets/commerce/consumer/procurement/apiv1/LicenseManagementClient/Assign/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/commerce/consumer/procurement/apiv1/LicenseManagementClient/EnumerateLicensedUsers/main.go b/internal/generated/snippets/commerce/consumer/procurement/apiv1/LicenseManagementClient/EnumerateLicensedUsers/main.go index 5248613a2799..785892e7aee8 100644 --- a/internal/generated/snippets/commerce/consumer/procurement/apiv1/LicenseManagementClient/EnumerateLicensedUsers/main.go +++ b/internal/generated/snippets/commerce/consumer/procurement/apiv1/LicenseManagementClient/EnumerateLicensedUsers/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/commerce/consumer/procurement/apiv1/LicenseManagementClient/GetLicensePool/main.go b/internal/generated/snippets/commerce/consumer/procurement/apiv1/LicenseManagementClient/GetLicensePool/main.go index 853d648c8562..31c689189a13 100644 --- a/internal/generated/snippets/commerce/consumer/procurement/apiv1/LicenseManagementClient/GetLicensePool/main.go +++ b/internal/generated/snippets/commerce/consumer/procurement/apiv1/LicenseManagementClient/GetLicensePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/commerce/consumer/procurement/apiv1/LicenseManagementClient/GetOperation/main.go b/internal/generated/snippets/commerce/consumer/procurement/apiv1/LicenseManagementClient/GetOperation/main.go index 978393d732d2..1ee777ca7105 100644 --- a/internal/generated/snippets/commerce/consumer/procurement/apiv1/LicenseManagementClient/GetOperation/main.go +++ b/internal/generated/snippets/commerce/consumer/procurement/apiv1/LicenseManagementClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/commerce/consumer/procurement/apiv1/LicenseManagementClient/Unassign/main.go b/internal/generated/snippets/commerce/consumer/procurement/apiv1/LicenseManagementClient/Unassign/main.go index 0d9b07c1e8d6..624365ab2e70 100644 --- a/internal/generated/snippets/commerce/consumer/procurement/apiv1/LicenseManagementClient/Unassign/main.go +++ b/internal/generated/snippets/commerce/consumer/procurement/apiv1/LicenseManagementClient/Unassign/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/commerce/consumer/procurement/apiv1/LicenseManagementClient/UpdateLicensePool/main.go b/internal/generated/snippets/commerce/consumer/procurement/apiv1/LicenseManagementClient/UpdateLicensePool/main.go index b717e458862f..cb6381600b85 100644 --- a/internal/generated/snippets/commerce/consumer/procurement/apiv1/LicenseManagementClient/UpdateLicensePool/main.go +++ b/internal/generated/snippets/commerce/consumer/procurement/apiv1/LicenseManagementClient/UpdateLicensePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/commerce/consumer/procurement/apiv1/snippet_metadata.google.cloud.commerce.consumer.procurement.v1.json b/internal/generated/snippets/commerce/consumer/procurement/apiv1/snippet_metadata.google.cloud.commerce.consumer.procurement.v1.json index 5dfcdac951dd..c4b1828b2e07 100644 --- a/internal/generated/snippets/commerce/consumer/procurement/apiv1/snippet_metadata.google.cloud.commerce.consumer.procurement.v1.json +++ b/internal/generated/snippets/commerce/consumer/procurement/apiv1/snippet_metadata.google.cloud.commerce.consumer.procurement.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/commerce/consumer/procurement/apiv1", - "version": "1.2.1", + "version": "1.2.2", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/compute/apiv1/AcceleratorTypesClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/AcceleratorTypesClient/AggregatedList/main.go index 7b1215c13e83..81c0969edd61 100644 --- a/internal/generated/snippets/compute/apiv1/AcceleratorTypesClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/AcceleratorTypesClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/AcceleratorTypesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/AcceleratorTypesClient/Get/main.go index 7b271430d9be..dff629c5fbd6 100644 --- a/internal/generated/snippets/compute/apiv1/AcceleratorTypesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/AcceleratorTypesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/AcceleratorTypesClient/List/main.go b/internal/generated/snippets/compute/apiv1/AcceleratorTypesClient/List/main.go index 302e7019348f..a7c503659ea7 100644 --- a/internal/generated/snippets/compute/apiv1/AcceleratorTypesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/AcceleratorTypesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/AddressesClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/AddressesClient/AggregatedList/main.go index cd71b37d32e6..0f06bf775c87 100644 --- a/internal/generated/snippets/compute/apiv1/AddressesClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/AddressesClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/AddressesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/AddressesClient/Delete/main.go index 89a4f2fae0b4..da030ef87918 100644 --- a/internal/generated/snippets/compute/apiv1/AddressesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/AddressesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/AddressesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/AddressesClient/Get/main.go index c1b73ea95891..6cfc49af2ce9 100644 --- a/internal/generated/snippets/compute/apiv1/AddressesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/AddressesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/AddressesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/AddressesClient/Insert/main.go index 1c33cd0a30b3..0d7aaaf86974 100644 --- a/internal/generated/snippets/compute/apiv1/AddressesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/AddressesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/AddressesClient/List/main.go b/internal/generated/snippets/compute/apiv1/AddressesClient/List/main.go index 830e99b3b676..77ba00debc4a 100644 --- a/internal/generated/snippets/compute/apiv1/AddressesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/AddressesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/AddressesClient/Move/main.go b/internal/generated/snippets/compute/apiv1/AddressesClient/Move/main.go index ac2aa4196155..698942a4d533 100644 --- a/internal/generated/snippets/compute/apiv1/AddressesClient/Move/main.go +++ b/internal/generated/snippets/compute/apiv1/AddressesClient/Move/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/AddressesClient/SetLabels/main.go b/internal/generated/snippets/compute/apiv1/AddressesClient/SetLabels/main.go index 2b3f2f5a6cd8..4cfe64210061 100644 --- a/internal/generated/snippets/compute/apiv1/AddressesClient/SetLabels/main.go +++ b/internal/generated/snippets/compute/apiv1/AddressesClient/SetLabels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/AutoscalersClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/AutoscalersClient/AggregatedList/main.go index b711df2c7c76..04566f6cd9c9 100644 --- a/internal/generated/snippets/compute/apiv1/AutoscalersClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/AutoscalersClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/AutoscalersClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/AutoscalersClient/Delete/main.go index 7e0e077c5aee..71d65005e0ca 100644 --- a/internal/generated/snippets/compute/apiv1/AutoscalersClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/AutoscalersClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/AutoscalersClient/Get/main.go b/internal/generated/snippets/compute/apiv1/AutoscalersClient/Get/main.go index b5c902252932..b41a443c513a 100644 --- a/internal/generated/snippets/compute/apiv1/AutoscalersClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/AutoscalersClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/AutoscalersClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/AutoscalersClient/Insert/main.go index d7961d90d8c5..58779f0e41e4 100644 --- a/internal/generated/snippets/compute/apiv1/AutoscalersClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/AutoscalersClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/AutoscalersClient/List/main.go b/internal/generated/snippets/compute/apiv1/AutoscalersClient/List/main.go index 1652f7e43331..f053107d9031 100644 --- a/internal/generated/snippets/compute/apiv1/AutoscalersClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/AutoscalersClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/AutoscalersClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/AutoscalersClient/Patch/main.go index 0e7712a7fbab..b3a8c7751b6c 100644 --- a/internal/generated/snippets/compute/apiv1/AutoscalersClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/AutoscalersClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/AutoscalersClient/Update/main.go b/internal/generated/snippets/compute/apiv1/AutoscalersClient/Update/main.go index 59d38eb7da3a..0c25467c9cb9 100644 --- a/internal/generated/snippets/compute/apiv1/AutoscalersClient/Update/main.go +++ b/internal/generated/snippets/compute/apiv1/AutoscalersClient/Update/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/BackendBucketsClient/AddSignedUrlKey/main.go b/internal/generated/snippets/compute/apiv1/BackendBucketsClient/AddSignedUrlKey/main.go index 8b6c910e04ec..c6423a4b8399 100644 --- a/internal/generated/snippets/compute/apiv1/BackendBucketsClient/AddSignedUrlKey/main.go +++ b/internal/generated/snippets/compute/apiv1/BackendBucketsClient/AddSignedUrlKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/BackendBucketsClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/BackendBucketsClient/Delete/main.go index 68d0cab3ce00..4dd1d2aadc1d 100644 --- a/internal/generated/snippets/compute/apiv1/BackendBucketsClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/BackendBucketsClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/BackendBucketsClient/DeleteSignedUrlKey/main.go b/internal/generated/snippets/compute/apiv1/BackendBucketsClient/DeleteSignedUrlKey/main.go index 6db78fb992f7..47bb31bd5c8f 100644 --- a/internal/generated/snippets/compute/apiv1/BackendBucketsClient/DeleteSignedUrlKey/main.go +++ b/internal/generated/snippets/compute/apiv1/BackendBucketsClient/DeleteSignedUrlKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/BackendBucketsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/BackendBucketsClient/Get/main.go index 6b227f017e46..4b40ad052967 100644 --- a/internal/generated/snippets/compute/apiv1/BackendBucketsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/BackendBucketsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/BackendBucketsClient/GetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/BackendBucketsClient/GetIamPolicy/main.go index 12708e29d144..8747152d2c9a 100644 --- a/internal/generated/snippets/compute/apiv1/BackendBucketsClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/BackendBucketsClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/BackendBucketsClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/BackendBucketsClient/Insert/main.go index 7a4bd47a2f55..fb02deb17e81 100644 --- a/internal/generated/snippets/compute/apiv1/BackendBucketsClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/BackendBucketsClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/BackendBucketsClient/List/main.go b/internal/generated/snippets/compute/apiv1/BackendBucketsClient/List/main.go index e8cc96997ee3..6cdc27e7b81e 100644 --- a/internal/generated/snippets/compute/apiv1/BackendBucketsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/BackendBucketsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/BackendBucketsClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/BackendBucketsClient/Patch/main.go index 61d9a4b6475a..162b12741711 100644 --- a/internal/generated/snippets/compute/apiv1/BackendBucketsClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/BackendBucketsClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/BackendBucketsClient/SetEdgeSecurityPolicy/main.go b/internal/generated/snippets/compute/apiv1/BackendBucketsClient/SetEdgeSecurityPolicy/main.go index ff04b1df1cc7..41366ba23f29 100644 --- a/internal/generated/snippets/compute/apiv1/BackendBucketsClient/SetEdgeSecurityPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/BackendBucketsClient/SetEdgeSecurityPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/BackendBucketsClient/SetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/BackendBucketsClient/SetIamPolicy/main.go index f945e7bf090c..a9edbe7abb81 100644 --- a/internal/generated/snippets/compute/apiv1/BackendBucketsClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/BackendBucketsClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/BackendBucketsClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/BackendBucketsClient/TestIamPermissions/main.go index 982ae3932289..ea6ade3400bf 100644 --- a/internal/generated/snippets/compute/apiv1/BackendBucketsClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/BackendBucketsClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/BackendBucketsClient/Update/main.go b/internal/generated/snippets/compute/apiv1/BackendBucketsClient/Update/main.go index 631c23589881..b92aa9f30d50 100644 --- a/internal/generated/snippets/compute/apiv1/BackendBucketsClient/Update/main.go +++ b/internal/generated/snippets/compute/apiv1/BackendBucketsClient/Update/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/BackendServicesClient/AddSignedUrlKey/main.go b/internal/generated/snippets/compute/apiv1/BackendServicesClient/AddSignedUrlKey/main.go index b54f7fc7a48b..9d67256cfe91 100644 --- a/internal/generated/snippets/compute/apiv1/BackendServicesClient/AddSignedUrlKey/main.go +++ b/internal/generated/snippets/compute/apiv1/BackendServicesClient/AddSignedUrlKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/BackendServicesClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/BackendServicesClient/AggregatedList/main.go index ab0f3cc59d6f..17e5b2c14b8e 100644 --- a/internal/generated/snippets/compute/apiv1/BackendServicesClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/BackendServicesClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/BackendServicesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/BackendServicesClient/Delete/main.go index 79b0210da453..0a51884b5fe9 100644 --- a/internal/generated/snippets/compute/apiv1/BackendServicesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/BackendServicesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/BackendServicesClient/DeleteSignedUrlKey/main.go b/internal/generated/snippets/compute/apiv1/BackendServicesClient/DeleteSignedUrlKey/main.go index b64fbcd19b39..d25d8e47e0df 100644 --- a/internal/generated/snippets/compute/apiv1/BackendServicesClient/DeleteSignedUrlKey/main.go +++ b/internal/generated/snippets/compute/apiv1/BackendServicesClient/DeleteSignedUrlKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/BackendServicesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/BackendServicesClient/Get/main.go index ecfe48dac642..2bb0eccfca66 100644 --- a/internal/generated/snippets/compute/apiv1/BackendServicesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/BackendServicesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/BackendServicesClient/GetHealth/main.go b/internal/generated/snippets/compute/apiv1/BackendServicesClient/GetHealth/main.go index de631e429001..bd53ef2b024e 100644 --- a/internal/generated/snippets/compute/apiv1/BackendServicesClient/GetHealth/main.go +++ b/internal/generated/snippets/compute/apiv1/BackendServicesClient/GetHealth/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/BackendServicesClient/GetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/BackendServicesClient/GetIamPolicy/main.go index cda29b765b83..6a233654b28d 100644 --- a/internal/generated/snippets/compute/apiv1/BackendServicesClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/BackendServicesClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/BackendServicesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/BackendServicesClient/Insert/main.go index 4a1e6d3c08a5..8145f618c479 100644 --- a/internal/generated/snippets/compute/apiv1/BackendServicesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/BackendServicesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/BackendServicesClient/List/main.go b/internal/generated/snippets/compute/apiv1/BackendServicesClient/List/main.go index e7910ad9b320..e234b9c76935 100644 --- a/internal/generated/snippets/compute/apiv1/BackendServicesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/BackendServicesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/BackendServicesClient/ListUsable/main.go b/internal/generated/snippets/compute/apiv1/BackendServicesClient/ListUsable/main.go index 8ac4d73aa13e..9d70130fcf8f 100644 --- a/internal/generated/snippets/compute/apiv1/BackendServicesClient/ListUsable/main.go +++ b/internal/generated/snippets/compute/apiv1/BackendServicesClient/ListUsable/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/BackendServicesClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/BackendServicesClient/Patch/main.go index 5ad36d4dfe64..0738ab40d883 100644 --- a/internal/generated/snippets/compute/apiv1/BackendServicesClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/BackendServicesClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/BackendServicesClient/SetEdgeSecurityPolicy/main.go b/internal/generated/snippets/compute/apiv1/BackendServicesClient/SetEdgeSecurityPolicy/main.go index c83a0fd1d8c6..a399db3b50d5 100644 --- a/internal/generated/snippets/compute/apiv1/BackendServicesClient/SetEdgeSecurityPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/BackendServicesClient/SetEdgeSecurityPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/BackendServicesClient/SetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/BackendServicesClient/SetIamPolicy/main.go index 24c212712133..93aba25807a3 100644 --- a/internal/generated/snippets/compute/apiv1/BackendServicesClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/BackendServicesClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/BackendServicesClient/SetSecurityPolicy/main.go b/internal/generated/snippets/compute/apiv1/BackendServicesClient/SetSecurityPolicy/main.go index f2f6fce8bd00..32b8a69edd8b 100644 --- a/internal/generated/snippets/compute/apiv1/BackendServicesClient/SetSecurityPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/BackendServicesClient/SetSecurityPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/BackendServicesClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/BackendServicesClient/TestIamPermissions/main.go index 2f9200b8f843..077e344ea521 100644 --- a/internal/generated/snippets/compute/apiv1/BackendServicesClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/BackendServicesClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/BackendServicesClient/Update/main.go b/internal/generated/snippets/compute/apiv1/BackendServicesClient/Update/main.go index 4e1373bcb28a..39b1b63340f7 100644 --- a/internal/generated/snippets/compute/apiv1/BackendServicesClient/Update/main.go +++ b/internal/generated/snippets/compute/apiv1/BackendServicesClient/Update/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/DiskTypesClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/DiskTypesClient/AggregatedList/main.go index 3565102e3822..a24ae884668f 100644 --- a/internal/generated/snippets/compute/apiv1/DiskTypesClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/DiskTypesClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/DiskTypesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/DiskTypesClient/Get/main.go index 11666e3b9d2c..ec3dde0aa3a8 100644 --- a/internal/generated/snippets/compute/apiv1/DiskTypesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/DiskTypesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/DiskTypesClient/List/main.go b/internal/generated/snippets/compute/apiv1/DiskTypesClient/List/main.go index dbc71d4f4999..605007eb2643 100644 --- a/internal/generated/snippets/compute/apiv1/DiskTypesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/DiskTypesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/DisksClient/AddResourcePolicies/main.go b/internal/generated/snippets/compute/apiv1/DisksClient/AddResourcePolicies/main.go index 7ef1459b36c2..5e18b0de77cb 100644 --- a/internal/generated/snippets/compute/apiv1/DisksClient/AddResourcePolicies/main.go +++ b/internal/generated/snippets/compute/apiv1/DisksClient/AddResourcePolicies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/DisksClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/DisksClient/AggregatedList/main.go index 45c18535694c..dc097d5d1d19 100644 --- a/internal/generated/snippets/compute/apiv1/DisksClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/DisksClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/DisksClient/BulkInsert/main.go b/internal/generated/snippets/compute/apiv1/DisksClient/BulkInsert/main.go index 8cd6d0018fb7..a9d99b2a325a 100644 --- a/internal/generated/snippets/compute/apiv1/DisksClient/BulkInsert/main.go +++ b/internal/generated/snippets/compute/apiv1/DisksClient/BulkInsert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/DisksClient/CreateSnapshot/main.go b/internal/generated/snippets/compute/apiv1/DisksClient/CreateSnapshot/main.go index be0445d057fb..6b8889cbb99e 100644 --- a/internal/generated/snippets/compute/apiv1/DisksClient/CreateSnapshot/main.go +++ b/internal/generated/snippets/compute/apiv1/DisksClient/CreateSnapshot/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/DisksClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/DisksClient/Delete/main.go index afa12d586ccc..f2cc13256cb4 100644 --- a/internal/generated/snippets/compute/apiv1/DisksClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/DisksClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/DisksClient/Get/main.go b/internal/generated/snippets/compute/apiv1/DisksClient/Get/main.go index c873c3a51740..2d04858392e7 100644 --- a/internal/generated/snippets/compute/apiv1/DisksClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/DisksClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/DisksClient/GetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/DisksClient/GetIamPolicy/main.go index ef650b506766..35bdcf37b386 100644 --- a/internal/generated/snippets/compute/apiv1/DisksClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/DisksClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/DisksClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/DisksClient/Insert/main.go index 51815a6cad80..5df58e977859 100644 --- a/internal/generated/snippets/compute/apiv1/DisksClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/DisksClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/DisksClient/List/main.go b/internal/generated/snippets/compute/apiv1/DisksClient/List/main.go index 9d5497ca04ed..bc38471437d2 100644 --- a/internal/generated/snippets/compute/apiv1/DisksClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/DisksClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/DisksClient/RemoveResourcePolicies/main.go b/internal/generated/snippets/compute/apiv1/DisksClient/RemoveResourcePolicies/main.go index 9beb79d4fa17..74470774e872 100644 --- a/internal/generated/snippets/compute/apiv1/DisksClient/RemoveResourcePolicies/main.go +++ b/internal/generated/snippets/compute/apiv1/DisksClient/RemoveResourcePolicies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/DisksClient/Resize/main.go b/internal/generated/snippets/compute/apiv1/DisksClient/Resize/main.go index 1dfb68b19648..882d545b2356 100644 --- a/internal/generated/snippets/compute/apiv1/DisksClient/Resize/main.go +++ b/internal/generated/snippets/compute/apiv1/DisksClient/Resize/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/DisksClient/SetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/DisksClient/SetIamPolicy/main.go index f236d991f8f1..341d7b499b62 100644 --- a/internal/generated/snippets/compute/apiv1/DisksClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/DisksClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/DisksClient/SetLabels/main.go b/internal/generated/snippets/compute/apiv1/DisksClient/SetLabels/main.go index 70ab94cb79f2..b99fd8c0a9ec 100644 --- a/internal/generated/snippets/compute/apiv1/DisksClient/SetLabels/main.go +++ b/internal/generated/snippets/compute/apiv1/DisksClient/SetLabels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/DisksClient/StartAsyncReplication/main.go b/internal/generated/snippets/compute/apiv1/DisksClient/StartAsyncReplication/main.go index 24240a3fe3d3..4b704ed112a8 100644 --- a/internal/generated/snippets/compute/apiv1/DisksClient/StartAsyncReplication/main.go +++ b/internal/generated/snippets/compute/apiv1/DisksClient/StartAsyncReplication/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/DisksClient/StopAsyncReplication/main.go b/internal/generated/snippets/compute/apiv1/DisksClient/StopAsyncReplication/main.go index db6beb041e3e..1d2cd442784f 100644 --- a/internal/generated/snippets/compute/apiv1/DisksClient/StopAsyncReplication/main.go +++ b/internal/generated/snippets/compute/apiv1/DisksClient/StopAsyncReplication/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/DisksClient/StopGroupAsyncReplication/main.go b/internal/generated/snippets/compute/apiv1/DisksClient/StopGroupAsyncReplication/main.go index 0af7649c3ccc..d270b386e24b 100644 --- a/internal/generated/snippets/compute/apiv1/DisksClient/StopGroupAsyncReplication/main.go +++ b/internal/generated/snippets/compute/apiv1/DisksClient/StopGroupAsyncReplication/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/DisksClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/DisksClient/TestIamPermissions/main.go index 4bd3fb3db65e..5545dad1581a 100644 --- a/internal/generated/snippets/compute/apiv1/DisksClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/DisksClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/DisksClient/Update/main.go b/internal/generated/snippets/compute/apiv1/DisksClient/Update/main.go index 98d56507e542..1cd168d1128a 100644 --- a/internal/generated/snippets/compute/apiv1/DisksClient/Update/main.go +++ b/internal/generated/snippets/compute/apiv1/DisksClient/Update/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ExternalVpnGatewaysClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/ExternalVpnGatewaysClient/Delete/main.go index d8410485e62c..fbe3ed186d38 100644 --- a/internal/generated/snippets/compute/apiv1/ExternalVpnGatewaysClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/ExternalVpnGatewaysClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ExternalVpnGatewaysClient/Get/main.go b/internal/generated/snippets/compute/apiv1/ExternalVpnGatewaysClient/Get/main.go index d7cf2839c6c7..82cbe873d468 100644 --- a/internal/generated/snippets/compute/apiv1/ExternalVpnGatewaysClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/ExternalVpnGatewaysClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ExternalVpnGatewaysClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/ExternalVpnGatewaysClient/Insert/main.go index 23180df6c478..088611155c48 100644 --- a/internal/generated/snippets/compute/apiv1/ExternalVpnGatewaysClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/ExternalVpnGatewaysClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ExternalVpnGatewaysClient/List/main.go b/internal/generated/snippets/compute/apiv1/ExternalVpnGatewaysClient/List/main.go index de07bd20d6bb..56c9dc21ee29 100644 --- a/internal/generated/snippets/compute/apiv1/ExternalVpnGatewaysClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/ExternalVpnGatewaysClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ExternalVpnGatewaysClient/SetLabels/main.go b/internal/generated/snippets/compute/apiv1/ExternalVpnGatewaysClient/SetLabels/main.go index 3c694d4a31cc..3d504dde06bf 100644 --- a/internal/generated/snippets/compute/apiv1/ExternalVpnGatewaysClient/SetLabels/main.go +++ b/internal/generated/snippets/compute/apiv1/ExternalVpnGatewaysClient/SetLabels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ExternalVpnGatewaysClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/ExternalVpnGatewaysClient/TestIamPermissions/main.go index f3f738660d78..959917ff4b5c 100644 --- a/internal/generated/snippets/compute/apiv1/ExternalVpnGatewaysClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/ExternalVpnGatewaysClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/AddAssociation/main.go b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/AddAssociation/main.go index b79bdfe8e356..c8b3366ff6a0 100644 --- a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/AddAssociation/main.go +++ b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/AddAssociation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/AddRule/main.go b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/AddRule/main.go index c3a5f8ab2646..9c9c5e194262 100644 --- a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/AddRule/main.go +++ b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/AddRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/CloneRules/main.go b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/CloneRules/main.go index 0f5c5af74f3e..2f635ff9b4a3 100644 --- a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/CloneRules/main.go +++ b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/CloneRules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/Delete/main.go index cb38a1acbbff..99fa588a38bf 100644 --- a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/Get/main.go index e5f0272c4c33..72023d983f93 100644 --- a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/GetAssociation/main.go b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/GetAssociation/main.go index ef5130df202c..e9f1a6de03c8 100644 --- a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/GetAssociation/main.go +++ b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/GetAssociation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/GetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/GetIamPolicy/main.go index b9b853458385..3f93b43a882a 100644 --- a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/GetRule/main.go b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/GetRule/main.go index d241c39dd61f..1309e69918c9 100644 --- a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/GetRule/main.go +++ b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/GetRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/Insert/main.go index c8cd9e50f5dd..d8eb7ebc6ebf 100644 --- a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/List/main.go b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/List/main.go index 5b1bcf2dd2e0..8b9d4ba7b718 100644 --- a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/ListAssociations/main.go b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/ListAssociations/main.go index 0c424ef9e06a..23c86e4c2704 100644 --- a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/ListAssociations/main.go +++ b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/ListAssociations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/Move/main.go b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/Move/main.go index 37a7345f9f47..ca25c0f5378d 100644 --- a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/Move/main.go +++ b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/Move/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/Patch/main.go index a8a1dca7ba17..730859130147 100644 --- a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/PatchRule/main.go b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/PatchRule/main.go index 45318a026d90..794bc040f46f 100644 --- a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/PatchRule/main.go +++ b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/PatchRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/RemoveAssociation/main.go b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/RemoveAssociation/main.go index 080c141523ea..853724841b1b 100644 --- a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/RemoveAssociation/main.go +++ b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/RemoveAssociation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/RemoveRule/main.go b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/RemoveRule/main.go index 55764d8d2ada..e9db7501f86e 100644 --- a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/RemoveRule/main.go +++ b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/RemoveRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/SetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/SetIamPolicy/main.go index 5ffb23b127c9..5b8aa847902d 100644 --- a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/TestIamPermissions/main.go index 03f1a7f56c25..69c6f205f756 100644 --- a/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/FirewallPoliciesClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/FirewallsClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/FirewallsClient/Delete/main.go index 1467d636fd2e..2e12f51945f9 100644 --- a/internal/generated/snippets/compute/apiv1/FirewallsClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/FirewallsClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/FirewallsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/FirewallsClient/Get/main.go index b8ea33e43829..acf9ab93dca2 100644 --- a/internal/generated/snippets/compute/apiv1/FirewallsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/FirewallsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/FirewallsClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/FirewallsClient/Insert/main.go index 829894f90755..366d01ea7b53 100644 --- a/internal/generated/snippets/compute/apiv1/FirewallsClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/FirewallsClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/FirewallsClient/List/main.go b/internal/generated/snippets/compute/apiv1/FirewallsClient/List/main.go index dc37f02b7b58..ede49c41900d 100644 --- a/internal/generated/snippets/compute/apiv1/FirewallsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/FirewallsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/FirewallsClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/FirewallsClient/Patch/main.go index bed7416e6d91..dee2111e8f36 100644 --- a/internal/generated/snippets/compute/apiv1/FirewallsClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/FirewallsClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/FirewallsClient/Update/main.go b/internal/generated/snippets/compute/apiv1/FirewallsClient/Update/main.go index 8dfb152a3856..b2a8fdd6e3b0 100644 --- a/internal/generated/snippets/compute/apiv1/FirewallsClient/Update/main.go +++ b/internal/generated/snippets/compute/apiv1/FirewallsClient/Update/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/AggregatedList/main.go index 5cbc28d7e605..fb98a760c6b2 100644 --- a/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/Delete/main.go index da9049e80ca6..a7eba81b2af8 100644 --- a/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/Get/main.go index 50855b4f4e03..5eb5fece0403 100644 --- a/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/Insert/main.go index c0a80daca8e4..f89e0fe29184 100644 --- a/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/List/main.go b/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/List/main.go index c4252095799c..2f0b85546a77 100644 --- a/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/Patch/main.go index d2cae6e02f8b..e1a3e8b13116 100644 --- a/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/SetLabels/main.go b/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/SetLabels/main.go index e8b31a89cae2..1e347e2a4b14 100644 --- a/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/SetLabels/main.go +++ b/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/SetLabels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/SetTarget/main.go b/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/SetTarget/main.go index 258bf5540b75..313e79e8c78e 100644 --- a/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/SetTarget/main.go +++ b/internal/generated/snippets/compute/apiv1/ForwardingRulesClient/SetTarget/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalAddressesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/GlobalAddressesClient/Delete/main.go index 90430df1aa98..9e98d0916ee5 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalAddressesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalAddressesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalAddressesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/GlobalAddressesClient/Get/main.go index d1a2410c9a36..f5974732b391 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalAddressesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalAddressesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalAddressesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/GlobalAddressesClient/Insert/main.go index a1c271d06222..91cff033841b 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalAddressesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalAddressesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalAddressesClient/List/main.go b/internal/generated/snippets/compute/apiv1/GlobalAddressesClient/List/main.go index 1811b6b2603b..3e3c86442575 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalAddressesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalAddressesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalAddressesClient/Move/main.go b/internal/generated/snippets/compute/apiv1/GlobalAddressesClient/Move/main.go index 462533666dae..603678d6fa99 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalAddressesClient/Move/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalAddressesClient/Move/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalAddressesClient/SetLabels/main.go b/internal/generated/snippets/compute/apiv1/GlobalAddressesClient/SetLabels/main.go index 1b0bb3e77ac7..496508f23b3c 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalAddressesClient/SetLabels/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalAddressesClient/SetLabels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalForwardingRulesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/GlobalForwardingRulesClient/Delete/main.go index 1f91aeb13636..31922f220fd0 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalForwardingRulesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalForwardingRulesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalForwardingRulesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/GlobalForwardingRulesClient/Get/main.go index 5c301e9b59fc..338588ac59d0 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalForwardingRulesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalForwardingRulesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalForwardingRulesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/GlobalForwardingRulesClient/Insert/main.go index e9f311e67332..a809b3e868c6 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalForwardingRulesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalForwardingRulesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalForwardingRulesClient/List/main.go b/internal/generated/snippets/compute/apiv1/GlobalForwardingRulesClient/List/main.go index 602222a2daac..4e0b6a08db3d 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalForwardingRulesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalForwardingRulesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalForwardingRulesClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/GlobalForwardingRulesClient/Patch/main.go index 148b14f128e1..67de86397464 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalForwardingRulesClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalForwardingRulesClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalForwardingRulesClient/SetLabels/main.go b/internal/generated/snippets/compute/apiv1/GlobalForwardingRulesClient/SetLabels/main.go index 9c2659123252..31cee6b61f50 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalForwardingRulesClient/SetLabels/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalForwardingRulesClient/SetLabels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalForwardingRulesClient/SetTarget/main.go b/internal/generated/snippets/compute/apiv1/GlobalForwardingRulesClient/SetTarget/main.go index 34b3a77d5268..6c53a8e22e13 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalForwardingRulesClient/SetTarget/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalForwardingRulesClient/SetTarget/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalNetworkEndpointGroupsClient/AttachNetworkEndpoints/main.go b/internal/generated/snippets/compute/apiv1/GlobalNetworkEndpointGroupsClient/AttachNetworkEndpoints/main.go index 7b88fc0149ac..29ea16658bca 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalNetworkEndpointGroupsClient/AttachNetworkEndpoints/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalNetworkEndpointGroupsClient/AttachNetworkEndpoints/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalNetworkEndpointGroupsClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/GlobalNetworkEndpointGroupsClient/Delete/main.go index 3fd109d07b30..1c921f04efcb 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalNetworkEndpointGroupsClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalNetworkEndpointGroupsClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalNetworkEndpointGroupsClient/DetachNetworkEndpoints/main.go b/internal/generated/snippets/compute/apiv1/GlobalNetworkEndpointGroupsClient/DetachNetworkEndpoints/main.go index 02d15192eeb6..41f1a8aabc17 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalNetworkEndpointGroupsClient/DetachNetworkEndpoints/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalNetworkEndpointGroupsClient/DetachNetworkEndpoints/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalNetworkEndpointGroupsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/GlobalNetworkEndpointGroupsClient/Get/main.go index b397aee153b2..270c3ad8de12 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalNetworkEndpointGroupsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalNetworkEndpointGroupsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalNetworkEndpointGroupsClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/GlobalNetworkEndpointGroupsClient/Insert/main.go index f1649cea23df..b3c47f2d9bfa 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalNetworkEndpointGroupsClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalNetworkEndpointGroupsClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalNetworkEndpointGroupsClient/List/main.go b/internal/generated/snippets/compute/apiv1/GlobalNetworkEndpointGroupsClient/List/main.go index 79c6cf56aeb7..da7bd85b29d9 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalNetworkEndpointGroupsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalNetworkEndpointGroupsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalNetworkEndpointGroupsClient/ListNetworkEndpoints/main.go b/internal/generated/snippets/compute/apiv1/GlobalNetworkEndpointGroupsClient/ListNetworkEndpoints/main.go index b60b2f025bd9..89dc07613203 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalNetworkEndpointGroupsClient/ListNetworkEndpoints/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalNetworkEndpointGroupsClient/ListNetworkEndpoints/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalOperationsClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/GlobalOperationsClient/AggregatedList/main.go index 7450ed538bd4..34a09d2d00f5 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalOperationsClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalOperationsClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalOperationsClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/GlobalOperationsClient/Delete/main.go index eef3a063039c..0dadf9eacf8c 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalOperationsClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalOperationsClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalOperationsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/GlobalOperationsClient/Get/main.go index 2cd93a704e2f..e6cc439c6853 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalOperationsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalOperationsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalOperationsClient/List/main.go b/internal/generated/snippets/compute/apiv1/GlobalOperationsClient/List/main.go index d8832f0afffb..549209ce1e57 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalOperationsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalOperationsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalOperationsClient/Wait/main.go b/internal/generated/snippets/compute/apiv1/GlobalOperationsClient/Wait/main.go index a4517cb30773..ec54f2165e8a 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalOperationsClient/Wait/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalOperationsClient/Wait/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalOrganizationOperationsClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/GlobalOrganizationOperationsClient/Delete/main.go index 539e794a3e5b..89b3759a7aa1 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalOrganizationOperationsClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalOrganizationOperationsClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalOrganizationOperationsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/GlobalOrganizationOperationsClient/Get/main.go index 5f391e58f9ec..644dd6ec8c2e 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalOrganizationOperationsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalOrganizationOperationsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalOrganizationOperationsClient/List/main.go b/internal/generated/snippets/compute/apiv1/GlobalOrganizationOperationsClient/List/main.go index f09988e968c2..c29e969bbfd3 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalOrganizationOperationsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalOrganizationOperationsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalPublicDelegatedPrefixesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/GlobalPublicDelegatedPrefixesClient/Delete/main.go index e54eab175c23..da45b1c0b86d 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalPublicDelegatedPrefixesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalPublicDelegatedPrefixesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalPublicDelegatedPrefixesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/GlobalPublicDelegatedPrefixesClient/Get/main.go index 8ab6cb08c6e3..4930655f4cc0 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalPublicDelegatedPrefixesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalPublicDelegatedPrefixesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalPublicDelegatedPrefixesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/GlobalPublicDelegatedPrefixesClient/Insert/main.go index 0d70d537b920..ab873634e90e 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalPublicDelegatedPrefixesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalPublicDelegatedPrefixesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalPublicDelegatedPrefixesClient/List/main.go b/internal/generated/snippets/compute/apiv1/GlobalPublicDelegatedPrefixesClient/List/main.go index 3d5111dcc94d..ad385db74585 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalPublicDelegatedPrefixesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalPublicDelegatedPrefixesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/GlobalPublicDelegatedPrefixesClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/GlobalPublicDelegatedPrefixesClient/Patch/main.go index 943ceb1da3bd..d2853e30d91b 100644 --- a/internal/generated/snippets/compute/apiv1/GlobalPublicDelegatedPrefixesClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/GlobalPublicDelegatedPrefixesClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/HealthChecksClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/HealthChecksClient/AggregatedList/main.go index 111ec4d8d452..4d841b1e66a8 100644 --- a/internal/generated/snippets/compute/apiv1/HealthChecksClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/HealthChecksClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/HealthChecksClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/HealthChecksClient/Delete/main.go index 083d135dcd65..fdc0c0d50446 100644 --- a/internal/generated/snippets/compute/apiv1/HealthChecksClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/HealthChecksClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/HealthChecksClient/Get/main.go b/internal/generated/snippets/compute/apiv1/HealthChecksClient/Get/main.go index 5578e644eb8c..a39ec6ed0983 100644 --- a/internal/generated/snippets/compute/apiv1/HealthChecksClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/HealthChecksClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/HealthChecksClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/HealthChecksClient/Insert/main.go index 8e1aeb6442a9..93ee10f3cb86 100644 --- a/internal/generated/snippets/compute/apiv1/HealthChecksClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/HealthChecksClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/HealthChecksClient/List/main.go b/internal/generated/snippets/compute/apiv1/HealthChecksClient/List/main.go index 5e6d60c4f9fe..a41426f5ad52 100644 --- a/internal/generated/snippets/compute/apiv1/HealthChecksClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/HealthChecksClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/HealthChecksClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/HealthChecksClient/Patch/main.go index d4a5c065c04f..77189768d518 100644 --- a/internal/generated/snippets/compute/apiv1/HealthChecksClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/HealthChecksClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/HealthChecksClient/Update/main.go b/internal/generated/snippets/compute/apiv1/HealthChecksClient/Update/main.go index 3798f85e6d7f..2de7362e26b6 100644 --- a/internal/generated/snippets/compute/apiv1/HealthChecksClient/Update/main.go +++ b/internal/generated/snippets/compute/apiv1/HealthChecksClient/Update/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ImageFamilyViewsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/ImageFamilyViewsClient/Get/main.go index 494b21e19fc2..6709578e9665 100644 --- a/internal/generated/snippets/compute/apiv1/ImageFamilyViewsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/ImageFamilyViewsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ImagesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/ImagesClient/Delete/main.go index ee045c04182c..8c06a6d073fc 100644 --- a/internal/generated/snippets/compute/apiv1/ImagesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/ImagesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ImagesClient/Deprecate/main.go b/internal/generated/snippets/compute/apiv1/ImagesClient/Deprecate/main.go index f603b31f9e23..3e7eb41cc349 100644 --- a/internal/generated/snippets/compute/apiv1/ImagesClient/Deprecate/main.go +++ b/internal/generated/snippets/compute/apiv1/ImagesClient/Deprecate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ImagesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/ImagesClient/Get/main.go index 9f931898bb7f..8acdeee41217 100644 --- a/internal/generated/snippets/compute/apiv1/ImagesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/ImagesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ImagesClient/GetFromFamily/main.go b/internal/generated/snippets/compute/apiv1/ImagesClient/GetFromFamily/main.go index f9a9fae68a11..155045d9f224 100644 --- a/internal/generated/snippets/compute/apiv1/ImagesClient/GetFromFamily/main.go +++ b/internal/generated/snippets/compute/apiv1/ImagesClient/GetFromFamily/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ImagesClient/GetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/ImagesClient/GetIamPolicy/main.go index add78296c682..d52d72a0a0a8 100644 --- a/internal/generated/snippets/compute/apiv1/ImagesClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/ImagesClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ImagesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/ImagesClient/Insert/main.go index e3392b8364bf..a470d1413964 100644 --- a/internal/generated/snippets/compute/apiv1/ImagesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/ImagesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ImagesClient/List/main.go b/internal/generated/snippets/compute/apiv1/ImagesClient/List/main.go index 0bf6d606c6c8..207a67b73ebc 100644 --- a/internal/generated/snippets/compute/apiv1/ImagesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/ImagesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ImagesClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/ImagesClient/Patch/main.go index 66e244a0c144..0daac24999b8 100644 --- a/internal/generated/snippets/compute/apiv1/ImagesClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/ImagesClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ImagesClient/SetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/ImagesClient/SetIamPolicy/main.go index 1b0c65a75f00..1e726fc63b6d 100644 --- a/internal/generated/snippets/compute/apiv1/ImagesClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/ImagesClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ImagesClient/SetLabels/main.go b/internal/generated/snippets/compute/apiv1/ImagesClient/SetLabels/main.go index 4df59e84edc2..edf658f413cc 100644 --- a/internal/generated/snippets/compute/apiv1/ImagesClient/SetLabels/main.go +++ b/internal/generated/snippets/compute/apiv1/ImagesClient/SetLabels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ImagesClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/ImagesClient/TestIamPermissions/main.go index 6ce1c0cc6c3e..5b391641c4f9 100644 --- a/internal/generated/snippets/compute/apiv1/ImagesClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/ImagesClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagerResizeRequestsClient/Cancel/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagerResizeRequestsClient/Cancel/main.go index 0e151e470f0f..9d3751673a60 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagerResizeRequestsClient/Cancel/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagerResizeRequestsClient/Cancel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagerResizeRequestsClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagerResizeRequestsClient/Delete/main.go index dadfd30a016c..e1fd786bf7ad 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagerResizeRequestsClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagerResizeRequestsClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagerResizeRequestsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagerResizeRequestsClient/Get/main.go index f1924a7508e6..48b8034d04fe 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagerResizeRequestsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagerResizeRequestsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagerResizeRequestsClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagerResizeRequestsClient/Insert/main.go index fc4b4408f82c..4a36b55e4840 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagerResizeRequestsClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagerResizeRequestsClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagerResizeRequestsClient/List/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagerResizeRequestsClient/List/main.go index e514b3b86873..d5b7792bc1da 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagerResizeRequestsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagerResizeRequestsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/AbandonInstances/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/AbandonInstances/main.go index 58e2fc9fc719..8b18105d9b69 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/AbandonInstances/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/AbandonInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/AggregatedList/main.go index f93e1330b68b..a708e1c936a1 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/ApplyUpdatesToInstances/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/ApplyUpdatesToInstances/main.go index 5c13581c913d..1070962b4a7a 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/ApplyUpdatesToInstances/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/ApplyUpdatesToInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/CreateInstances/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/CreateInstances/main.go index 2354414072f7..984eac07eb9d 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/CreateInstances/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/CreateInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/Delete/main.go index f8ea1eabd9f8..bb7e13a19a4f 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/DeleteInstances/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/DeleteInstances/main.go index 9aecd7f8ab77..df2ffffbc931 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/DeleteInstances/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/DeleteInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/DeletePerInstanceConfigs/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/DeletePerInstanceConfigs/main.go index 45586648ca82..e8f616de4502 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/DeletePerInstanceConfigs/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/DeletePerInstanceConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/Get/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/Get/main.go index e9cc84b05015..8c9c32930eb7 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/Insert/main.go index 133cd3964334..ae0a60fc3c3b 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/List/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/List/main.go index 7eed183573fe..61c5092b839d 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/ListErrors/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/ListErrors/main.go index 4527ded491c5..b3783186764a 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/ListErrors/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/ListErrors/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/ListManagedInstances/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/ListManagedInstances/main.go index 991b5544979f..18fff0ddde5d 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/ListManagedInstances/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/ListManagedInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/ListPerInstanceConfigs/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/ListPerInstanceConfigs/main.go index 82d113119e93..afd3d1632013 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/ListPerInstanceConfigs/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/ListPerInstanceConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/Patch/main.go index 9c55ce0edd26..97637c4d3a49 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/PatchPerInstanceConfigs/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/PatchPerInstanceConfigs/main.go index 9b7a074e96f3..7b5f58a19ec8 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/PatchPerInstanceConfigs/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/PatchPerInstanceConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/RecreateInstances/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/RecreateInstances/main.go index 74c39dcc58d7..3f8563201cb4 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/RecreateInstances/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/RecreateInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/Resize/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/Resize/main.go index 79e7f5ba42d7..c8d5e250ceb6 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/Resize/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/Resize/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/ResumeInstances/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/ResumeInstances/main.go index 92eeb4a14bf7..234ceb4531a9 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/ResumeInstances/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/ResumeInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/SetInstanceTemplate/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/SetInstanceTemplate/main.go index 39af200b3f4f..afad7e8ce5d5 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/SetInstanceTemplate/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/SetInstanceTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/SetTargetPools/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/SetTargetPools/main.go index 5a591ebdcf37..dc225f4a54dd 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/SetTargetPools/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/SetTargetPools/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/StartInstances/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/StartInstances/main.go index bd209b1c9595..33e08acc4484 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/StartInstances/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/StartInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/StopInstances/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/StopInstances/main.go index 62a68c94727b..d2ca21223d61 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/StopInstances/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/StopInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/SuspendInstances/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/SuspendInstances/main.go index b6215646b356..91a0ac3e2a94 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/SuspendInstances/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/SuspendInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/UpdatePerInstanceConfigs/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/UpdatePerInstanceConfigs/main.go index 4ca57f6d819d..7d18f91fa989 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/UpdatePerInstanceConfigs/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupManagersClient/UpdatePerInstanceConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/AddInstances/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/AddInstances/main.go index 69e6c1b36276..57295c1dd124 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/AddInstances/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/AddInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/AggregatedList/main.go index fc12a1a93ad9..30a0e5861516 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/Delete/main.go index 367102a7a84a..d05e772c6681 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/Get/main.go index 5a2d3a11dbe6..9e03dd77b0ba 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/Insert/main.go index b68fa74d6775..75a6888f573c 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/List/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/List/main.go index 22b7226f98b1..d619da5d170c 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/ListInstances/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/ListInstances/main.go index 81fb357988a3..f4db30c5131c 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/ListInstances/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/ListInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/RemoveInstances/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/RemoveInstances/main.go index f96a6084601f..bb9d5820cece 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/RemoveInstances/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/RemoveInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/SetNamedPorts/main.go b/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/SetNamedPorts/main.go index ed173774ffad..b29ec4ac7bd7 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/SetNamedPorts/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceGroupsClient/SetNamedPorts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceSettingsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/InstanceSettingsClient/Get/main.go index 7e07e6160b0c..a34b2dd3facf 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceSettingsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceSettingsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceSettingsClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/InstanceSettingsClient/Patch/main.go index e9ae19503407..76b4856e061a 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceSettingsClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceSettingsClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/AggregatedList/main.go index 6b0473e76974..691329f497bc 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/Delete/main.go index ce17b5cc8062..057ba215a644 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/Get/main.go index d8c8599bc7dd..c98e6887b74b 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/GetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/GetIamPolicy/main.go index 4601c3e1fb51..8bf5b8f04999 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/Insert/main.go index edf73f4ecd93..18f5eda0208b 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/List/main.go b/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/List/main.go index 40b521f1f1f8..ded5241a9b04 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/SetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/SetIamPolicy/main.go index 6dadd735ef27..34848b807a8c 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/TestIamPermissions/main.go index 96e8d8b0890c..c136b7297fe5 100644 --- a/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/InstanceTemplatesClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/AddAccessConfig/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/AddAccessConfig/main.go index aef79e87cd17..435c44bf666b 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/AddAccessConfig/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/AddAccessConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/AddResourcePolicies/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/AddResourcePolicies/main.go index feadef0b3743..b51f642fa4f5 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/AddResourcePolicies/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/AddResourcePolicies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/AggregatedList/main.go index f76790efee45..f3b3473ff625 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/AttachDisk/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/AttachDisk/main.go index 23b1cdb1c330..440643e4c192 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/AttachDisk/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/AttachDisk/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/BulkInsert/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/BulkInsert/main.go index bc4e354f21aa..535b79d6c656 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/BulkInsert/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/BulkInsert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/Delete/main.go index c20aeb595f80..4130b62cac8a 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/DeleteAccessConfig/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/DeleteAccessConfig/main.go index 2847a3a2f834..2fc0d1202d4b 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/DeleteAccessConfig/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/DeleteAccessConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/DetachDisk/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/DetachDisk/main.go index 334703872e26..36c4693dd856 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/DetachDisk/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/DetachDisk/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/Get/main.go index 5012c2d05820..83b466f36e9a 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/GetEffectiveFirewalls/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/GetEffectiveFirewalls/main.go index 4d141e52d816..f4d00438a3fc 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/GetEffectiveFirewalls/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/GetEffectiveFirewalls/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/GetGuestAttributes/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/GetGuestAttributes/main.go index c30d364a6fdf..afdb3f0ba8ba 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/GetGuestAttributes/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/GetGuestAttributes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/GetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/GetIamPolicy/main.go index 68675e7b00da..f46d3a63afb4 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/GetScreenshot/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/GetScreenshot/main.go index cf25caf56e97..af4478e90eef 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/GetScreenshot/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/GetScreenshot/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/GetSerialPortOutput/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/GetSerialPortOutput/main.go index d6d5ac942331..f967f55c5df0 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/GetSerialPortOutput/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/GetSerialPortOutput/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/GetShieldedInstanceIdentity/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/GetShieldedInstanceIdentity/main.go index 7b5ae90655d0..178683b05d94 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/GetShieldedInstanceIdentity/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/GetShieldedInstanceIdentity/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/Insert/main.go index 46272f93b00c..3e98c8de5ba6 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/List/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/List/main.go index 14eef97303b4..6179d6002870 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/ListReferrers/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/ListReferrers/main.go index d514bb22bf64..d4326aa48ac1 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/ListReferrers/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/ListReferrers/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/PerformMaintenance/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/PerformMaintenance/main.go index b0745dcee7f9..d53def4ebbf5 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/PerformMaintenance/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/PerformMaintenance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/RemoveResourcePolicies/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/RemoveResourcePolicies/main.go index 092ad8fdd009..840b2445b67d 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/RemoveResourcePolicies/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/RemoveResourcePolicies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/Reset/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/Reset/main.go index 89834592dbad..5e8946215381 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/Reset/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/Reset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/Resume/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/Resume/main.go index 9e9fea13f6a1..ab8dcce7b5b0 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/Resume/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/Resume/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/SendDiagnosticInterrupt/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/SendDiagnosticInterrupt/main.go index 6cd3a3a302d0..bfea78785e72 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/SendDiagnosticInterrupt/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/SendDiagnosticInterrupt/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/SetDeletionProtection/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/SetDeletionProtection/main.go index 907685c15ef5..25e3d6e9ddff 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/SetDeletionProtection/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/SetDeletionProtection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/SetDiskAutoDelete/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/SetDiskAutoDelete/main.go index edbdd146cc25..7ec71021a72f 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/SetDiskAutoDelete/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/SetDiskAutoDelete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/SetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/SetIamPolicy/main.go index a59848994396..f2ea08b21965 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/SetLabels/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/SetLabels/main.go index 0d42bca0acfb..cb4725221e2c 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/SetLabels/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/SetLabels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/SetMachineResources/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/SetMachineResources/main.go index a76bfc5053ee..048c2cdbf1c1 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/SetMachineResources/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/SetMachineResources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/SetMachineType/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/SetMachineType/main.go index b4bddfe8a851..dfc15da5fbf6 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/SetMachineType/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/SetMachineType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/SetMetadata/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/SetMetadata/main.go index b75ff04ec008..4fd2559fc321 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/SetMetadata/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/SetMetadata/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/SetMinCpuPlatform/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/SetMinCpuPlatform/main.go index 3383e6753b4d..b1723ce600a3 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/SetMinCpuPlatform/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/SetMinCpuPlatform/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/SetName/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/SetName/main.go index c6ea8be236b1..d007cc66a9dd 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/SetName/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/SetName/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/SetScheduling/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/SetScheduling/main.go index 8e30445295b0..95a6d0a1b7b8 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/SetScheduling/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/SetScheduling/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/SetSecurityPolicy/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/SetSecurityPolicy/main.go index c9a2bc9e68fe..8b38fb57f93d 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/SetSecurityPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/SetSecurityPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/SetServiceAccount/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/SetServiceAccount/main.go index 0590c704f67c..4b27634fefbd 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/SetServiceAccount/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/SetServiceAccount/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/SetShieldedInstanceIntegrityPolicy/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/SetShieldedInstanceIntegrityPolicy/main.go index db9e411ec293..e3536871dddb 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/SetShieldedInstanceIntegrityPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/SetShieldedInstanceIntegrityPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/SetTags/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/SetTags/main.go index 31afaa407586..7d287688e0cc 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/SetTags/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/SetTags/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/SimulateMaintenanceEvent/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/SimulateMaintenanceEvent/main.go index a9edddbbc055..bcf48f7ee0c9 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/SimulateMaintenanceEvent/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/SimulateMaintenanceEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/Start/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/Start/main.go index 8bb4b6ffed15..eb68aef69d4e 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/Start/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/Start/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/StartWithEncryptionKey/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/StartWithEncryptionKey/main.go index b40f7e445dcb..7c76c5be3882 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/StartWithEncryptionKey/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/StartWithEncryptionKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/Stop/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/Stop/main.go index f211b356f0f3..4f08f24c111f 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/Stop/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/Stop/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/Suspend/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/Suspend/main.go index 7d8848f613fc..1471fbc874ce 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/Suspend/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/Suspend/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/TestIamPermissions/main.go index 1826977ef130..adedbb9a693d 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/Update/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/Update/main.go index 769cb23fbd61..f6e8cc241db8 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/Update/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/Update/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/UpdateAccessConfig/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/UpdateAccessConfig/main.go index e23049223adb..8d163b65b927 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/UpdateAccessConfig/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/UpdateAccessConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/UpdateDisplayDevice/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/UpdateDisplayDevice/main.go index ba2f18e9e9a1..a60c8d26e361 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/UpdateDisplayDevice/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/UpdateDisplayDevice/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/UpdateNetworkInterface/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/UpdateNetworkInterface/main.go index acc7ffd66106..b9fd3ec1e308 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/UpdateNetworkInterface/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/UpdateNetworkInterface/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstancesClient/UpdateShieldedInstanceConfig/main.go b/internal/generated/snippets/compute/apiv1/InstancesClient/UpdateShieldedInstanceConfig/main.go index 0fa851c5e9bb..a0525a9816b5 100644 --- a/internal/generated/snippets/compute/apiv1/InstancesClient/UpdateShieldedInstanceConfig/main.go +++ b/internal/generated/snippets/compute/apiv1/InstancesClient/UpdateShieldedInstanceConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/AggregatedList/main.go index 1ef155da0daa..6ec3a4459096 100644 --- a/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/Delete/main.go index 030b89abeac9..b66ce2219d96 100644 --- a/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/Get/main.go index 3b63e1ede0e6..2077c6de3db6 100644 --- a/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/GetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/GetIamPolicy/main.go index b6a70112a531..928adaa254c5 100644 --- a/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/Insert/main.go index ac521e968982..cdc253858c17 100644 --- a/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/List/main.go b/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/List/main.go index 647ffe119965..b99e07746bec 100644 --- a/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/SetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/SetIamPolicy/main.go index 367787d15b0b..bfbb85fbc35d 100644 --- a/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/SetLabels/main.go b/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/SetLabels/main.go index 22ad1ce079ab..f7bb0d79acb6 100644 --- a/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/SetLabels/main.go +++ b/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/SetLabels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/TestIamPermissions/main.go index 68ce40fa2257..0829f9d83e65 100644 --- a/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/InstantSnapshotsClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InterconnectAttachmentsClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/InterconnectAttachmentsClient/AggregatedList/main.go index d9fbecf8a822..779d1afec22c 100644 --- a/internal/generated/snippets/compute/apiv1/InterconnectAttachmentsClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/InterconnectAttachmentsClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InterconnectAttachmentsClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/InterconnectAttachmentsClient/Delete/main.go index a31c7cc00f0a..b82c0c9b684f 100644 --- a/internal/generated/snippets/compute/apiv1/InterconnectAttachmentsClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/InterconnectAttachmentsClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InterconnectAttachmentsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/InterconnectAttachmentsClient/Get/main.go index 4b371aeeb0c4..1ca2e7e6a09f 100644 --- a/internal/generated/snippets/compute/apiv1/InterconnectAttachmentsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/InterconnectAttachmentsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InterconnectAttachmentsClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/InterconnectAttachmentsClient/Insert/main.go index d5563b77b5c8..029e97cc9f95 100644 --- a/internal/generated/snippets/compute/apiv1/InterconnectAttachmentsClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/InterconnectAttachmentsClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InterconnectAttachmentsClient/List/main.go b/internal/generated/snippets/compute/apiv1/InterconnectAttachmentsClient/List/main.go index 0bd979e2f131..e62032030096 100644 --- a/internal/generated/snippets/compute/apiv1/InterconnectAttachmentsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/InterconnectAttachmentsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InterconnectAttachmentsClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/InterconnectAttachmentsClient/Patch/main.go index 5a483bd4b06c..30f8b4565147 100644 --- a/internal/generated/snippets/compute/apiv1/InterconnectAttachmentsClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/InterconnectAttachmentsClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InterconnectAttachmentsClient/SetLabels/main.go b/internal/generated/snippets/compute/apiv1/InterconnectAttachmentsClient/SetLabels/main.go index 92dd9eb6a9fd..fd865144a55f 100644 --- a/internal/generated/snippets/compute/apiv1/InterconnectAttachmentsClient/SetLabels/main.go +++ b/internal/generated/snippets/compute/apiv1/InterconnectAttachmentsClient/SetLabels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InterconnectLocationsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/InterconnectLocationsClient/Get/main.go index 80cac89e1a7f..619d203453d9 100644 --- a/internal/generated/snippets/compute/apiv1/InterconnectLocationsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/InterconnectLocationsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InterconnectLocationsClient/List/main.go b/internal/generated/snippets/compute/apiv1/InterconnectLocationsClient/List/main.go index 06d6b4249a95..8765245fd7fb 100644 --- a/internal/generated/snippets/compute/apiv1/InterconnectLocationsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/InterconnectLocationsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InterconnectRemoteLocationsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/InterconnectRemoteLocationsClient/Get/main.go index 6e805f281677..b9db737306c4 100644 --- a/internal/generated/snippets/compute/apiv1/InterconnectRemoteLocationsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/InterconnectRemoteLocationsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InterconnectRemoteLocationsClient/List/main.go b/internal/generated/snippets/compute/apiv1/InterconnectRemoteLocationsClient/List/main.go index 70428624fab5..ce4a2005851c 100644 --- a/internal/generated/snippets/compute/apiv1/InterconnectRemoteLocationsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/InterconnectRemoteLocationsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InterconnectsClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/InterconnectsClient/Delete/main.go index 98dc5c980f1e..6c3975d0faa2 100644 --- a/internal/generated/snippets/compute/apiv1/InterconnectsClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/InterconnectsClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InterconnectsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/InterconnectsClient/Get/main.go index d10a2b737788..36c46222871f 100644 --- a/internal/generated/snippets/compute/apiv1/InterconnectsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/InterconnectsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InterconnectsClient/GetDiagnostics/main.go b/internal/generated/snippets/compute/apiv1/InterconnectsClient/GetDiagnostics/main.go index 9ac557b2f3c7..04277c744c92 100644 --- a/internal/generated/snippets/compute/apiv1/InterconnectsClient/GetDiagnostics/main.go +++ b/internal/generated/snippets/compute/apiv1/InterconnectsClient/GetDiagnostics/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InterconnectsClient/GetMacsecConfig/main.go b/internal/generated/snippets/compute/apiv1/InterconnectsClient/GetMacsecConfig/main.go index cf62429b1542..dbb6fa5f6cdc 100644 --- a/internal/generated/snippets/compute/apiv1/InterconnectsClient/GetMacsecConfig/main.go +++ b/internal/generated/snippets/compute/apiv1/InterconnectsClient/GetMacsecConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InterconnectsClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/InterconnectsClient/Insert/main.go index 29b8a46d084c..dfaca5467229 100644 --- a/internal/generated/snippets/compute/apiv1/InterconnectsClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/InterconnectsClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InterconnectsClient/List/main.go b/internal/generated/snippets/compute/apiv1/InterconnectsClient/List/main.go index eabd8e2c2b7f..4e374d8109ba 100644 --- a/internal/generated/snippets/compute/apiv1/InterconnectsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/InterconnectsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InterconnectsClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/InterconnectsClient/Patch/main.go index 230fcb310200..10d9fa203550 100644 --- a/internal/generated/snippets/compute/apiv1/InterconnectsClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/InterconnectsClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/InterconnectsClient/SetLabels/main.go b/internal/generated/snippets/compute/apiv1/InterconnectsClient/SetLabels/main.go index 9050bf331d28..da9344c85053 100644 --- a/internal/generated/snippets/compute/apiv1/InterconnectsClient/SetLabels/main.go +++ b/internal/generated/snippets/compute/apiv1/InterconnectsClient/SetLabels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/LicenseCodesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/LicenseCodesClient/Get/main.go index a8107c129091..da096f7092a8 100644 --- a/internal/generated/snippets/compute/apiv1/LicenseCodesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/LicenseCodesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/LicenseCodesClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/LicenseCodesClient/TestIamPermissions/main.go index 455ba5e2b0c2..f9c9f41072bf 100644 --- a/internal/generated/snippets/compute/apiv1/LicenseCodesClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/LicenseCodesClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/LicensesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/LicensesClient/Delete/main.go index 65c6ed61eefc..2bc79e2203e1 100644 --- a/internal/generated/snippets/compute/apiv1/LicensesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/LicensesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/LicensesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/LicensesClient/Get/main.go index fb181ce4cc19..38f32afb1740 100644 --- a/internal/generated/snippets/compute/apiv1/LicensesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/LicensesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/LicensesClient/GetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/LicensesClient/GetIamPolicy/main.go index 26910229213a..7b80af9c8578 100644 --- a/internal/generated/snippets/compute/apiv1/LicensesClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/LicensesClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/LicensesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/LicensesClient/Insert/main.go index 0b0c79edafad..9bb3f67d501a 100644 --- a/internal/generated/snippets/compute/apiv1/LicensesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/LicensesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/LicensesClient/List/main.go b/internal/generated/snippets/compute/apiv1/LicensesClient/List/main.go index d84e594292c5..98eec27dc821 100644 --- a/internal/generated/snippets/compute/apiv1/LicensesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/LicensesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/LicensesClient/SetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/LicensesClient/SetIamPolicy/main.go index 8b19cce481d5..a785b8d178b2 100644 --- a/internal/generated/snippets/compute/apiv1/LicensesClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/LicensesClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/LicensesClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/LicensesClient/TestIamPermissions/main.go index 0523c30d4ca2..d1aadb92eff4 100644 --- a/internal/generated/snippets/compute/apiv1/LicensesClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/LicensesClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/MachineImagesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/MachineImagesClient/Delete/main.go index 9e3c4bf94b74..cedb60844f5c 100644 --- a/internal/generated/snippets/compute/apiv1/MachineImagesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/MachineImagesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/MachineImagesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/MachineImagesClient/Get/main.go index 22a765adc4a1..d18bb2e10585 100644 --- a/internal/generated/snippets/compute/apiv1/MachineImagesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/MachineImagesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/MachineImagesClient/GetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/MachineImagesClient/GetIamPolicy/main.go index 03d01b52d170..69f9d6479dfd 100644 --- a/internal/generated/snippets/compute/apiv1/MachineImagesClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/MachineImagesClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/MachineImagesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/MachineImagesClient/Insert/main.go index 1a05841a2b67..78ac14288b23 100644 --- a/internal/generated/snippets/compute/apiv1/MachineImagesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/MachineImagesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/MachineImagesClient/List/main.go b/internal/generated/snippets/compute/apiv1/MachineImagesClient/List/main.go index 06a1a1e1d2d8..ffa2189ed15d 100644 --- a/internal/generated/snippets/compute/apiv1/MachineImagesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/MachineImagesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/MachineImagesClient/SetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/MachineImagesClient/SetIamPolicy/main.go index f5dd0b4a3ef5..39a359e4748b 100644 --- a/internal/generated/snippets/compute/apiv1/MachineImagesClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/MachineImagesClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/MachineImagesClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/MachineImagesClient/TestIamPermissions/main.go index f0941a4ecf52..0d80aafe8706 100644 --- a/internal/generated/snippets/compute/apiv1/MachineImagesClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/MachineImagesClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/MachineTypesClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/MachineTypesClient/AggregatedList/main.go index b5f5440118c8..1b8875eff5f4 100644 --- a/internal/generated/snippets/compute/apiv1/MachineTypesClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/MachineTypesClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/MachineTypesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/MachineTypesClient/Get/main.go index 707ba1c897ac..0266633c55c7 100644 --- a/internal/generated/snippets/compute/apiv1/MachineTypesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/MachineTypesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/MachineTypesClient/List/main.go b/internal/generated/snippets/compute/apiv1/MachineTypesClient/List/main.go index 2d7ec55fd7a7..50f7ec3f1446 100644 --- a/internal/generated/snippets/compute/apiv1/MachineTypesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/MachineTypesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/AggregatedList/main.go index 07bcb029fe95..29cd3a4695a7 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/Delete/main.go index 02af578fdacd..bb7a065bf48e 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/Get/main.go index 27c6e44cfaf4..65d9d6a7edf8 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/GetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/GetIamPolicy/main.go index d7e0993de078..92c073d5963e 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/Insert/main.go index 7a9e09956047..bbc517b8e928 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/List/main.go b/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/List/main.go index bb67ee9a90f7..fa358cb298e4 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/Patch/main.go index 850d814ca150..ea1aacc597ef 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/SetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/SetIamPolicy/main.go index 5c89c4e9d6ca..37e9b85ae563 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/TestIamPermissions/main.go index 99e40704fa3b..aca457ab6401 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkAttachmentsClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkEdgeSecurityServicesClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/NetworkEdgeSecurityServicesClient/AggregatedList/main.go index 63b4fdaa4aca..db174f186471 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkEdgeSecurityServicesClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkEdgeSecurityServicesClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkEdgeSecurityServicesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/NetworkEdgeSecurityServicesClient/Delete/main.go index c59ec4ef8516..eefd9366513d 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkEdgeSecurityServicesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkEdgeSecurityServicesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkEdgeSecurityServicesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/NetworkEdgeSecurityServicesClient/Get/main.go index b7859b1c7e26..f291d18b63ab 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkEdgeSecurityServicesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkEdgeSecurityServicesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkEdgeSecurityServicesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/NetworkEdgeSecurityServicesClient/Insert/main.go index 93092447d70f..567110aadc75 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkEdgeSecurityServicesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkEdgeSecurityServicesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkEdgeSecurityServicesClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/NetworkEdgeSecurityServicesClient/Patch/main.go index 9e6eda6cc444..58cc72bf1e5a 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkEdgeSecurityServicesClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkEdgeSecurityServicesClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/AggregatedList/main.go index a0f4359ee9a1..06bb7815158b 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/AttachNetworkEndpoints/main.go b/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/AttachNetworkEndpoints/main.go index 90d4eb798189..7d9d7c62da9c 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/AttachNetworkEndpoints/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/AttachNetworkEndpoints/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/Delete/main.go index 6dc051f14198..ab63de331321 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/DetachNetworkEndpoints/main.go b/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/DetachNetworkEndpoints/main.go index bc0e23299fd5..a132a6533e1b 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/DetachNetworkEndpoints/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/DetachNetworkEndpoints/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/Get/main.go index edf90a6ba861..deb60d0d5ab7 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/Insert/main.go index 72f7c394fd64..4f2ef2bc7fe0 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/List/main.go b/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/List/main.go index c647a127cf1e..aa1481196220 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/ListNetworkEndpoints/main.go b/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/ListNetworkEndpoints/main.go index cc2976a8a7b6..f46b6b985f5c 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/ListNetworkEndpoints/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/ListNetworkEndpoints/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/TestIamPermissions/main.go index f74e9ea85f65..fd87d1c89a25 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkEndpointGroupsClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/AddAssociation/main.go b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/AddAssociation/main.go index 212e8e376482..784bc03ae255 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/AddAssociation/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/AddAssociation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/AddRule/main.go b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/AddRule/main.go index 83ff87c5382c..3b3ad5d89931 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/AddRule/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/AddRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/CloneRules/main.go b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/CloneRules/main.go index 6d6919dfe582..40bbf1815bac 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/CloneRules/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/CloneRules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/Delete/main.go index d37cb4b1bb11..9c8a13a3a0a8 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/Get/main.go index c92f4c2b36b6..b24306744244 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/GetAssociation/main.go b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/GetAssociation/main.go index e6361c14ff30..e403de1056a4 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/GetAssociation/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/GetAssociation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/GetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/GetIamPolicy/main.go index fe2d2d5ae334..905dc697a037 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/GetRule/main.go b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/GetRule/main.go index 5cd797fef786..874725a4749f 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/GetRule/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/GetRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/Insert/main.go index 9b0550b3f5ab..da854568e25d 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/List/main.go b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/List/main.go index ff51cc84ad16..87cacc93504d 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/Patch/main.go index fc9e1e89bd65..438ec31ea8f5 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/PatchRule/main.go b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/PatchRule/main.go index c84e1b1a9846..95416b42fd92 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/PatchRule/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/PatchRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/RemoveAssociation/main.go b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/RemoveAssociation/main.go index d59371c3e4d2..428ca8703d4a 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/RemoveAssociation/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/RemoveAssociation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/RemoveRule/main.go b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/RemoveRule/main.go index bbbf79a5af84..e5bdedaf9e64 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/RemoveRule/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/RemoveRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/SetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/SetIamPolicy/main.go index add0ad1e9cb4..abbccb3a2d2a 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/TestIamPermissions/main.go index 226ccdab00ef..69aa193a5e9e 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkFirewallPoliciesClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkProfilesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/NetworkProfilesClient/Get/main.go index 41acce1d6293..96b47b4105d1 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkProfilesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkProfilesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworkProfilesClient/List/main.go b/internal/generated/snippets/compute/apiv1/NetworkProfilesClient/List/main.go index 20d07b0fd120..668ba41a43b1 100644 --- a/internal/generated/snippets/compute/apiv1/NetworkProfilesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworkProfilesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworksClient/AddPeering/main.go b/internal/generated/snippets/compute/apiv1/NetworksClient/AddPeering/main.go index eb923c9eb432..d051d7fa033c 100644 --- a/internal/generated/snippets/compute/apiv1/NetworksClient/AddPeering/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworksClient/AddPeering/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworksClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/NetworksClient/Delete/main.go index 5f456aa0f00a..42086e4f1e69 100644 --- a/internal/generated/snippets/compute/apiv1/NetworksClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworksClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworksClient/Get/main.go b/internal/generated/snippets/compute/apiv1/NetworksClient/Get/main.go index 692cfe3fc3ed..c202c678f826 100644 --- a/internal/generated/snippets/compute/apiv1/NetworksClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworksClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworksClient/GetEffectiveFirewalls/main.go b/internal/generated/snippets/compute/apiv1/NetworksClient/GetEffectiveFirewalls/main.go index 0b6b1829749d..8b5d5fbc5ba7 100644 --- a/internal/generated/snippets/compute/apiv1/NetworksClient/GetEffectiveFirewalls/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworksClient/GetEffectiveFirewalls/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworksClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/NetworksClient/Insert/main.go index f8f5363b3ade..bbffd083e4e7 100644 --- a/internal/generated/snippets/compute/apiv1/NetworksClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworksClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworksClient/List/main.go b/internal/generated/snippets/compute/apiv1/NetworksClient/List/main.go index 220a3f0aa82d..b98133ade1bb 100644 --- a/internal/generated/snippets/compute/apiv1/NetworksClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworksClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworksClient/ListPeeringRoutes/main.go b/internal/generated/snippets/compute/apiv1/NetworksClient/ListPeeringRoutes/main.go index f6c2dd79367b..6857f382ca2c 100644 --- a/internal/generated/snippets/compute/apiv1/NetworksClient/ListPeeringRoutes/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworksClient/ListPeeringRoutes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworksClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/NetworksClient/Patch/main.go index f8391e41b392..1c41458e3f6d 100644 --- a/internal/generated/snippets/compute/apiv1/NetworksClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworksClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworksClient/RemovePeering/main.go b/internal/generated/snippets/compute/apiv1/NetworksClient/RemovePeering/main.go index 36b2ae641c36..1daa763be7f2 100644 --- a/internal/generated/snippets/compute/apiv1/NetworksClient/RemovePeering/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworksClient/RemovePeering/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworksClient/SwitchToCustomMode/main.go b/internal/generated/snippets/compute/apiv1/NetworksClient/SwitchToCustomMode/main.go index ac7ba2d1803e..8d0c8f721b8c 100644 --- a/internal/generated/snippets/compute/apiv1/NetworksClient/SwitchToCustomMode/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworksClient/SwitchToCustomMode/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NetworksClient/UpdatePeering/main.go b/internal/generated/snippets/compute/apiv1/NetworksClient/UpdatePeering/main.go index 567421db6ea0..2fa267b64ba2 100644 --- a/internal/generated/snippets/compute/apiv1/NetworksClient/UpdatePeering/main.go +++ b/internal/generated/snippets/compute/apiv1/NetworksClient/UpdatePeering/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/AddNodes/main.go b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/AddNodes/main.go index 6a47b0a74072..ff031606a6b7 100644 --- a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/AddNodes/main.go +++ b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/AddNodes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/AggregatedList/main.go index af5d7686b487..dcb35dccb428 100644 --- a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/Delete/main.go index dc04545c351b..b56e31013171 100644 --- a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/DeleteNodes/main.go b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/DeleteNodes/main.go index bca57130d7b9..989efed2b68f 100644 --- a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/DeleteNodes/main.go +++ b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/DeleteNodes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/Get/main.go index 3178b7d66131..a4cc18f686af 100644 --- a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/GetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/GetIamPolicy/main.go index 644d6a6fc9ad..654e90e75e2f 100644 --- a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/Insert/main.go index 153e764e0fef..e2b041ec8026 100644 --- a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/List/main.go b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/List/main.go index 6d4c0efd6043..4290c36d78a5 100644 --- a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/ListNodes/main.go b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/ListNodes/main.go index 35f4adfcac79..8261f8a7c4b6 100644 --- a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/ListNodes/main.go +++ b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/ListNodes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/Patch/main.go index 7762e7706d06..9dabb47e38ee 100644 --- a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/PerformMaintenance/main.go b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/PerformMaintenance/main.go index 28a094500fb6..53efa6413824 100644 --- a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/PerformMaintenance/main.go +++ b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/PerformMaintenance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/SetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/SetIamPolicy/main.go index 47908417be76..e4a7fb031cbd 100644 --- a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/SetNodeTemplate/main.go b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/SetNodeTemplate/main.go index ca79e2b864eb..7b2cc2880418 100644 --- a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/SetNodeTemplate/main.go +++ b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/SetNodeTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/SimulateMaintenanceEvent/main.go b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/SimulateMaintenanceEvent/main.go index 088f453f109c..73ed87c6cc6b 100644 --- a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/SimulateMaintenanceEvent/main.go +++ b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/SimulateMaintenanceEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/TestIamPermissions/main.go index 21d3d918606c..4f81d390c0db 100644 --- a/internal/generated/snippets/compute/apiv1/NodeGroupsClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/NodeGroupsClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/AggregatedList/main.go index fb8d155c6efe..58fc306824ba 100644 --- a/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/Delete/main.go index 31431e45739a..57d4c9132a91 100644 --- a/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/Get/main.go index 740524886227..ddd7ade4e01e 100644 --- a/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/GetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/GetIamPolicy/main.go index 96e16484e263..4abc8c0074fe 100644 --- a/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/Insert/main.go index 521769685874..952332ce719b 100644 --- a/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/List/main.go b/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/List/main.go index 356ba1dcdb8c..abd67dd47333 100644 --- a/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/SetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/SetIamPolicy/main.go index f7b6f6106f2c..8a83cba64531 100644 --- a/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/TestIamPermissions/main.go index 4c5dd29051d8..a3139362184a 100644 --- a/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/NodeTemplatesClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NodeTypesClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/NodeTypesClient/AggregatedList/main.go index f20cd13c9148..4d6634ec24e4 100644 --- a/internal/generated/snippets/compute/apiv1/NodeTypesClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/NodeTypesClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NodeTypesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/NodeTypesClient/Get/main.go index 9f33db03f823..44b1c605a701 100644 --- a/internal/generated/snippets/compute/apiv1/NodeTypesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/NodeTypesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/NodeTypesClient/List/main.go b/internal/generated/snippets/compute/apiv1/NodeTypesClient/List/main.go index 198df8f3db73..2966a981773f 100644 --- a/internal/generated/snippets/compute/apiv1/NodeTypesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/NodeTypesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/PacketMirroringsClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/PacketMirroringsClient/AggregatedList/main.go index 2af7b9fa1d7c..d0d6e517caf2 100644 --- a/internal/generated/snippets/compute/apiv1/PacketMirroringsClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/PacketMirroringsClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/PacketMirroringsClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/PacketMirroringsClient/Delete/main.go index 1a21048ba3ef..2f012d1db0af 100644 --- a/internal/generated/snippets/compute/apiv1/PacketMirroringsClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/PacketMirroringsClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/PacketMirroringsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/PacketMirroringsClient/Get/main.go index 4f2b4f0ddb1c..b784be40ce14 100644 --- a/internal/generated/snippets/compute/apiv1/PacketMirroringsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/PacketMirroringsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/PacketMirroringsClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/PacketMirroringsClient/Insert/main.go index e8c32e74052a..61da65315d78 100644 --- a/internal/generated/snippets/compute/apiv1/PacketMirroringsClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/PacketMirroringsClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/PacketMirroringsClient/List/main.go b/internal/generated/snippets/compute/apiv1/PacketMirroringsClient/List/main.go index b7720c714cd4..f015213c77b7 100644 --- a/internal/generated/snippets/compute/apiv1/PacketMirroringsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/PacketMirroringsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/PacketMirroringsClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/PacketMirroringsClient/Patch/main.go index 556de9f327e8..a84c708285cb 100644 --- a/internal/generated/snippets/compute/apiv1/PacketMirroringsClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/PacketMirroringsClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/PacketMirroringsClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/PacketMirroringsClient/TestIamPermissions/main.go index 1c7b907315bd..37a5499e2262 100644 --- a/internal/generated/snippets/compute/apiv1/PacketMirroringsClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/PacketMirroringsClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ProjectsClient/DisableXpnHost/main.go b/internal/generated/snippets/compute/apiv1/ProjectsClient/DisableXpnHost/main.go index 61e57da9d035..71baa97939b7 100644 --- a/internal/generated/snippets/compute/apiv1/ProjectsClient/DisableXpnHost/main.go +++ b/internal/generated/snippets/compute/apiv1/ProjectsClient/DisableXpnHost/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ProjectsClient/DisableXpnResource/main.go b/internal/generated/snippets/compute/apiv1/ProjectsClient/DisableXpnResource/main.go index 9a77c9a18b69..04dc122069ac 100644 --- a/internal/generated/snippets/compute/apiv1/ProjectsClient/DisableXpnResource/main.go +++ b/internal/generated/snippets/compute/apiv1/ProjectsClient/DisableXpnResource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ProjectsClient/EnableXpnHost/main.go b/internal/generated/snippets/compute/apiv1/ProjectsClient/EnableXpnHost/main.go index 81783922a608..cbf5c3767fdd 100644 --- a/internal/generated/snippets/compute/apiv1/ProjectsClient/EnableXpnHost/main.go +++ b/internal/generated/snippets/compute/apiv1/ProjectsClient/EnableXpnHost/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ProjectsClient/EnableXpnResource/main.go b/internal/generated/snippets/compute/apiv1/ProjectsClient/EnableXpnResource/main.go index f7a56c18d467..4083e568ca7e 100644 --- a/internal/generated/snippets/compute/apiv1/ProjectsClient/EnableXpnResource/main.go +++ b/internal/generated/snippets/compute/apiv1/ProjectsClient/EnableXpnResource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ProjectsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/ProjectsClient/Get/main.go index 850bf8d1a6cb..125eac2ce583 100644 --- a/internal/generated/snippets/compute/apiv1/ProjectsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/ProjectsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ProjectsClient/GetXpnHost/main.go b/internal/generated/snippets/compute/apiv1/ProjectsClient/GetXpnHost/main.go index 1d72e5df65e7..187d67f1f774 100644 --- a/internal/generated/snippets/compute/apiv1/ProjectsClient/GetXpnHost/main.go +++ b/internal/generated/snippets/compute/apiv1/ProjectsClient/GetXpnHost/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ProjectsClient/GetXpnResources/main.go b/internal/generated/snippets/compute/apiv1/ProjectsClient/GetXpnResources/main.go index 21bf1d0dcf8d..fab887ceac7d 100644 --- a/internal/generated/snippets/compute/apiv1/ProjectsClient/GetXpnResources/main.go +++ b/internal/generated/snippets/compute/apiv1/ProjectsClient/GetXpnResources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ProjectsClient/ListXpnHosts/main.go b/internal/generated/snippets/compute/apiv1/ProjectsClient/ListXpnHosts/main.go index b89141062563..2a02b8343c0d 100644 --- a/internal/generated/snippets/compute/apiv1/ProjectsClient/ListXpnHosts/main.go +++ b/internal/generated/snippets/compute/apiv1/ProjectsClient/ListXpnHosts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ProjectsClient/MoveDisk/main.go b/internal/generated/snippets/compute/apiv1/ProjectsClient/MoveDisk/main.go index a93f20f46064..0a8221b9f66c 100644 --- a/internal/generated/snippets/compute/apiv1/ProjectsClient/MoveDisk/main.go +++ b/internal/generated/snippets/compute/apiv1/ProjectsClient/MoveDisk/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ProjectsClient/MoveInstance/main.go b/internal/generated/snippets/compute/apiv1/ProjectsClient/MoveInstance/main.go index 21e152f395f3..a83d196f887a 100644 --- a/internal/generated/snippets/compute/apiv1/ProjectsClient/MoveInstance/main.go +++ b/internal/generated/snippets/compute/apiv1/ProjectsClient/MoveInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ProjectsClient/SetCloudArmorTier/main.go b/internal/generated/snippets/compute/apiv1/ProjectsClient/SetCloudArmorTier/main.go index 2adfdab1801b..527e3712d526 100644 --- a/internal/generated/snippets/compute/apiv1/ProjectsClient/SetCloudArmorTier/main.go +++ b/internal/generated/snippets/compute/apiv1/ProjectsClient/SetCloudArmorTier/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ProjectsClient/SetCommonInstanceMetadata/main.go b/internal/generated/snippets/compute/apiv1/ProjectsClient/SetCommonInstanceMetadata/main.go index 93576ef437a9..2f8c2b216716 100644 --- a/internal/generated/snippets/compute/apiv1/ProjectsClient/SetCommonInstanceMetadata/main.go +++ b/internal/generated/snippets/compute/apiv1/ProjectsClient/SetCommonInstanceMetadata/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ProjectsClient/SetDefaultNetworkTier/main.go b/internal/generated/snippets/compute/apiv1/ProjectsClient/SetDefaultNetworkTier/main.go index 9b004db58b01..b63bf8c0b43d 100644 --- a/internal/generated/snippets/compute/apiv1/ProjectsClient/SetDefaultNetworkTier/main.go +++ b/internal/generated/snippets/compute/apiv1/ProjectsClient/SetDefaultNetworkTier/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ProjectsClient/SetUsageExportBucket/main.go b/internal/generated/snippets/compute/apiv1/ProjectsClient/SetUsageExportBucket/main.go index dbe8e229856f..d4cd08b03f15 100644 --- a/internal/generated/snippets/compute/apiv1/ProjectsClient/SetUsageExportBucket/main.go +++ b/internal/generated/snippets/compute/apiv1/ProjectsClient/SetUsageExportBucket/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/PublicAdvertisedPrefixesClient/Announce/main.go b/internal/generated/snippets/compute/apiv1/PublicAdvertisedPrefixesClient/Announce/main.go index b8c45481c40d..7afecdb55a26 100644 --- a/internal/generated/snippets/compute/apiv1/PublicAdvertisedPrefixesClient/Announce/main.go +++ b/internal/generated/snippets/compute/apiv1/PublicAdvertisedPrefixesClient/Announce/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/PublicAdvertisedPrefixesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/PublicAdvertisedPrefixesClient/Delete/main.go index 49636a233925..21abc8784d1e 100644 --- a/internal/generated/snippets/compute/apiv1/PublicAdvertisedPrefixesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/PublicAdvertisedPrefixesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/PublicAdvertisedPrefixesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/PublicAdvertisedPrefixesClient/Get/main.go index 2fff17d5a4d6..97f1869434c6 100644 --- a/internal/generated/snippets/compute/apiv1/PublicAdvertisedPrefixesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/PublicAdvertisedPrefixesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/PublicAdvertisedPrefixesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/PublicAdvertisedPrefixesClient/Insert/main.go index 01b5cd28f6e3..22f7bfd2b6ad 100644 --- a/internal/generated/snippets/compute/apiv1/PublicAdvertisedPrefixesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/PublicAdvertisedPrefixesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/PublicAdvertisedPrefixesClient/List/main.go b/internal/generated/snippets/compute/apiv1/PublicAdvertisedPrefixesClient/List/main.go index 7b419123c4e7..9b9da14a1bf5 100644 --- a/internal/generated/snippets/compute/apiv1/PublicAdvertisedPrefixesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/PublicAdvertisedPrefixesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/PublicAdvertisedPrefixesClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/PublicAdvertisedPrefixesClient/Patch/main.go index 5fca86449394..2adec11081a9 100644 --- a/internal/generated/snippets/compute/apiv1/PublicAdvertisedPrefixesClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/PublicAdvertisedPrefixesClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/PublicAdvertisedPrefixesClient/Withdraw/main.go b/internal/generated/snippets/compute/apiv1/PublicAdvertisedPrefixesClient/Withdraw/main.go index 4dead0dd6014..f42c8bf64b33 100644 --- a/internal/generated/snippets/compute/apiv1/PublicAdvertisedPrefixesClient/Withdraw/main.go +++ b/internal/generated/snippets/compute/apiv1/PublicAdvertisedPrefixesClient/Withdraw/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/AggregatedList/main.go index 110a7b8e42f2..a1ab73a851af 100644 --- a/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/Announce/main.go b/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/Announce/main.go index 2dbbe5b33d98..8551d5cecb80 100644 --- a/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/Announce/main.go +++ b/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/Announce/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/Delete/main.go index 86593c162a04..53beface2be5 100644 --- a/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/Get/main.go index 43243bd305b5..cb37f9c1b5d1 100644 --- a/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/Insert/main.go index c2efc0ffbaef..585b7eefa09e 100644 --- a/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/List/main.go b/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/List/main.go index 6ded3b51acfc..f902d1cc1d7d 100644 --- a/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/Patch/main.go index 84d724bda4dd..ef5de23afa13 100644 --- a/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/Withdraw/main.go b/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/Withdraw/main.go index 4e5c9043575a..1a7656bd107e 100644 --- a/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/Withdraw/main.go +++ b/internal/generated/snippets/compute/apiv1/PublicDelegatedPrefixesClient/Withdraw/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionAutoscalersClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/RegionAutoscalersClient/Delete/main.go index 5c8df012c770..7baac39a927a 100644 --- a/internal/generated/snippets/compute/apiv1/RegionAutoscalersClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionAutoscalersClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionAutoscalersClient/Get/main.go b/internal/generated/snippets/compute/apiv1/RegionAutoscalersClient/Get/main.go index 4b8009a2939b..5781a1b718d4 100644 --- a/internal/generated/snippets/compute/apiv1/RegionAutoscalersClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionAutoscalersClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionAutoscalersClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/RegionAutoscalersClient/Insert/main.go index 704403eb84b4..be74e72de1f5 100644 --- a/internal/generated/snippets/compute/apiv1/RegionAutoscalersClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionAutoscalersClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionAutoscalersClient/List/main.go b/internal/generated/snippets/compute/apiv1/RegionAutoscalersClient/List/main.go index 38e69dea44b3..c87dc309b970 100644 --- a/internal/generated/snippets/compute/apiv1/RegionAutoscalersClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionAutoscalersClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionAutoscalersClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/RegionAutoscalersClient/Patch/main.go index 2f2d7b90a101..5617c0061ba2 100644 --- a/internal/generated/snippets/compute/apiv1/RegionAutoscalersClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionAutoscalersClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionAutoscalersClient/Update/main.go b/internal/generated/snippets/compute/apiv1/RegionAutoscalersClient/Update/main.go index aba978658a6d..2b75b25ccac3 100644 --- a/internal/generated/snippets/compute/apiv1/RegionAutoscalersClient/Update/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionAutoscalersClient/Update/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/Delete/main.go index a90efa3fe6de..9507b2f9340f 100644 --- a/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/Get/main.go index c6df65d25614..ddf1438b5158 100644 --- a/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/GetHealth/main.go b/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/GetHealth/main.go index e58f6fa95a77..1e9d78f14e1d 100644 --- a/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/GetHealth/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/GetHealth/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/GetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/GetIamPolicy/main.go index 3e43afb67d9e..0a65dd4cb15f 100644 --- a/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/Insert/main.go index 4b477fe9570f..c03a5c03b6a8 100644 --- a/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/List/main.go b/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/List/main.go index 2b1b226e9ca6..1a4514348e68 100644 --- a/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/ListUsable/main.go b/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/ListUsable/main.go index 487b2d554a8b..37baaca90083 100644 --- a/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/ListUsable/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/ListUsable/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/Patch/main.go index 8081300dc89b..2c5e3ed3d080 100644 --- a/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/SetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/SetIamPolicy/main.go index c40f106230ce..54f9d028a9f9 100644 --- a/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/SetSecurityPolicy/main.go b/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/SetSecurityPolicy/main.go index 36f887ded645..f2877b50e164 100644 --- a/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/SetSecurityPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/SetSecurityPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/TestIamPermissions/main.go index f5538379daaa..ced0893019d6 100644 --- a/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/Update/main.go b/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/Update/main.go index 1b8c939eb154..59b4b51e063a 100644 --- a/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/Update/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionBackendServicesClient/Update/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionCommitmentsClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/RegionCommitmentsClient/AggregatedList/main.go index 6bc57e3f55d7..06603e305290 100644 --- a/internal/generated/snippets/compute/apiv1/RegionCommitmentsClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionCommitmentsClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionCommitmentsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/RegionCommitmentsClient/Get/main.go index a47423e6c2a6..ec6918b62f76 100644 --- a/internal/generated/snippets/compute/apiv1/RegionCommitmentsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionCommitmentsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionCommitmentsClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/RegionCommitmentsClient/Insert/main.go index bdf3f323328d..98e5ecf329f9 100644 --- a/internal/generated/snippets/compute/apiv1/RegionCommitmentsClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionCommitmentsClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionCommitmentsClient/List/main.go b/internal/generated/snippets/compute/apiv1/RegionCommitmentsClient/List/main.go index 0868aca25793..6f029f112ac9 100644 --- a/internal/generated/snippets/compute/apiv1/RegionCommitmentsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionCommitmentsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionCommitmentsClient/Update/main.go b/internal/generated/snippets/compute/apiv1/RegionCommitmentsClient/Update/main.go index 6c366a061878..489d77ff539a 100644 --- a/internal/generated/snippets/compute/apiv1/RegionCommitmentsClient/Update/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionCommitmentsClient/Update/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionDiskTypesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/RegionDiskTypesClient/Get/main.go index 950768309ad5..c7d67a4c1819 100644 --- a/internal/generated/snippets/compute/apiv1/RegionDiskTypesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionDiskTypesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionDiskTypesClient/List/main.go b/internal/generated/snippets/compute/apiv1/RegionDiskTypesClient/List/main.go index 0a807fa947be..927013550970 100644 --- a/internal/generated/snippets/compute/apiv1/RegionDiskTypesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionDiskTypesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionDisksClient/AddResourcePolicies/main.go b/internal/generated/snippets/compute/apiv1/RegionDisksClient/AddResourcePolicies/main.go index 1d3be830b420..664b4671a29e 100644 --- a/internal/generated/snippets/compute/apiv1/RegionDisksClient/AddResourcePolicies/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionDisksClient/AddResourcePolicies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionDisksClient/BulkInsert/main.go b/internal/generated/snippets/compute/apiv1/RegionDisksClient/BulkInsert/main.go index d17f0e8eebe7..8fb6784a66f6 100644 --- a/internal/generated/snippets/compute/apiv1/RegionDisksClient/BulkInsert/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionDisksClient/BulkInsert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionDisksClient/CreateSnapshot/main.go b/internal/generated/snippets/compute/apiv1/RegionDisksClient/CreateSnapshot/main.go index 68281e31203d..778df0d3f274 100644 --- a/internal/generated/snippets/compute/apiv1/RegionDisksClient/CreateSnapshot/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionDisksClient/CreateSnapshot/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionDisksClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/RegionDisksClient/Delete/main.go index 7f8c801308bb..043b57292a14 100644 --- a/internal/generated/snippets/compute/apiv1/RegionDisksClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionDisksClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionDisksClient/Get/main.go b/internal/generated/snippets/compute/apiv1/RegionDisksClient/Get/main.go index d48b4680c165..2a8001f48505 100644 --- a/internal/generated/snippets/compute/apiv1/RegionDisksClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionDisksClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionDisksClient/GetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/RegionDisksClient/GetIamPolicy/main.go index d3d1ba289c23..ce267ebe5c62 100644 --- a/internal/generated/snippets/compute/apiv1/RegionDisksClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionDisksClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionDisksClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/RegionDisksClient/Insert/main.go index 6baff615e406..4f1814a51dce 100644 --- a/internal/generated/snippets/compute/apiv1/RegionDisksClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionDisksClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionDisksClient/List/main.go b/internal/generated/snippets/compute/apiv1/RegionDisksClient/List/main.go index cdc87737c9b1..8843ef1ed724 100644 --- a/internal/generated/snippets/compute/apiv1/RegionDisksClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionDisksClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionDisksClient/RemoveResourcePolicies/main.go b/internal/generated/snippets/compute/apiv1/RegionDisksClient/RemoveResourcePolicies/main.go index bb90826205d0..215e5341ca34 100644 --- a/internal/generated/snippets/compute/apiv1/RegionDisksClient/RemoveResourcePolicies/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionDisksClient/RemoveResourcePolicies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionDisksClient/Resize/main.go b/internal/generated/snippets/compute/apiv1/RegionDisksClient/Resize/main.go index 9cfcdf71f5f6..cf6fba273aab 100644 --- a/internal/generated/snippets/compute/apiv1/RegionDisksClient/Resize/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionDisksClient/Resize/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionDisksClient/SetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/RegionDisksClient/SetIamPolicy/main.go index a942fc4c647f..b546664d3411 100644 --- a/internal/generated/snippets/compute/apiv1/RegionDisksClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionDisksClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionDisksClient/SetLabels/main.go b/internal/generated/snippets/compute/apiv1/RegionDisksClient/SetLabels/main.go index 2c08e412d411..58f43915fb7b 100644 --- a/internal/generated/snippets/compute/apiv1/RegionDisksClient/SetLabels/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionDisksClient/SetLabels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionDisksClient/StartAsyncReplication/main.go b/internal/generated/snippets/compute/apiv1/RegionDisksClient/StartAsyncReplication/main.go index 852cae2c44b3..7b9add2596d6 100644 --- a/internal/generated/snippets/compute/apiv1/RegionDisksClient/StartAsyncReplication/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionDisksClient/StartAsyncReplication/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionDisksClient/StopAsyncReplication/main.go b/internal/generated/snippets/compute/apiv1/RegionDisksClient/StopAsyncReplication/main.go index dfe709121871..ef7726827b03 100644 --- a/internal/generated/snippets/compute/apiv1/RegionDisksClient/StopAsyncReplication/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionDisksClient/StopAsyncReplication/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionDisksClient/StopGroupAsyncReplication/main.go b/internal/generated/snippets/compute/apiv1/RegionDisksClient/StopGroupAsyncReplication/main.go index 16d7242d3a99..318b73a87a6c 100644 --- a/internal/generated/snippets/compute/apiv1/RegionDisksClient/StopGroupAsyncReplication/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionDisksClient/StopGroupAsyncReplication/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionDisksClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/RegionDisksClient/TestIamPermissions/main.go index fb533f61da89..5c551e788476 100644 --- a/internal/generated/snippets/compute/apiv1/RegionDisksClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionDisksClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionDisksClient/Update/main.go b/internal/generated/snippets/compute/apiv1/RegionDisksClient/Update/main.go index 0989332d8a9a..558136b893dc 100644 --- a/internal/generated/snippets/compute/apiv1/RegionDisksClient/Update/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionDisksClient/Update/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionHealthCheckServicesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/RegionHealthCheckServicesClient/Delete/main.go index 9d836136c42c..707eafa2cb63 100644 --- a/internal/generated/snippets/compute/apiv1/RegionHealthCheckServicesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionHealthCheckServicesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionHealthCheckServicesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/RegionHealthCheckServicesClient/Get/main.go index 106dc93b954a..195894c87a2a 100644 --- a/internal/generated/snippets/compute/apiv1/RegionHealthCheckServicesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionHealthCheckServicesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionHealthCheckServicesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/RegionHealthCheckServicesClient/Insert/main.go index bb34731b6828..9b9a426c6f93 100644 --- a/internal/generated/snippets/compute/apiv1/RegionHealthCheckServicesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionHealthCheckServicesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionHealthCheckServicesClient/List/main.go b/internal/generated/snippets/compute/apiv1/RegionHealthCheckServicesClient/List/main.go index 238addece78c..baa551f9cbe6 100644 --- a/internal/generated/snippets/compute/apiv1/RegionHealthCheckServicesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionHealthCheckServicesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionHealthCheckServicesClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/RegionHealthCheckServicesClient/Patch/main.go index 6012ebfc6f0f..05071d06ec23 100644 --- a/internal/generated/snippets/compute/apiv1/RegionHealthCheckServicesClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionHealthCheckServicesClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionHealthChecksClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/RegionHealthChecksClient/Delete/main.go index 2bf371ff129a..cda7fc97b39c 100644 --- a/internal/generated/snippets/compute/apiv1/RegionHealthChecksClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionHealthChecksClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionHealthChecksClient/Get/main.go b/internal/generated/snippets/compute/apiv1/RegionHealthChecksClient/Get/main.go index 3d31b2754675..76db4eb9fbee 100644 --- a/internal/generated/snippets/compute/apiv1/RegionHealthChecksClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionHealthChecksClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionHealthChecksClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/RegionHealthChecksClient/Insert/main.go index 1398b6470b0e..da3469bbf0ed 100644 --- a/internal/generated/snippets/compute/apiv1/RegionHealthChecksClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionHealthChecksClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionHealthChecksClient/List/main.go b/internal/generated/snippets/compute/apiv1/RegionHealthChecksClient/List/main.go index 7e008b803199..da7c2312b049 100644 --- a/internal/generated/snippets/compute/apiv1/RegionHealthChecksClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionHealthChecksClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionHealthChecksClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/RegionHealthChecksClient/Patch/main.go index 3f903eee0fa5..adae2db65400 100644 --- a/internal/generated/snippets/compute/apiv1/RegionHealthChecksClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionHealthChecksClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionHealthChecksClient/Update/main.go b/internal/generated/snippets/compute/apiv1/RegionHealthChecksClient/Update/main.go index 120610acf39a..5be1ac6962e4 100644 --- a/internal/generated/snippets/compute/apiv1/RegionHealthChecksClient/Update/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionHealthChecksClient/Update/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/AbandonInstances/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/AbandonInstances/main.go index b95531e8d793..9016d338c0bc 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/AbandonInstances/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/AbandonInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/ApplyUpdatesToInstances/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/ApplyUpdatesToInstances/main.go index c1d543d360b4..fe482f8e2098 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/ApplyUpdatesToInstances/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/ApplyUpdatesToInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/CreateInstances/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/CreateInstances/main.go index c84adfd9d386..101ba4e8a60d 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/CreateInstances/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/CreateInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/Delete/main.go index 5dc927c186b0..6693ca4c8625 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/DeleteInstances/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/DeleteInstances/main.go index afacbf95a0cd..cc8ef741796a 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/DeleteInstances/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/DeleteInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/DeletePerInstanceConfigs/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/DeletePerInstanceConfigs/main.go index 47f56d343803..eb30213a655f 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/DeletePerInstanceConfigs/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/DeletePerInstanceConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/Get/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/Get/main.go index 7237485d4a48..dc2bc9021b48 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/Insert/main.go index a07cc49fab1c..dbe458d5aa6f 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/List/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/List/main.go index 47f43ba4ab39..80fe4452bbe9 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/ListErrors/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/ListErrors/main.go index e14a401d40fb..b3b8603ef105 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/ListErrors/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/ListErrors/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/ListManagedInstances/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/ListManagedInstances/main.go index cfb34a5c5888..392eaf073d3a 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/ListManagedInstances/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/ListManagedInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/ListPerInstanceConfigs/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/ListPerInstanceConfigs/main.go index 70f2e9fb38eb..72990b00a675 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/ListPerInstanceConfigs/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/ListPerInstanceConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/Patch/main.go index e4f149946f32..dc3fa3a211e3 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/PatchPerInstanceConfigs/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/PatchPerInstanceConfigs/main.go index 944c8ff2a985..5eb208a51926 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/PatchPerInstanceConfigs/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/PatchPerInstanceConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/RecreateInstances/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/RecreateInstances/main.go index 3256d720ece7..afd9f7366e52 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/RecreateInstances/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/RecreateInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/Resize/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/Resize/main.go index 0f405d2e5ba1..256f5c367546 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/Resize/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/Resize/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/ResumeInstances/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/ResumeInstances/main.go index c8a6380d6923..d020d3723181 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/ResumeInstances/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/ResumeInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/SetInstanceTemplate/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/SetInstanceTemplate/main.go index ca60761eb8a8..e45d92eadc96 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/SetInstanceTemplate/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/SetInstanceTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/SetTargetPools/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/SetTargetPools/main.go index 70408f945d53..9afb38545086 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/SetTargetPools/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/SetTargetPools/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/StartInstances/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/StartInstances/main.go index 843eaa3b96f7..133c54428b60 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/StartInstances/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/StartInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/StopInstances/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/StopInstances/main.go index 554e33473fc8..dd65cf8c8fb9 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/StopInstances/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/StopInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/SuspendInstances/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/SuspendInstances/main.go index 74477a2b3d7b..0b718d3bfcef 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/SuspendInstances/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/SuspendInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/UpdatePerInstanceConfigs/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/UpdatePerInstanceConfigs/main.go index a990557ffcba..287a53bd0d2b 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/UpdatePerInstanceConfigs/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupManagersClient/UpdatePerInstanceConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupsClient/Get/main.go index d82a4921c2ae..457ca0fb3704 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupsClient/List/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupsClient/List/main.go index ca1bd2201b59..c47f82d3f732 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupsClient/ListInstances/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupsClient/ListInstances/main.go index feda5356bdb3..5b90c4f8f5f3 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupsClient/ListInstances/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupsClient/ListInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupsClient/SetNamedPorts/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupsClient/SetNamedPorts/main.go index 291d0482d2e5..c468478e6b97 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceGroupsClient/SetNamedPorts/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceGroupsClient/SetNamedPorts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceTemplatesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceTemplatesClient/Delete/main.go index 025ced38fbd9..11ad6eced63e 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceTemplatesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceTemplatesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceTemplatesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceTemplatesClient/Get/main.go index 56726d0f35c9..3c61de88afce 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceTemplatesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceTemplatesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceTemplatesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceTemplatesClient/Insert/main.go index 18016f706f72..49e38cf75a02 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceTemplatesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceTemplatesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstanceTemplatesClient/List/main.go b/internal/generated/snippets/compute/apiv1/RegionInstanceTemplatesClient/List/main.go index c35d7b13643e..855465002bd4 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstanceTemplatesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstanceTemplatesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstancesClient/BulkInsert/main.go b/internal/generated/snippets/compute/apiv1/RegionInstancesClient/BulkInsert/main.go index 74d2f0fed147..6cde6890d879 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstancesClient/BulkInsert/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstancesClient/BulkInsert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/Delete/main.go index 10f34f480afa..365ae959887c 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/Get/main.go index 61b1213bf49d..dc6f078db052 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/GetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/GetIamPolicy/main.go index 40e27b106533..d34165416522 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/Insert/main.go index c54f7892edec..ca215c452557 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/List/main.go b/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/List/main.go index 246b14581a59..7ac0891cea16 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/SetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/SetIamPolicy/main.go index 5fc66f029729..a4fc8da7b6bb 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/SetLabels/main.go b/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/SetLabels/main.go index 8b10bf784ea9..21597e76e48e 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/SetLabels/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/SetLabels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/TestIamPermissions/main.go index 6947a6b0aa5e..13e30f203b02 100644 --- a/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionInstantSnapshotsClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionNetworkEndpointGroupsClient/AttachNetworkEndpoints/main.go b/internal/generated/snippets/compute/apiv1/RegionNetworkEndpointGroupsClient/AttachNetworkEndpoints/main.go index 84eae063700d..4cddcffc0778 100644 --- a/internal/generated/snippets/compute/apiv1/RegionNetworkEndpointGroupsClient/AttachNetworkEndpoints/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionNetworkEndpointGroupsClient/AttachNetworkEndpoints/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionNetworkEndpointGroupsClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/RegionNetworkEndpointGroupsClient/Delete/main.go index 8e0813551d8d..254ce32728c9 100644 --- a/internal/generated/snippets/compute/apiv1/RegionNetworkEndpointGroupsClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionNetworkEndpointGroupsClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionNetworkEndpointGroupsClient/DetachNetworkEndpoints/main.go b/internal/generated/snippets/compute/apiv1/RegionNetworkEndpointGroupsClient/DetachNetworkEndpoints/main.go index 0314f5f9f741..87ea1b0d2ebc 100644 --- a/internal/generated/snippets/compute/apiv1/RegionNetworkEndpointGroupsClient/DetachNetworkEndpoints/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionNetworkEndpointGroupsClient/DetachNetworkEndpoints/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionNetworkEndpointGroupsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/RegionNetworkEndpointGroupsClient/Get/main.go index 19fb6aaa8cbc..5369f5b296c2 100644 --- a/internal/generated/snippets/compute/apiv1/RegionNetworkEndpointGroupsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionNetworkEndpointGroupsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionNetworkEndpointGroupsClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/RegionNetworkEndpointGroupsClient/Insert/main.go index e8bd46fa3922..2123b50cfb6b 100644 --- a/internal/generated/snippets/compute/apiv1/RegionNetworkEndpointGroupsClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionNetworkEndpointGroupsClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionNetworkEndpointGroupsClient/List/main.go b/internal/generated/snippets/compute/apiv1/RegionNetworkEndpointGroupsClient/List/main.go index 3aefad6a1f9e..3c2a97098ea5 100644 --- a/internal/generated/snippets/compute/apiv1/RegionNetworkEndpointGroupsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionNetworkEndpointGroupsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionNetworkEndpointGroupsClient/ListNetworkEndpoints/main.go b/internal/generated/snippets/compute/apiv1/RegionNetworkEndpointGroupsClient/ListNetworkEndpoints/main.go index cdc9a5e76faa..8ca0f110d6a5 100644 --- a/internal/generated/snippets/compute/apiv1/RegionNetworkEndpointGroupsClient/ListNetworkEndpoints/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionNetworkEndpointGroupsClient/ListNetworkEndpoints/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/AddAssociation/main.go b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/AddAssociation/main.go index 2aa7c6766827..d7a61e8d00a6 100644 --- a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/AddAssociation/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/AddAssociation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/AddRule/main.go b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/AddRule/main.go index a570bf65e2c6..f41b5b1d0c57 100644 --- a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/AddRule/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/AddRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/CloneRules/main.go b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/CloneRules/main.go index ae8f43b94fae..4c5e13418f6a 100644 --- a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/CloneRules/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/CloneRules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/Delete/main.go index 750f86f30721..a80a00f72d84 100644 --- a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/Get/main.go index e476f48504de..04c532cef6a3 100644 --- a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/GetAssociation/main.go b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/GetAssociation/main.go index 2a338f3704db..2bf380a292ed 100644 --- a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/GetAssociation/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/GetAssociation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/GetEffectiveFirewalls/main.go b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/GetEffectiveFirewalls/main.go index 8ab8468aa901..3171cdec5dc1 100644 --- a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/GetEffectiveFirewalls/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/GetEffectiveFirewalls/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/GetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/GetIamPolicy/main.go index 3aa6ff955836..685518dae20a 100644 --- a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/GetRule/main.go b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/GetRule/main.go index 9e4e946eb6ab..850a69ef3895 100644 --- a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/GetRule/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/GetRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/Insert/main.go index e8498573b997..19f94e71e62b 100644 --- a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/List/main.go b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/List/main.go index 98031cf8e466..b6cabd2f069f 100644 --- a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/Patch/main.go index a6aa093d8c17..774d0269dca1 100644 --- a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/PatchRule/main.go b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/PatchRule/main.go index 73aa9d42ba57..f8908d66f2a4 100644 --- a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/PatchRule/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/PatchRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/RemoveAssociation/main.go b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/RemoveAssociation/main.go index 39c2b94eaf5a..d0e7f39cce91 100644 --- a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/RemoveAssociation/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/RemoveAssociation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/RemoveRule/main.go b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/RemoveRule/main.go index 97edaa0bc07d..5b04406ce90b 100644 --- a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/RemoveRule/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/RemoveRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/SetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/SetIamPolicy/main.go index f5b104003408..e0b06c109faf 100644 --- a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/TestIamPermissions/main.go index 60d5d6bc7623..b48e21c53ed6 100644 --- a/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionNetworkFirewallPoliciesClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionNotificationEndpointsClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/RegionNotificationEndpointsClient/Delete/main.go index 7d5010dcac31..06443f08ad72 100644 --- a/internal/generated/snippets/compute/apiv1/RegionNotificationEndpointsClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionNotificationEndpointsClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionNotificationEndpointsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/RegionNotificationEndpointsClient/Get/main.go index a744f3d3ab5c..cbdc677ad5c2 100644 --- a/internal/generated/snippets/compute/apiv1/RegionNotificationEndpointsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionNotificationEndpointsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionNotificationEndpointsClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/RegionNotificationEndpointsClient/Insert/main.go index 87f702562b80..830bb1c2e221 100644 --- a/internal/generated/snippets/compute/apiv1/RegionNotificationEndpointsClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionNotificationEndpointsClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionNotificationEndpointsClient/List/main.go b/internal/generated/snippets/compute/apiv1/RegionNotificationEndpointsClient/List/main.go index fc321a0c86b4..3060a7ccfc6a 100644 --- a/internal/generated/snippets/compute/apiv1/RegionNotificationEndpointsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionNotificationEndpointsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionOperationsClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/RegionOperationsClient/Delete/main.go index 056f0f2539ad..9839aee4b9f0 100644 --- a/internal/generated/snippets/compute/apiv1/RegionOperationsClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionOperationsClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionOperationsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/RegionOperationsClient/Get/main.go index 27393831af02..4394a99c85ac 100644 --- a/internal/generated/snippets/compute/apiv1/RegionOperationsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionOperationsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionOperationsClient/List/main.go b/internal/generated/snippets/compute/apiv1/RegionOperationsClient/List/main.go index b88a09ecd16e..d15516813642 100644 --- a/internal/generated/snippets/compute/apiv1/RegionOperationsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionOperationsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionOperationsClient/Wait/main.go b/internal/generated/snippets/compute/apiv1/RegionOperationsClient/Wait/main.go index 24307bdbe697..8981d9ddc90d 100644 --- a/internal/generated/snippets/compute/apiv1/RegionOperationsClient/Wait/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionOperationsClient/Wait/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/AddRule/main.go b/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/AddRule/main.go index 134f5019040e..972fd7372a3f 100644 --- a/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/AddRule/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/AddRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/Delete/main.go index 0558805fda07..42deb611ce97 100644 --- a/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/Get/main.go index b68c4db623d4..71c28ddada02 100644 --- a/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/GetRule/main.go b/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/GetRule/main.go index f73eb857f912..0a41ad2e3d15 100644 --- a/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/GetRule/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/GetRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/Insert/main.go index 71f3e02051ef..886c5f98e8d2 100644 --- a/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/List/main.go b/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/List/main.go index d3662a1203e0..f3a58e31a157 100644 --- a/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/Patch/main.go index e292279cd403..d4ad41a133fc 100644 --- a/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/PatchRule/main.go b/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/PatchRule/main.go index 2f42476bb4fc..3a02c4a6523d 100644 --- a/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/PatchRule/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/PatchRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/RemoveRule/main.go b/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/RemoveRule/main.go index 60f4f8897602..94579441e17c 100644 --- a/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/RemoveRule/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/RemoveRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/SetLabels/main.go b/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/SetLabels/main.go index f29f28dae15d..4b7c813796f9 100644 --- a/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/SetLabels/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionSecurityPoliciesClient/SetLabels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionSslCertificatesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/RegionSslCertificatesClient/Delete/main.go index fc1bcf94993a..48ed15c6edb6 100644 --- a/internal/generated/snippets/compute/apiv1/RegionSslCertificatesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionSslCertificatesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionSslCertificatesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/RegionSslCertificatesClient/Get/main.go index 7927671f2558..7ee715198e86 100644 --- a/internal/generated/snippets/compute/apiv1/RegionSslCertificatesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionSslCertificatesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionSslCertificatesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/RegionSslCertificatesClient/Insert/main.go index 78b9fc18f3b1..421f42f3afc3 100644 --- a/internal/generated/snippets/compute/apiv1/RegionSslCertificatesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionSslCertificatesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionSslCertificatesClient/List/main.go b/internal/generated/snippets/compute/apiv1/RegionSslCertificatesClient/List/main.go index 758487a4f4d0..a2f101e5296e 100644 --- a/internal/generated/snippets/compute/apiv1/RegionSslCertificatesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionSslCertificatesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionSslPoliciesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/RegionSslPoliciesClient/Delete/main.go index 8c690323aa4d..3d5adee04e12 100644 --- a/internal/generated/snippets/compute/apiv1/RegionSslPoliciesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionSslPoliciesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionSslPoliciesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/RegionSslPoliciesClient/Get/main.go index 57e124688e1f..e3a49193212b 100644 --- a/internal/generated/snippets/compute/apiv1/RegionSslPoliciesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionSslPoliciesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionSslPoliciesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/RegionSslPoliciesClient/Insert/main.go index 3d418f55722a..b757c218de7e 100644 --- a/internal/generated/snippets/compute/apiv1/RegionSslPoliciesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionSslPoliciesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionSslPoliciesClient/List/main.go b/internal/generated/snippets/compute/apiv1/RegionSslPoliciesClient/List/main.go index 79913012ea1f..dc75549108e0 100644 --- a/internal/generated/snippets/compute/apiv1/RegionSslPoliciesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionSslPoliciesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionSslPoliciesClient/ListAvailableFeatures/main.go b/internal/generated/snippets/compute/apiv1/RegionSslPoliciesClient/ListAvailableFeatures/main.go index ef772c8e717d..557f3829645a 100644 --- a/internal/generated/snippets/compute/apiv1/RegionSslPoliciesClient/ListAvailableFeatures/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionSslPoliciesClient/ListAvailableFeatures/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionSslPoliciesClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/RegionSslPoliciesClient/Patch/main.go index 0eee945de66e..890a89701ad1 100644 --- a/internal/generated/snippets/compute/apiv1/RegionSslPoliciesClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionSslPoliciesClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionTargetHttpProxiesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/RegionTargetHttpProxiesClient/Delete/main.go index 3b84f9d520fd..a377074ccf03 100644 --- a/internal/generated/snippets/compute/apiv1/RegionTargetHttpProxiesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionTargetHttpProxiesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionTargetHttpProxiesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/RegionTargetHttpProxiesClient/Get/main.go index 63c531d0412b..c9a0f79f2a80 100644 --- a/internal/generated/snippets/compute/apiv1/RegionTargetHttpProxiesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionTargetHttpProxiesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionTargetHttpProxiesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/RegionTargetHttpProxiesClient/Insert/main.go index ed13233f8b36..34fb4086568f 100644 --- a/internal/generated/snippets/compute/apiv1/RegionTargetHttpProxiesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionTargetHttpProxiesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionTargetHttpProxiesClient/List/main.go b/internal/generated/snippets/compute/apiv1/RegionTargetHttpProxiesClient/List/main.go index 6235aa664aed..d97804383496 100644 --- a/internal/generated/snippets/compute/apiv1/RegionTargetHttpProxiesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionTargetHttpProxiesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionTargetHttpProxiesClient/SetUrlMap/main.go b/internal/generated/snippets/compute/apiv1/RegionTargetHttpProxiesClient/SetUrlMap/main.go index 51eb80f456d1..8b2dfc5ce867 100644 --- a/internal/generated/snippets/compute/apiv1/RegionTargetHttpProxiesClient/SetUrlMap/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionTargetHttpProxiesClient/SetUrlMap/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionTargetHttpsProxiesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/RegionTargetHttpsProxiesClient/Delete/main.go index 383e63b1b9cb..6e940edf9af2 100644 --- a/internal/generated/snippets/compute/apiv1/RegionTargetHttpsProxiesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionTargetHttpsProxiesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionTargetHttpsProxiesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/RegionTargetHttpsProxiesClient/Get/main.go index a458f8133849..e748eb333abf 100644 --- a/internal/generated/snippets/compute/apiv1/RegionTargetHttpsProxiesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionTargetHttpsProxiesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionTargetHttpsProxiesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/RegionTargetHttpsProxiesClient/Insert/main.go index 3acdf4e4f43b..b75ee7b70de6 100644 --- a/internal/generated/snippets/compute/apiv1/RegionTargetHttpsProxiesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionTargetHttpsProxiesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionTargetHttpsProxiesClient/List/main.go b/internal/generated/snippets/compute/apiv1/RegionTargetHttpsProxiesClient/List/main.go index 2a06daf07be7..4913020bf9d5 100644 --- a/internal/generated/snippets/compute/apiv1/RegionTargetHttpsProxiesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionTargetHttpsProxiesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionTargetHttpsProxiesClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/RegionTargetHttpsProxiesClient/Patch/main.go index e226aa72237f..c245e291109a 100644 --- a/internal/generated/snippets/compute/apiv1/RegionTargetHttpsProxiesClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionTargetHttpsProxiesClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionTargetHttpsProxiesClient/SetSslCertificates/main.go b/internal/generated/snippets/compute/apiv1/RegionTargetHttpsProxiesClient/SetSslCertificates/main.go index 6d6c5e1f5fc8..1fc647a52694 100644 --- a/internal/generated/snippets/compute/apiv1/RegionTargetHttpsProxiesClient/SetSslCertificates/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionTargetHttpsProxiesClient/SetSslCertificates/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionTargetHttpsProxiesClient/SetUrlMap/main.go b/internal/generated/snippets/compute/apiv1/RegionTargetHttpsProxiesClient/SetUrlMap/main.go index 6208e5087351..1c6ae2b43fab 100644 --- a/internal/generated/snippets/compute/apiv1/RegionTargetHttpsProxiesClient/SetUrlMap/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionTargetHttpsProxiesClient/SetUrlMap/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionTargetTcpProxiesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/RegionTargetTcpProxiesClient/Delete/main.go index b4378b46157f..3dd1bb0b5739 100644 --- a/internal/generated/snippets/compute/apiv1/RegionTargetTcpProxiesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionTargetTcpProxiesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionTargetTcpProxiesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/RegionTargetTcpProxiesClient/Get/main.go index 65c533601de0..a522dd289df8 100644 --- a/internal/generated/snippets/compute/apiv1/RegionTargetTcpProxiesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionTargetTcpProxiesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionTargetTcpProxiesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/RegionTargetTcpProxiesClient/Insert/main.go index 6b6d6cf0bd71..cca65ef1c947 100644 --- a/internal/generated/snippets/compute/apiv1/RegionTargetTcpProxiesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionTargetTcpProxiesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionTargetTcpProxiesClient/List/main.go b/internal/generated/snippets/compute/apiv1/RegionTargetTcpProxiesClient/List/main.go index 105902ec1214..213c5f1db27a 100644 --- a/internal/generated/snippets/compute/apiv1/RegionTargetTcpProxiesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionTargetTcpProxiesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionUrlMapsClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/RegionUrlMapsClient/Delete/main.go index ad16c6fd727d..4a2ebb092cb8 100644 --- a/internal/generated/snippets/compute/apiv1/RegionUrlMapsClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionUrlMapsClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionUrlMapsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/RegionUrlMapsClient/Get/main.go index 6c6f24c3a533..c44e188d9921 100644 --- a/internal/generated/snippets/compute/apiv1/RegionUrlMapsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionUrlMapsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionUrlMapsClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/RegionUrlMapsClient/Insert/main.go index 56bdc91d1855..c420836cd4bf 100644 --- a/internal/generated/snippets/compute/apiv1/RegionUrlMapsClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionUrlMapsClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionUrlMapsClient/List/main.go b/internal/generated/snippets/compute/apiv1/RegionUrlMapsClient/List/main.go index bc8a4e8b8d93..9881469ff0fa 100644 --- a/internal/generated/snippets/compute/apiv1/RegionUrlMapsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionUrlMapsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionUrlMapsClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/RegionUrlMapsClient/Patch/main.go index f415ee8bf354..b720d311653d 100644 --- a/internal/generated/snippets/compute/apiv1/RegionUrlMapsClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionUrlMapsClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionUrlMapsClient/Update/main.go b/internal/generated/snippets/compute/apiv1/RegionUrlMapsClient/Update/main.go index 8b33826b08e0..e261b5acee9b 100644 --- a/internal/generated/snippets/compute/apiv1/RegionUrlMapsClient/Update/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionUrlMapsClient/Update/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionUrlMapsClient/Validate/main.go b/internal/generated/snippets/compute/apiv1/RegionUrlMapsClient/Validate/main.go index 30f2a3b163c7..76d356e5d5ca 100644 --- a/internal/generated/snippets/compute/apiv1/RegionUrlMapsClient/Validate/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionUrlMapsClient/Validate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionZonesClient/List/main.go b/internal/generated/snippets/compute/apiv1/RegionZonesClient/List/main.go index 0bf0eb8e63dd..4050ecfa8ecd 100644 --- a/internal/generated/snippets/compute/apiv1/RegionZonesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionZonesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/RegionsClient/Get/main.go index 14c54b49fab3..6d23a6dd5daa 100644 --- a/internal/generated/snippets/compute/apiv1/RegionsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RegionsClient/List/main.go b/internal/generated/snippets/compute/apiv1/RegionsClient/List/main.go index 2cff7d6c35ce..687f6f1744ff 100644 --- a/internal/generated/snippets/compute/apiv1/RegionsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/RegionsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ReservationsClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/ReservationsClient/AggregatedList/main.go index 5c6eeaa568a1..877fd813c685 100644 --- a/internal/generated/snippets/compute/apiv1/ReservationsClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/ReservationsClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ReservationsClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/ReservationsClient/Delete/main.go index b54a389a9d61..d3810725ff49 100644 --- a/internal/generated/snippets/compute/apiv1/ReservationsClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/ReservationsClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ReservationsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/ReservationsClient/Get/main.go index f7bd616aa31e..56c1e30984ed 100644 --- a/internal/generated/snippets/compute/apiv1/ReservationsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/ReservationsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ReservationsClient/GetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/ReservationsClient/GetIamPolicy/main.go index 2ba6dbda3184..566e39072a78 100644 --- a/internal/generated/snippets/compute/apiv1/ReservationsClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/ReservationsClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ReservationsClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/ReservationsClient/Insert/main.go index 05d5bd2c2c04..0ccb2bda2be9 100644 --- a/internal/generated/snippets/compute/apiv1/ReservationsClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/ReservationsClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ReservationsClient/List/main.go b/internal/generated/snippets/compute/apiv1/ReservationsClient/List/main.go index c4b29a0b742d..e92fe6ad3299 100644 --- a/internal/generated/snippets/compute/apiv1/ReservationsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/ReservationsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ReservationsClient/Resize/main.go b/internal/generated/snippets/compute/apiv1/ReservationsClient/Resize/main.go index c1582935eb74..8fc5da0629ce 100644 --- a/internal/generated/snippets/compute/apiv1/ReservationsClient/Resize/main.go +++ b/internal/generated/snippets/compute/apiv1/ReservationsClient/Resize/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ReservationsClient/SetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/ReservationsClient/SetIamPolicy/main.go index 577198ff0e5b..6efe6d190adb 100644 --- a/internal/generated/snippets/compute/apiv1/ReservationsClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/ReservationsClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ReservationsClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/ReservationsClient/TestIamPermissions/main.go index f0f882c1a288..6dedb330f574 100644 --- a/internal/generated/snippets/compute/apiv1/ReservationsClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/ReservationsClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ReservationsClient/Update/main.go b/internal/generated/snippets/compute/apiv1/ReservationsClient/Update/main.go index a3a27523ef7f..d568338da42a 100644 --- a/internal/generated/snippets/compute/apiv1/ReservationsClient/Update/main.go +++ b/internal/generated/snippets/compute/apiv1/ReservationsClient/Update/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/AggregatedList/main.go index e8f66dcd6796..e987b15e1d60 100644 --- a/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/Delete/main.go index cf4dc2d1e94d..437838dc052d 100644 --- a/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/Get/main.go index 6883ce3e5c79..5533c201c8d0 100644 --- a/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/GetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/GetIamPolicy/main.go index 34d3e0639618..b066f830de88 100644 --- a/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/Insert/main.go index 6b544bb1dbb5..60c3864e11f7 100644 --- a/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/List/main.go b/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/List/main.go index 1d39afa8c5c1..c185c33300ff 100644 --- a/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/Patch/main.go index fd1681578ea5..f0bf1252330c 100644 --- a/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/SetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/SetIamPolicy/main.go index b85fe1715e66..af63ca9b5af4 100644 --- a/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/TestIamPermissions/main.go index e9644facd6f4..509661cfa53f 100644 --- a/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/ResourcePoliciesClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RoutersClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/RoutersClient/AggregatedList/main.go index ae35f50c71d6..9294a9f66701 100644 --- a/internal/generated/snippets/compute/apiv1/RoutersClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/RoutersClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RoutersClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/RoutersClient/Delete/main.go index 691a2c17e9cd..a51022bdf976 100644 --- a/internal/generated/snippets/compute/apiv1/RoutersClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/RoutersClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RoutersClient/Get/main.go b/internal/generated/snippets/compute/apiv1/RoutersClient/Get/main.go index a322a15913ce..02701ffa6364 100644 --- a/internal/generated/snippets/compute/apiv1/RoutersClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/RoutersClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RoutersClient/GetNatIpInfo/main.go b/internal/generated/snippets/compute/apiv1/RoutersClient/GetNatIpInfo/main.go index 34bc8f9ea84d..0815209c67df 100644 --- a/internal/generated/snippets/compute/apiv1/RoutersClient/GetNatIpInfo/main.go +++ b/internal/generated/snippets/compute/apiv1/RoutersClient/GetNatIpInfo/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RoutersClient/GetNatMappingInfo/main.go b/internal/generated/snippets/compute/apiv1/RoutersClient/GetNatMappingInfo/main.go index 410b77e17486..28dddcf420f4 100644 --- a/internal/generated/snippets/compute/apiv1/RoutersClient/GetNatMappingInfo/main.go +++ b/internal/generated/snippets/compute/apiv1/RoutersClient/GetNatMappingInfo/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RoutersClient/GetRouterStatus/main.go b/internal/generated/snippets/compute/apiv1/RoutersClient/GetRouterStatus/main.go index 9091e21d3d23..227ba7a9f541 100644 --- a/internal/generated/snippets/compute/apiv1/RoutersClient/GetRouterStatus/main.go +++ b/internal/generated/snippets/compute/apiv1/RoutersClient/GetRouterStatus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RoutersClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/RoutersClient/Insert/main.go index 828b1798e04c..162553e6b4dd 100644 --- a/internal/generated/snippets/compute/apiv1/RoutersClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/RoutersClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RoutersClient/List/main.go b/internal/generated/snippets/compute/apiv1/RoutersClient/List/main.go index 80c984113a50..484d67ff9346 100644 --- a/internal/generated/snippets/compute/apiv1/RoutersClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/RoutersClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RoutersClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/RoutersClient/Patch/main.go index e903c5b66d45..c2da749a2cbe 100644 --- a/internal/generated/snippets/compute/apiv1/RoutersClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/RoutersClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RoutersClient/Preview/main.go b/internal/generated/snippets/compute/apiv1/RoutersClient/Preview/main.go index e133ec431db4..31c7c08c5198 100644 --- a/internal/generated/snippets/compute/apiv1/RoutersClient/Preview/main.go +++ b/internal/generated/snippets/compute/apiv1/RoutersClient/Preview/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RoutersClient/Update/main.go b/internal/generated/snippets/compute/apiv1/RoutersClient/Update/main.go index 837c1516da0c..ee860e2ed0a4 100644 --- a/internal/generated/snippets/compute/apiv1/RoutersClient/Update/main.go +++ b/internal/generated/snippets/compute/apiv1/RoutersClient/Update/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RoutesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/RoutesClient/Delete/main.go index 2287f9d53372..64168bc3f3db 100644 --- a/internal/generated/snippets/compute/apiv1/RoutesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/RoutesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RoutesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/RoutesClient/Get/main.go index 1887493ee178..7c3c7d829842 100644 --- a/internal/generated/snippets/compute/apiv1/RoutesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/RoutesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RoutesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/RoutesClient/Insert/main.go index b4dd3a04b82d..35b9c6243492 100644 --- a/internal/generated/snippets/compute/apiv1/RoutesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/RoutesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/RoutesClient/List/main.go b/internal/generated/snippets/compute/apiv1/RoutesClient/List/main.go index f9742c43de19..3302e5a1caed 100644 --- a/internal/generated/snippets/compute/apiv1/RoutesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/RoutesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/AddRule/main.go b/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/AddRule/main.go index 66fdb3e74435..3cc412036e4c 100644 --- a/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/AddRule/main.go +++ b/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/AddRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/AggregatedList/main.go index 86a15d1869a8..1143815945a2 100644 --- a/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/Delete/main.go index ff96026d2482..7a1419baa20d 100644 --- a/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/Get/main.go index 2e909a331ec2..4e1ac2333def 100644 --- a/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/GetRule/main.go b/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/GetRule/main.go index 2b7ddcddedaf..bb7bf310d7f0 100644 --- a/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/GetRule/main.go +++ b/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/GetRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/Insert/main.go index 3f7a90686b3f..127188521691 100644 --- a/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/List/main.go b/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/List/main.go index 618962802207..6bccf93f9a82 100644 --- a/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/ListPreconfiguredExpressionSets/main.go b/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/ListPreconfiguredExpressionSets/main.go index c26c1befc72b..b864298779a3 100644 --- a/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/ListPreconfiguredExpressionSets/main.go +++ b/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/ListPreconfiguredExpressionSets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/Patch/main.go index 265f141f5987..e4298504b123 100644 --- a/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/PatchRule/main.go b/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/PatchRule/main.go index 57206323148f..85a4cc4d5af6 100644 --- a/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/PatchRule/main.go +++ b/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/PatchRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/RemoveRule/main.go b/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/RemoveRule/main.go index 99b792f2d112..3db084e8dd2a 100644 --- a/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/RemoveRule/main.go +++ b/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/RemoveRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/SetLabels/main.go b/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/SetLabels/main.go index e6e509677770..09d908ff1641 100644 --- a/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/SetLabels/main.go +++ b/internal/generated/snippets/compute/apiv1/SecurityPoliciesClient/SetLabels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/AggregatedList/main.go index 597181be9e3b..e6234df3cd9d 100644 --- a/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/Delete/main.go index bd1035052da1..0230ec1f50d0 100644 --- a/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/Get/main.go index 94407ffdffdd..09ba1d368525 100644 --- a/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/GetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/GetIamPolicy/main.go index 8c2dddaf2a6b..7ae98f86eafb 100644 --- a/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/Insert/main.go index 7fa6940cf2d3..e0b8c80ae47b 100644 --- a/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/List/main.go b/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/List/main.go index 1a9592889150..e6b7a57b8b31 100644 --- a/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/Patch/main.go index edd0fcdcc28f..79418f115749 100644 --- a/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/SetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/SetIamPolicy/main.go index 7215aa8603af..b0acf123f0f2 100644 --- a/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/TestIamPermissions/main.go index 91c415582f0d..40b6cb2261e6 100644 --- a/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/ServiceAttachmentsClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SnapshotSettingsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/SnapshotSettingsClient/Get/main.go index 2933e3145279..e09efe7e4586 100644 --- a/internal/generated/snippets/compute/apiv1/SnapshotSettingsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/SnapshotSettingsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SnapshotSettingsClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/SnapshotSettingsClient/Patch/main.go index 968cefb7f8f0..31ba53ae4448 100644 --- a/internal/generated/snippets/compute/apiv1/SnapshotSettingsClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/SnapshotSettingsClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SnapshotsClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/SnapshotsClient/Delete/main.go index 818cfc8edc91..3ad85bb0416c 100644 --- a/internal/generated/snippets/compute/apiv1/SnapshotsClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/SnapshotsClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SnapshotsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/SnapshotsClient/Get/main.go index 53a11eaed880..72aabcca281b 100644 --- a/internal/generated/snippets/compute/apiv1/SnapshotsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/SnapshotsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SnapshotsClient/GetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/SnapshotsClient/GetIamPolicy/main.go index ba4a4f70537f..e161c3825cf6 100644 --- a/internal/generated/snippets/compute/apiv1/SnapshotsClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/SnapshotsClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SnapshotsClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/SnapshotsClient/Insert/main.go index a627264933d1..2d50445df344 100644 --- a/internal/generated/snippets/compute/apiv1/SnapshotsClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/SnapshotsClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SnapshotsClient/List/main.go b/internal/generated/snippets/compute/apiv1/SnapshotsClient/List/main.go index 8f44dd1c3489..a9f56177093f 100644 --- a/internal/generated/snippets/compute/apiv1/SnapshotsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/SnapshotsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SnapshotsClient/SetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/SnapshotsClient/SetIamPolicy/main.go index 365ec9ad6ca7..537900f66913 100644 --- a/internal/generated/snippets/compute/apiv1/SnapshotsClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/SnapshotsClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SnapshotsClient/SetLabels/main.go b/internal/generated/snippets/compute/apiv1/SnapshotsClient/SetLabels/main.go index eea8f7662f51..0b26526dbd02 100644 --- a/internal/generated/snippets/compute/apiv1/SnapshotsClient/SetLabels/main.go +++ b/internal/generated/snippets/compute/apiv1/SnapshotsClient/SetLabels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SnapshotsClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/SnapshotsClient/TestIamPermissions/main.go index 57ef2b182b11..34c3e629bb71 100644 --- a/internal/generated/snippets/compute/apiv1/SnapshotsClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/SnapshotsClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SslCertificatesClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/SslCertificatesClient/AggregatedList/main.go index 2e848617c69e..b1588d6cc100 100644 --- a/internal/generated/snippets/compute/apiv1/SslCertificatesClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/SslCertificatesClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SslCertificatesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/SslCertificatesClient/Delete/main.go index bf373aaff101..de7b3616c253 100644 --- a/internal/generated/snippets/compute/apiv1/SslCertificatesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/SslCertificatesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SslCertificatesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/SslCertificatesClient/Get/main.go index f89514a6d399..103a28feab24 100644 --- a/internal/generated/snippets/compute/apiv1/SslCertificatesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/SslCertificatesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SslCertificatesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/SslCertificatesClient/Insert/main.go index b994d57defe7..0c8409702969 100644 --- a/internal/generated/snippets/compute/apiv1/SslCertificatesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/SslCertificatesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SslCertificatesClient/List/main.go b/internal/generated/snippets/compute/apiv1/SslCertificatesClient/List/main.go index d91c7c41109c..bb623a5bd1ea 100644 --- a/internal/generated/snippets/compute/apiv1/SslCertificatesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/SslCertificatesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SslPoliciesClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/SslPoliciesClient/AggregatedList/main.go index b551c6d00174..5b70ff241501 100644 --- a/internal/generated/snippets/compute/apiv1/SslPoliciesClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/SslPoliciesClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SslPoliciesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/SslPoliciesClient/Delete/main.go index 3a71e533413f..2e8495535d02 100644 --- a/internal/generated/snippets/compute/apiv1/SslPoliciesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/SslPoliciesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SslPoliciesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/SslPoliciesClient/Get/main.go index c7f3304a2a74..3e124579e5ce 100644 --- a/internal/generated/snippets/compute/apiv1/SslPoliciesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/SslPoliciesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SslPoliciesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/SslPoliciesClient/Insert/main.go index 28c6fe5ad2fc..31bc355ecba9 100644 --- a/internal/generated/snippets/compute/apiv1/SslPoliciesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/SslPoliciesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SslPoliciesClient/List/main.go b/internal/generated/snippets/compute/apiv1/SslPoliciesClient/List/main.go index 87d2e74fe1ee..856d0023e121 100644 --- a/internal/generated/snippets/compute/apiv1/SslPoliciesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/SslPoliciesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SslPoliciesClient/ListAvailableFeatures/main.go b/internal/generated/snippets/compute/apiv1/SslPoliciesClient/ListAvailableFeatures/main.go index 95e7e0d11738..08ef9493cf38 100644 --- a/internal/generated/snippets/compute/apiv1/SslPoliciesClient/ListAvailableFeatures/main.go +++ b/internal/generated/snippets/compute/apiv1/SslPoliciesClient/ListAvailableFeatures/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SslPoliciesClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/SslPoliciesClient/Patch/main.go index 008e94c396c0..854649d9b46d 100644 --- a/internal/generated/snippets/compute/apiv1/SslPoliciesClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/SslPoliciesClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/StoragePoolTypesClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/StoragePoolTypesClient/AggregatedList/main.go index c2db8f619958..f9fa84bb3dbd 100644 --- a/internal/generated/snippets/compute/apiv1/StoragePoolTypesClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/StoragePoolTypesClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/StoragePoolTypesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/StoragePoolTypesClient/Get/main.go index c9d1049ef7c2..0fb9be20ae57 100644 --- a/internal/generated/snippets/compute/apiv1/StoragePoolTypesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/StoragePoolTypesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/StoragePoolTypesClient/List/main.go b/internal/generated/snippets/compute/apiv1/StoragePoolTypesClient/List/main.go index 67aa0cf05124..06003e0c388f 100644 --- a/internal/generated/snippets/compute/apiv1/StoragePoolTypesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/StoragePoolTypesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/StoragePoolsClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/StoragePoolsClient/AggregatedList/main.go index cf143d38f5e8..a7535afd052e 100644 --- a/internal/generated/snippets/compute/apiv1/StoragePoolsClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/StoragePoolsClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/StoragePoolsClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/StoragePoolsClient/Delete/main.go index 8c264e0b5aeb..149c7895fad1 100644 --- a/internal/generated/snippets/compute/apiv1/StoragePoolsClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/StoragePoolsClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/StoragePoolsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/StoragePoolsClient/Get/main.go index 6b66430e7007..6c0742ee75e1 100644 --- a/internal/generated/snippets/compute/apiv1/StoragePoolsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/StoragePoolsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/StoragePoolsClient/GetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/StoragePoolsClient/GetIamPolicy/main.go index c4a3133044ea..dd73a01d46af 100644 --- a/internal/generated/snippets/compute/apiv1/StoragePoolsClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/StoragePoolsClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/StoragePoolsClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/StoragePoolsClient/Insert/main.go index d505a5eb1ee9..3a7c430cfa73 100644 --- a/internal/generated/snippets/compute/apiv1/StoragePoolsClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/StoragePoolsClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/StoragePoolsClient/List/main.go b/internal/generated/snippets/compute/apiv1/StoragePoolsClient/List/main.go index 365507c697b5..d9bdaf06c405 100644 --- a/internal/generated/snippets/compute/apiv1/StoragePoolsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/StoragePoolsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/StoragePoolsClient/ListDisks/main.go b/internal/generated/snippets/compute/apiv1/StoragePoolsClient/ListDisks/main.go index 6be643a3d07e..3e373d20668a 100644 --- a/internal/generated/snippets/compute/apiv1/StoragePoolsClient/ListDisks/main.go +++ b/internal/generated/snippets/compute/apiv1/StoragePoolsClient/ListDisks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/StoragePoolsClient/SetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/StoragePoolsClient/SetIamPolicy/main.go index 13bb84f9508d..2825f3a108c8 100644 --- a/internal/generated/snippets/compute/apiv1/StoragePoolsClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/StoragePoolsClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/StoragePoolsClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/StoragePoolsClient/TestIamPermissions/main.go index c224b98ac9e5..bd82ed1f62c4 100644 --- a/internal/generated/snippets/compute/apiv1/StoragePoolsClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/StoragePoolsClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/StoragePoolsClient/Update/main.go b/internal/generated/snippets/compute/apiv1/StoragePoolsClient/Update/main.go index ab7fd2157794..f56185e221d0 100644 --- a/internal/generated/snippets/compute/apiv1/StoragePoolsClient/Update/main.go +++ b/internal/generated/snippets/compute/apiv1/StoragePoolsClient/Update/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SubnetworksClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/SubnetworksClient/AggregatedList/main.go index 3b40bbc434de..479086644a66 100644 --- a/internal/generated/snippets/compute/apiv1/SubnetworksClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/SubnetworksClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SubnetworksClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/SubnetworksClient/Delete/main.go index 035ac4b992a6..761cdd5ec1a1 100644 --- a/internal/generated/snippets/compute/apiv1/SubnetworksClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/SubnetworksClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SubnetworksClient/ExpandIpCidrRange/main.go b/internal/generated/snippets/compute/apiv1/SubnetworksClient/ExpandIpCidrRange/main.go index d79781823560..f11122df309e 100644 --- a/internal/generated/snippets/compute/apiv1/SubnetworksClient/ExpandIpCidrRange/main.go +++ b/internal/generated/snippets/compute/apiv1/SubnetworksClient/ExpandIpCidrRange/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SubnetworksClient/Get/main.go b/internal/generated/snippets/compute/apiv1/SubnetworksClient/Get/main.go index 12e4463a10e2..ade893a77dfa 100644 --- a/internal/generated/snippets/compute/apiv1/SubnetworksClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/SubnetworksClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SubnetworksClient/GetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/SubnetworksClient/GetIamPolicy/main.go index 01835d93bbff..30b709dfcde3 100644 --- a/internal/generated/snippets/compute/apiv1/SubnetworksClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/SubnetworksClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SubnetworksClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/SubnetworksClient/Insert/main.go index 811b9f753a25..df6efff8b154 100644 --- a/internal/generated/snippets/compute/apiv1/SubnetworksClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/SubnetworksClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SubnetworksClient/List/main.go b/internal/generated/snippets/compute/apiv1/SubnetworksClient/List/main.go index ed3debaebfb7..13c8ee8ddf1e 100644 --- a/internal/generated/snippets/compute/apiv1/SubnetworksClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/SubnetworksClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SubnetworksClient/ListUsable/main.go b/internal/generated/snippets/compute/apiv1/SubnetworksClient/ListUsable/main.go index 1b2a7aba8644..079c17a16604 100644 --- a/internal/generated/snippets/compute/apiv1/SubnetworksClient/ListUsable/main.go +++ b/internal/generated/snippets/compute/apiv1/SubnetworksClient/ListUsable/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SubnetworksClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/SubnetworksClient/Patch/main.go index bd5e74b13214..4792c4e666b3 100644 --- a/internal/generated/snippets/compute/apiv1/SubnetworksClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/SubnetworksClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SubnetworksClient/SetIamPolicy/main.go b/internal/generated/snippets/compute/apiv1/SubnetworksClient/SetIamPolicy/main.go index 7758837b9c7a..5424a7a549df 100644 --- a/internal/generated/snippets/compute/apiv1/SubnetworksClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/SubnetworksClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SubnetworksClient/SetPrivateIpGoogleAccess/main.go b/internal/generated/snippets/compute/apiv1/SubnetworksClient/SetPrivateIpGoogleAccess/main.go index 2d743b82017e..536f77f1707c 100644 --- a/internal/generated/snippets/compute/apiv1/SubnetworksClient/SetPrivateIpGoogleAccess/main.go +++ b/internal/generated/snippets/compute/apiv1/SubnetworksClient/SetPrivateIpGoogleAccess/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/SubnetworksClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/SubnetworksClient/TestIamPermissions/main.go index 4687f40bbe60..c82d87a56eb3 100644 --- a/internal/generated/snippets/compute/apiv1/SubnetworksClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/SubnetworksClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetGrpcProxiesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/TargetGrpcProxiesClient/Delete/main.go index eca8c8838a42..bcc53a46743c 100644 --- a/internal/generated/snippets/compute/apiv1/TargetGrpcProxiesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetGrpcProxiesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetGrpcProxiesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/TargetGrpcProxiesClient/Get/main.go index 6b73e4303a09..39051ffb4d41 100644 --- a/internal/generated/snippets/compute/apiv1/TargetGrpcProxiesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetGrpcProxiesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetGrpcProxiesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/TargetGrpcProxiesClient/Insert/main.go index 9154f0c4e236..87841f9904b7 100644 --- a/internal/generated/snippets/compute/apiv1/TargetGrpcProxiesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetGrpcProxiesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetGrpcProxiesClient/List/main.go b/internal/generated/snippets/compute/apiv1/TargetGrpcProxiesClient/List/main.go index 53da97e27cfe..048a83c3a183 100644 --- a/internal/generated/snippets/compute/apiv1/TargetGrpcProxiesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetGrpcProxiesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetGrpcProxiesClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/TargetGrpcProxiesClient/Patch/main.go index e199e26a9013..2611a0444b92 100644 --- a/internal/generated/snippets/compute/apiv1/TargetGrpcProxiesClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetGrpcProxiesClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetHttpProxiesClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/TargetHttpProxiesClient/AggregatedList/main.go index c8f6f2d9b942..04e75e28731e 100644 --- a/internal/generated/snippets/compute/apiv1/TargetHttpProxiesClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetHttpProxiesClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetHttpProxiesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/TargetHttpProxiesClient/Delete/main.go index ec7769fe36e9..5ebba707300f 100644 --- a/internal/generated/snippets/compute/apiv1/TargetHttpProxiesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetHttpProxiesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetHttpProxiesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/TargetHttpProxiesClient/Get/main.go index 1a1c7c37fbac..948dcfcc4b65 100644 --- a/internal/generated/snippets/compute/apiv1/TargetHttpProxiesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetHttpProxiesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetHttpProxiesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/TargetHttpProxiesClient/Insert/main.go index 84390fad1cd0..389f90995777 100644 --- a/internal/generated/snippets/compute/apiv1/TargetHttpProxiesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetHttpProxiesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetHttpProxiesClient/List/main.go b/internal/generated/snippets/compute/apiv1/TargetHttpProxiesClient/List/main.go index 72c25c6b3c6b..a278d4dc34c9 100644 --- a/internal/generated/snippets/compute/apiv1/TargetHttpProxiesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetHttpProxiesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetHttpProxiesClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/TargetHttpProxiesClient/Patch/main.go index 85069d6b95c8..6b60cff0a048 100644 --- a/internal/generated/snippets/compute/apiv1/TargetHttpProxiesClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetHttpProxiesClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetHttpProxiesClient/SetUrlMap/main.go b/internal/generated/snippets/compute/apiv1/TargetHttpProxiesClient/SetUrlMap/main.go index 1f71608bdf55..6248e84582a1 100644 --- a/internal/generated/snippets/compute/apiv1/TargetHttpProxiesClient/SetUrlMap/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetHttpProxiesClient/SetUrlMap/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/AggregatedList/main.go index 1903673ae2a4..1365ea243535 100644 --- a/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/Delete/main.go index 51cf81f706cb..010dd954a3c4 100644 --- a/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/Get/main.go index ad038beaa239..d038aba98428 100644 --- a/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/Insert/main.go index 822c0145188c..403e15b51f7c 100644 --- a/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/List/main.go b/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/List/main.go index bd221cb6cdc5..54d068c90813 100644 --- a/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/Patch/main.go index 1ed4c03cb886..2155de4fef41 100644 --- a/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/SetCertificateMap/main.go b/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/SetCertificateMap/main.go index fdd9ba5a97ee..98a1508d368d 100644 --- a/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/SetCertificateMap/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/SetCertificateMap/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/SetQuicOverride/main.go b/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/SetQuicOverride/main.go index 9640a6ed2034..f480ad57e4ec 100644 --- a/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/SetQuicOverride/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/SetQuicOverride/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/SetSslCertificates/main.go b/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/SetSslCertificates/main.go index 9e25fcb60def..8f2b19223364 100644 --- a/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/SetSslCertificates/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/SetSslCertificates/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/SetSslPolicy/main.go b/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/SetSslPolicy/main.go index abbc6eb1e77b..f53c39ae40c1 100644 --- a/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/SetSslPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/SetSslPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/SetUrlMap/main.go b/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/SetUrlMap/main.go index 30e8493e4c48..8b1d219f1b75 100644 --- a/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/SetUrlMap/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetHttpsProxiesClient/SetUrlMap/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetInstancesClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/TargetInstancesClient/AggregatedList/main.go index fcbab056bc44..4a51e3897142 100644 --- a/internal/generated/snippets/compute/apiv1/TargetInstancesClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetInstancesClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetInstancesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/TargetInstancesClient/Delete/main.go index b4be7cb6cb7f..a574ffd7df95 100644 --- a/internal/generated/snippets/compute/apiv1/TargetInstancesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetInstancesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetInstancesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/TargetInstancesClient/Get/main.go index ac5893bd02d2..00d75f612869 100644 --- a/internal/generated/snippets/compute/apiv1/TargetInstancesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetInstancesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetInstancesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/TargetInstancesClient/Insert/main.go index a12d8cb2c9e0..3aaafb669ebe 100644 --- a/internal/generated/snippets/compute/apiv1/TargetInstancesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetInstancesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetInstancesClient/List/main.go b/internal/generated/snippets/compute/apiv1/TargetInstancesClient/List/main.go index ee7584d53113..2dc0999e18a4 100644 --- a/internal/generated/snippets/compute/apiv1/TargetInstancesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetInstancesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetInstancesClient/SetSecurityPolicy/main.go b/internal/generated/snippets/compute/apiv1/TargetInstancesClient/SetSecurityPolicy/main.go index 5808d2856395..ca54d1da961d 100644 --- a/internal/generated/snippets/compute/apiv1/TargetInstancesClient/SetSecurityPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetInstancesClient/SetSecurityPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetPoolsClient/AddHealthCheck/main.go b/internal/generated/snippets/compute/apiv1/TargetPoolsClient/AddHealthCheck/main.go index a7bc11ca29ee..e42906a37400 100644 --- a/internal/generated/snippets/compute/apiv1/TargetPoolsClient/AddHealthCheck/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetPoolsClient/AddHealthCheck/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetPoolsClient/AddInstance/main.go b/internal/generated/snippets/compute/apiv1/TargetPoolsClient/AddInstance/main.go index 961d1a4c782a..ba647abbaf0e 100644 --- a/internal/generated/snippets/compute/apiv1/TargetPoolsClient/AddInstance/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetPoolsClient/AddInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetPoolsClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/TargetPoolsClient/AggregatedList/main.go index b599f7f54ad6..96625e2caf99 100644 --- a/internal/generated/snippets/compute/apiv1/TargetPoolsClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetPoolsClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetPoolsClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/TargetPoolsClient/Delete/main.go index 0555f179762a..c8d5d1d0ce94 100644 --- a/internal/generated/snippets/compute/apiv1/TargetPoolsClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetPoolsClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetPoolsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/TargetPoolsClient/Get/main.go index f95389858858..b98452a49079 100644 --- a/internal/generated/snippets/compute/apiv1/TargetPoolsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetPoolsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetPoolsClient/GetHealth/main.go b/internal/generated/snippets/compute/apiv1/TargetPoolsClient/GetHealth/main.go index 89a1632be21f..b7df1917e27c 100644 --- a/internal/generated/snippets/compute/apiv1/TargetPoolsClient/GetHealth/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetPoolsClient/GetHealth/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetPoolsClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/TargetPoolsClient/Insert/main.go index e68f93560750..49d78d2dd24f 100644 --- a/internal/generated/snippets/compute/apiv1/TargetPoolsClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetPoolsClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetPoolsClient/List/main.go b/internal/generated/snippets/compute/apiv1/TargetPoolsClient/List/main.go index 06b9b64d2769..ec6622c27b3e 100644 --- a/internal/generated/snippets/compute/apiv1/TargetPoolsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetPoolsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetPoolsClient/RemoveHealthCheck/main.go b/internal/generated/snippets/compute/apiv1/TargetPoolsClient/RemoveHealthCheck/main.go index 70082ed8c299..24b0e9faf3e9 100644 --- a/internal/generated/snippets/compute/apiv1/TargetPoolsClient/RemoveHealthCheck/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetPoolsClient/RemoveHealthCheck/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetPoolsClient/RemoveInstance/main.go b/internal/generated/snippets/compute/apiv1/TargetPoolsClient/RemoveInstance/main.go index 84c02ff334cc..3fdfdf6ce842 100644 --- a/internal/generated/snippets/compute/apiv1/TargetPoolsClient/RemoveInstance/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetPoolsClient/RemoveInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetPoolsClient/SetBackup/main.go b/internal/generated/snippets/compute/apiv1/TargetPoolsClient/SetBackup/main.go index 250acd9ee09f..1c351f4cad2f 100644 --- a/internal/generated/snippets/compute/apiv1/TargetPoolsClient/SetBackup/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetPoolsClient/SetBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetPoolsClient/SetSecurityPolicy/main.go b/internal/generated/snippets/compute/apiv1/TargetPoolsClient/SetSecurityPolicy/main.go index b27a0a6518e7..d79928983fdf 100644 --- a/internal/generated/snippets/compute/apiv1/TargetPoolsClient/SetSecurityPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetPoolsClient/SetSecurityPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/Delete/main.go index 04b5d1c5cbc1..22cdeea21eaf 100644 --- a/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/Get/main.go index ce4141408588..1783f50f279e 100644 --- a/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/Insert/main.go index fb7d5331066a..44da3a132a29 100644 --- a/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/List/main.go b/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/List/main.go index 86bc3d68d889..a2c685d73a51 100644 --- a/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/SetBackendService/main.go b/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/SetBackendService/main.go index 50eefb38f986..8a1996fc9484 100644 --- a/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/SetBackendService/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/SetBackendService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/SetCertificateMap/main.go b/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/SetCertificateMap/main.go index 25855e34c224..4f16a444b649 100644 --- a/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/SetCertificateMap/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/SetCertificateMap/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/SetProxyHeader/main.go b/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/SetProxyHeader/main.go index 34149709cdba..2462837413d8 100644 --- a/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/SetProxyHeader/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/SetProxyHeader/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/SetSslCertificates/main.go b/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/SetSslCertificates/main.go index db1cbfe422ac..b50b36fb783e 100644 --- a/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/SetSslCertificates/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/SetSslCertificates/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/SetSslPolicy/main.go b/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/SetSslPolicy/main.go index 61df80a3d202..f9fb34a124f8 100644 --- a/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/SetSslPolicy/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetSslProxiesClient/SetSslPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetTcpProxiesClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/TargetTcpProxiesClient/AggregatedList/main.go index a3c89cc95bb5..28aba4b2aa5c 100644 --- a/internal/generated/snippets/compute/apiv1/TargetTcpProxiesClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetTcpProxiesClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetTcpProxiesClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/TargetTcpProxiesClient/Delete/main.go index bfa79769f28a..78a9f9490a0b 100644 --- a/internal/generated/snippets/compute/apiv1/TargetTcpProxiesClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetTcpProxiesClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetTcpProxiesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/TargetTcpProxiesClient/Get/main.go index 405f0a6ea559..2c8046d46bbb 100644 --- a/internal/generated/snippets/compute/apiv1/TargetTcpProxiesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetTcpProxiesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetTcpProxiesClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/TargetTcpProxiesClient/Insert/main.go index 1b8a610726c7..42590a86b446 100644 --- a/internal/generated/snippets/compute/apiv1/TargetTcpProxiesClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetTcpProxiesClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetTcpProxiesClient/List/main.go b/internal/generated/snippets/compute/apiv1/TargetTcpProxiesClient/List/main.go index 1ba02afede4b..db0c42fad9fd 100644 --- a/internal/generated/snippets/compute/apiv1/TargetTcpProxiesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetTcpProxiesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetTcpProxiesClient/SetBackendService/main.go b/internal/generated/snippets/compute/apiv1/TargetTcpProxiesClient/SetBackendService/main.go index ff93ba958214..6cd1068758ab 100644 --- a/internal/generated/snippets/compute/apiv1/TargetTcpProxiesClient/SetBackendService/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetTcpProxiesClient/SetBackendService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetTcpProxiesClient/SetProxyHeader/main.go b/internal/generated/snippets/compute/apiv1/TargetTcpProxiesClient/SetProxyHeader/main.go index 17fc63e71b74..4154d7826b1d 100644 --- a/internal/generated/snippets/compute/apiv1/TargetTcpProxiesClient/SetProxyHeader/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetTcpProxiesClient/SetProxyHeader/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetVpnGatewaysClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/TargetVpnGatewaysClient/AggregatedList/main.go index 2fafb8dab757..81cb333eeb4a 100644 --- a/internal/generated/snippets/compute/apiv1/TargetVpnGatewaysClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetVpnGatewaysClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetVpnGatewaysClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/TargetVpnGatewaysClient/Delete/main.go index 252a16b57dc8..44b899418972 100644 --- a/internal/generated/snippets/compute/apiv1/TargetVpnGatewaysClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetVpnGatewaysClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetVpnGatewaysClient/Get/main.go b/internal/generated/snippets/compute/apiv1/TargetVpnGatewaysClient/Get/main.go index 05ec22dd5a31..0aad9d5ea164 100644 --- a/internal/generated/snippets/compute/apiv1/TargetVpnGatewaysClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetVpnGatewaysClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetVpnGatewaysClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/TargetVpnGatewaysClient/Insert/main.go index ba95200a427a..e9e1ff1069a7 100644 --- a/internal/generated/snippets/compute/apiv1/TargetVpnGatewaysClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetVpnGatewaysClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetVpnGatewaysClient/List/main.go b/internal/generated/snippets/compute/apiv1/TargetVpnGatewaysClient/List/main.go index 4e4fb56f2246..67f3704854ee 100644 --- a/internal/generated/snippets/compute/apiv1/TargetVpnGatewaysClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetVpnGatewaysClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/TargetVpnGatewaysClient/SetLabels/main.go b/internal/generated/snippets/compute/apiv1/TargetVpnGatewaysClient/SetLabels/main.go index 7a9d653f515b..2a7847d43ffc 100644 --- a/internal/generated/snippets/compute/apiv1/TargetVpnGatewaysClient/SetLabels/main.go +++ b/internal/generated/snippets/compute/apiv1/TargetVpnGatewaysClient/SetLabels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/UrlMapsClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/UrlMapsClient/AggregatedList/main.go index 1d87a6579667..605a0044aa57 100644 --- a/internal/generated/snippets/compute/apiv1/UrlMapsClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/UrlMapsClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/UrlMapsClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/UrlMapsClient/Delete/main.go index 79b72b02e501..fdc36dd9d9aa 100644 --- a/internal/generated/snippets/compute/apiv1/UrlMapsClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/UrlMapsClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/UrlMapsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/UrlMapsClient/Get/main.go index b010e4910afc..c6f085c8c940 100644 --- a/internal/generated/snippets/compute/apiv1/UrlMapsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/UrlMapsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/UrlMapsClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/UrlMapsClient/Insert/main.go index fce0fe4d9051..34a2eb5a489f 100644 --- a/internal/generated/snippets/compute/apiv1/UrlMapsClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/UrlMapsClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/UrlMapsClient/InvalidateCache/main.go b/internal/generated/snippets/compute/apiv1/UrlMapsClient/InvalidateCache/main.go index 955e1a34cc2a..936ced18486b 100644 --- a/internal/generated/snippets/compute/apiv1/UrlMapsClient/InvalidateCache/main.go +++ b/internal/generated/snippets/compute/apiv1/UrlMapsClient/InvalidateCache/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/UrlMapsClient/List/main.go b/internal/generated/snippets/compute/apiv1/UrlMapsClient/List/main.go index f23a5efc66fb..f6a88bdcbade 100644 --- a/internal/generated/snippets/compute/apiv1/UrlMapsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/UrlMapsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/UrlMapsClient/Patch/main.go b/internal/generated/snippets/compute/apiv1/UrlMapsClient/Patch/main.go index f84efe125d78..bb789301473d 100644 --- a/internal/generated/snippets/compute/apiv1/UrlMapsClient/Patch/main.go +++ b/internal/generated/snippets/compute/apiv1/UrlMapsClient/Patch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/UrlMapsClient/Update/main.go b/internal/generated/snippets/compute/apiv1/UrlMapsClient/Update/main.go index b049735c76d1..e88102e4da84 100644 --- a/internal/generated/snippets/compute/apiv1/UrlMapsClient/Update/main.go +++ b/internal/generated/snippets/compute/apiv1/UrlMapsClient/Update/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/UrlMapsClient/Validate/main.go b/internal/generated/snippets/compute/apiv1/UrlMapsClient/Validate/main.go index f928d411f5cf..2d02b332fcfd 100644 --- a/internal/generated/snippets/compute/apiv1/UrlMapsClient/Validate/main.go +++ b/internal/generated/snippets/compute/apiv1/UrlMapsClient/Validate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/AggregatedList/main.go index edb71efc14f3..8da048f362db 100644 --- a/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/Delete/main.go index b29a12888798..120fc1d38e04 100644 --- a/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/Get/main.go b/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/Get/main.go index 23fbaee08d95..82e36548b309 100644 --- a/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/GetStatus/main.go b/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/GetStatus/main.go index ed6955814183..587857ced091 100644 --- a/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/GetStatus/main.go +++ b/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/GetStatus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/Insert/main.go index 82b81573d639..d2bf85b96fb2 100644 --- a/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/List/main.go b/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/List/main.go index ee8f0e6da1c3..4051441117af 100644 --- a/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/SetLabels/main.go b/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/SetLabels/main.go index 969866d3aa4a..34127af8df6d 100644 --- a/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/SetLabels/main.go +++ b/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/SetLabels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/TestIamPermissions/main.go b/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/TestIamPermissions/main.go index 361a0248f4c6..4a6e4fa29864 100644 --- a/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/compute/apiv1/VpnGatewaysClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/VpnTunnelsClient/AggregatedList/main.go b/internal/generated/snippets/compute/apiv1/VpnTunnelsClient/AggregatedList/main.go index 95842d08b3b3..516dafe29d82 100644 --- a/internal/generated/snippets/compute/apiv1/VpnTunnelsClient/AggregatedList/main.go +++ b/internal/generated/snippets/compute/apiv1/VpnTunnelsClient/AggregatedList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/VpnTunnelsClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/VpnTunnelsClient/Delete/main.go index a057892bb5e6..274316c32798 100644 --- a/internal/generated/snippets/compute/apiv1/VpnTunnelsClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/VpnTunnelsClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/VpnTunnelsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/VpnTunnelsClient/Get/main.go index 98f67465506c..7803a8a190c8 100644 --- a/internal/generated/snippets/compute/apiv1/VpnTunnelsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/VpnTunnelsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/VpnTunnelsClient/Insert/main.go b/internal/generated/snippets/compute/apiv1/VpnTunnelsClient/Insert/main.go index dddec9b33627..86d2a1362702 100644 --- a/internal/generated/snippets/compute/apiv1/VpnTunnelsClient/Insert/main.go +++ b/internal/generated/snippets/compute/apiv1/VpnTunnelsClient/Insert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/VpnTunnelsClient/List/main.go b/internal/generated/snippets/compute/apiv1/VpnTunnelsClient/List/main.go index 59f38f840b67..5479896e05a5 100644 --- a/internal/generated/snippets/compute/apiv1/VpnTunnelsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/VpnTunnelsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/VpnTunnelsClient/SetLabels/main.go b/internal/generated/snippets/compute/apiv1/VpnTunnelsClient/SetLabels/main.go index 69f4e6b00f04..7455beb2d2e5 100644 --- a/internal/generated/snippets/compute/apiv1/VpnTunnelsClient/SetLabels/main.go +++ b/internal/generated/snippets/compute/apiv1/VpnTunnelsClient/SetLabels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ZoneOperationsClient/Delete/main.go b/internal/generated/snippets/compute/apiv1/ZoneOperationsClient/Delete/main.go index b5be71237eda..e791e6fbd4b7 100644 --- a/internal/generated/snippets/compute/apiv1/ZoneOperationsClient/Delete/main.go +++ b/internal/generated/snippets/compute/apiv1/ZoneOperationsClient/Delete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ZoneOperationsClient/Get/main.go b/internal/generated/snippets/compute/apiv1/ZoneOperationsClient/Get/main.go index 59fc5546ad66..00a3789e6f02 100644 --- a/internal/generated/snippets/compute/apiv1/ZoneOperationsClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/ZoneOperationsClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ZoneOperationsClient/List/main.go b/internal/generated/snippets/compute/apiv1/ZoneOperationsClient/List/main.go index 18e7230ab376..c2d15ddad729 100644 --- a/internal/generated/snippets/compute/apiv1/ZoneOperationsClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/ZoneOperationsClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ZoneOperationsClient/Wait/main.go b/internal/generated/snippets/compute/apiv1/ZoneOperationsClient/Wait/main.go index cd0bd2619471..38f8b33320cd 100644 --- a/internal/generated/snippets/compute/apiv1/ZoneOperationsClient/Wait/main.go +++ b/internal/generated/snippets/compute/apiv1/ZoneOperationsClient/Wait/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ZonesClient/Get/main.go b/internal/generated/snippets/compute/apiv1/ZonesClient/Get/main.go index b43e0a293c7c..0fb59f80a0c8 100644 --- a/internal/generated/snippets/compute/apiv1/ZonesClient/Get/main.go +++ b/internal/generated/snippets/compute/apiv1/ZonesClient/Get/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/ZonesClient/List/main.go b/internal/generated/snippets/compute/apiv1/ZonesClient/List/main.go index 1d5a55257bdc..59e67ff380e8 100644 --- a/internal/generated/snippets/compute/apiv1/ZonesClient/List/main.go +++ b/internal/generated/snippets/compute/apiv1/ZonesClient/List/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/compute/apiv1/snippet_metadata.google.cloud.compute.v1.json b/internal/generated/snippets/compute/apiv1/snippet_metadata.google.cloud.compute.v1.json index 06884439d840..58dfb3139017 100644 --- a/internal/generated/snippets/compute/apiv1/snippet_metadata.google.cloud.compute.v1.json +++ b/internal/generated/snippets/compute/apiv1/snippet_metadata.google.cloud.compute.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/compute/apiv1", - "version": "1.31.0", + "version": "1.31.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/confidentialcomputing/apiv1/Client/CreateChallenge/main.go b/internal/generated/snippets/confidentialcomputing/apiv1/Client/CreateChallenge/main.go index 3be322b5eec9..13ba5db114df 100644 --- a/internal/generated/snippets/confidentialcomputing/apiv1/Client/CreateChallenge/main.go +++ b/internal/generated/snippets/confidentialcomputing/apiv1/Client/CreateChallenge/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/confidentialcomputing/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/confidentialcomputing/apiv1/Client/GetLocation/main.go index 82422d5e435f..b1d7f473902a 100644 --- a/internal/generated/snippets/confidentialcomputing/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/confidentialcomputing/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/confidentialcomputing/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/confidentialcomputing/apiv1/Client/ListLocations/main.go index 3a604866f902..c93bbfb0f3ed 100644 --- a/internal/generated/snippets/confidentialcomputing/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/confidentialcomputing/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/confidentialcomputing/apiv1/Client/VerifyAttestation/main.go b/internal/generated/snippets/confidentialcomputing/apiv1/Client/VerifyAttestation/main.go index 7cf2289b9e0a..3cb15e9497a5 100644 --- a/internal/generated/snippets/confidentialcomputing/apiv1/Client/VerifyAttestation/main.go +++ b/internal/generated/snippets/confidentialcomputing/apiv1/Client/VerifyAttestation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/confidentialcomputing/apiv1/snippet_metadata.google.cloud.confidentialcomputing.v1.json b/internal/generated/snippets/confidentialcomputing/apiv1/snippet_metadata.google.cloud.confidentialcomputing.v1.json index 4e5db6177d1c..53670875c596 100644 --- a/internal/generated/snippets/confidentialcomputing/apiv1/snippet_metadata.google.cloud.confidentialcomputing.v1.json +++ b/internal/generated/snippets/confidentialcomputing/apiv1/snippet_metadata.google.cloud.confidentialcomputing.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/confidentialcomputing/apiv1", - "version": "1.8.0", + "version": "1.8.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/confidentialcomputing/apiv1alpha1/Client/CreateChallenge/main.go b/internal/generated/snippets/confidentialcomputing/apiv1alpha1/Client/CreateChallenge/main.go index 56c5742a1081..7bf7cfbd9b1d 100644 --- a/internal/generated/snippets/confidentialcomputing/apiv1alpha1/Client/CreateChallenge/main.go +++ b/internal/generated/snippets/confidentialcomputing/apiv1alpha1/Client/CreateChallenge/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/confidentialcomputing/apiv1alpha1/Client/GetLocation/main.go b/internal/generated/snippets/confidentialcomputing/apiv1alpha1/Client/GetLocation/main.go index ddc7ab137230..2a48beb2c213 100644 --- a/internal/generated/snippets/confidentialcomputing/apiv1alpha1/Client/GetLocation/main.go +++ b/internal/generated/snippets/confidentialcomputing/apiv1alpha1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/confidentialcomputing/apiv1alpha1/Client/ListLocations/main.go b/internal/generated/snippets/confidentialcomputing/apiv1alpha1/Client/ListLocations/main.go index 3fa7c1718b93..182289fd809e 100644 --- a/internal/generated/snippets/confidentialcomputing/apiv1alpha1/Client/ListLocations/main.go +++ b/internal/generated/snippets/confidentialcomputing/apiv1alpha1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/confidentialcomputing/apiv1alpha1/Client/VerifyAttestation/main.go b/internal/generated/snippets/confidentialcomputing/apiv1alpha1/Client/VerifyAttestation/main.go index 8bb0c5c06907..2af20ae7d62c 100644 --- a/internal/generated/snippets/confidentialcomputing/apiv1alpha1/Client/VerifyAttestation/main.go +++ b/internal/generated/snippets/confidentialcomputing/apiv1alpha1/Client/VerifyAttestation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/confidentialcomputing/apiv1alpha1/snippet_metadata.google.cloud.confidentialcomputing.v1alpha1.json b/internal/generated/snippets/confidentialcomputing/apiv1alpha1/snippet_metadata.google.cloud.confidentialcomputing.v1alpha1.json index bf660b59e9d8..aee312d0a9a2 100644 --- a/internal/generated/snippets/confidentialcomputing/apiv1alpha1/snippet_metadata.google.cloud.confidentialcomputing.v1alpha1.json +++ b/internal/generated/snippets/confidentialcomputing/apiv1alpha1/snippet_metadata.google.cloud.confidentialcomputing.v1alpha1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/confidentialcomputing/apiv1alpha1", - "version": "1.8.0", + "version": "1.8.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/config/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/config/apiv1/Client/CancelOperation/main.go index 993fa4c97406..c76faa3bd309 100644 --- a/internal/generated/snippets/config/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/config/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/CreateDeployment/main.go b/internal/generated/snippets/config/apiv1/Client/CreateDeployment/main.go index 9051af5d9889..942a6670af83 100644 --- a/internal/generated/snippets/config/apiv1/Client/CreateDeployment/main.go +++ b/internal/generated/snippets/config/apiv1/Client/CreateDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/CreatePreview/main.go b/internal/generated/snippets/config/apiv1/Client/CreatePreview/main.go index 7d4ae8504d6d..0e1d084f84ba 100644 --- a/internal/generated/snippets/config/apiv1/Client/CreatePreview/main.go +++ b/internal/generated/snippets/config/apiv1/Client/CreatePreview/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/DeleteDeployment/main.go b/internal/generated/snippets/config/apiv1/Client/DeleteDeployment/main.go index fa5b128e5404..7a0c8c0ca6a3 100644 --- a/internal/generated/snippets/config/apiv1/Client/DeleteDeployment/main.go +++ b/internal/generated/snippets/config/apiv1/Client/DeleteDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/config/apiv1/Client/DeleteOperation/main.go index 6888855e695f..20372f7d6053 100644 --- a/internal/generated/snippets/config/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/config/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/DeletePreview/main.go b/internal/generated/snippets/config/apiv1/Client/DeletePreview/main.go index 46ddc59da0a5..70a73f2424cd 100644 --- a/internal/generated/snippets/config/apiv1/Client/DeletePreview/main.go +++ b/internal/generated/snippets/config/apiv1/Client/DeletePreview/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/DeleteStatefile/main.go b/internal/generated/snippets/config/apiv1/Client/DeleteStatefile/main.go index 948f7104405b..afc0178edef8 100644 --- a/internal/generated/snippets/config/apiv1/Client/DeleteStatefile/main.go +++ b/internal/generated/snippets/config/apiv1/Client/DeleteStatefile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/ExportDeploymentStatefile/main.go b/internal/generated/snippets/config/apiv1/Client/ExportDeploymentStatefile/main.go index 4db8e7dc6c31..bcde21115aba 100644 --- a/internal/generated/snippets/config/apiv1/Client/ExportDeploymentStatefile/main.go +++ b/internal/generated/snippets/config/apiv1/Client/ExportDeploymentStatefile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/ExportLockInfo/main.go b/internal/generated/snippets/config/apiv1/Client/ExportLockInfo/main.go index 5b2b85905753..feb9945c78a3 100644 --- a/internal/generated/snippets/config/apiv1/Client/ExportLockInfo/main.go +++ b/internal/generated/snippets/config/apiv1/Client/ExportLockInfo/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/ExportPreviewResult/main.go b/internal/generated/snippets/config/apiv1/Client/ExportPreviewResult/main.go index 008da06b398b..a0378e1f4c91 100644 --- a/internal/generated/snippets/config/apiv1/Client/ExportPreviewResult/main.go +++ b/internal/generated/snippets/config/apiv1/Client/ExportPreviewResult/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/ExportRevisionStatefile/main.go b/internal/generated/snippets/config/apiv1/Client/ExportRevisionStatefile/main.go index 72da1e89199f..52c666fad532 100644 --- a/internal/generated/snippets/config/apiv1/Client/ExportRevisionStatefile/main.go +++ b/internal/generated/snippets/config/apiv1/Client/ExportRevisionStatefile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/GetDeployment/main.go b/internal/generated/snippets/config/apiv1/Client/GetDeployment/main.go index 05cd82a167a5..4b57eb2d63dd 100644 --- a/internal/generated/snippets/config/apiv1/Client/GetDeployment/main.go +++ b/internal/generated/snippets/config/apiv1/Client/GetDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/GetIamPolicy/main.go b/internal/generated/snippets/config/apiv1/Client/GetIamPolicy/main.go index dd6928e8f393..4fdc47985b41 100644 --- a/internal/generated/snippets/config/apiv1/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/config/apiv1/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/config/apiv1/Client/GetLocation/main.go index 09c987e6d1d7..f50e68711df6 100644 --- a/internal/generated/snippets/config/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/config/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/config/apiv1/Client/GetOperation/main.go index 3fddb4ab8002..dc15c2ea0f48 100644 --- a/internal/generated/snippets/config/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/config/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/GetPreview/main.go b/internal/generated/snippets/config/apiv1/Client/GetPreview/main.go index 6d7b71b53ca8..05f4a5123aeb 100644 --- a/internal/generated/snippets/config/apiv1/Client/GetPreview/main.go +++ b/internal/generated/snippets/config/apiv1/Client/GetPreview/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/GetResource/main.go b/internal/generated/snippets/config/apiv1/Client/GetResource/main.go index 18c4da3dc57e..a27a1a993a8b 100644 --- a/internal/generated/snippets/config/apiv1/Client/GetResource/main.go +++ b/internal/generated/snippets/config/apiv1/Client/GetResource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/GetRevision/main.go b/internal/generated/snippets/config/apiv1/Client/GetRevision/main.go index bb665d13b5de..73eceeb60ae2 100644 --- a/internal/generated/snippets/config/apiv1/Client/GetRevision/main.go +++ b/internal/generated/snippets/config/apiv1/Client/GetRevision/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/GetTerraformVersion/main.go b/internal/generated/snippets/config/apiv1/Client/GetTerraformVersion/main.go index f043e02a1388..ff978b67f49a 100644 --- a/internal/generated/snippets/config/apiv1/Client/GetTerraformVersion/main.go +++ b/internal/generated/snippets/config/apiv1/Client/GetTerraformVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/ImportStatefile/main.go b/internal/generated/snippets/config/apiv1/Client/ImportStatefile/main.go index 60908027cdb1..7e3fab22f62c 100644 --- a/internal/generated/snippets/config/apiv1/Client/ImportStatefile/main.go +++ b/internal/generated/snippets/config/apiv1/Client/ImportStatefile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/ListDeployments/main.go b/internal/generated/snippets/config/apiv1/Client/ListDeployments/main.go index 45b6b4387c92..209bb8ad97bd 100644 --- a/internal/generated/snippets/config/apiv1/Client/ListDeployments/main.go +++ b/internal/generated/snippets/config/apiv1/Client/ListDeployments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/config/apiv1/Client/ListLocations/main.go index f9e12bbda564..85ff37158f7a 100644 --- a/internal/generated/snippets/config/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/config/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/config/apiv1/Client/ListOperations/main.go index dfd9b8f08a3e..42d40edb2aeb 100644 --- a/internal/generated/snippets/config/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/config/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/ListPreviews/main.go b/internal/generated/snippets/config/apiv1/Client/ListPreviews/main.go index ef09a84c6eee..f82a5dcc4658 100644 --- a/internal/generated/snippets/config/apiv1/Client/ListPreviews/main.go +++ b/internal/generated/snippets/config/apiv1/Client/ListPreviews/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/ListResources/main.go b/internal/generated/snippets/config/apiv1/Client/ListResources/main.go index e82ede8b822a..061f87a538ca 100644 --- a/internal/generated/snippets/config/apiv1/Client/ListResources/main.go +++ b/internal/generated/snippets/config/apiv1/Client/ListResources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/ListRevisions/main.go b/internal/generated/snippets/config/apiv1/Client/ListRevisions/main.go index 0277493accfd..4fc31c6a53c5 100644 --- a/internal/generated/snippets/config/apiv1/Client/ListRevisions/main.go +++ b/internal/generated/snippets/config/apiv1/Client/ListRevisions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/ListTerraformVersions/main.go b/internal/generated/snippets/config/apiv1/Client/ListTerraformVersions/main.go index 519e0203d382..6916a99bced2 100644 --- a/internal/generated/snippets/config/apiv1/Client/ListTerraformVersions/main.go +++ b/internal/generated/snippets/config/apiv1/Client/ListTerraformVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/LockDeployment/main.go b/internal/generated/snippets/config/apiv1/Client/LockDeployment/main.go index 32455f536151..cd14c452ba1e 100644 --- a/internal/generated/snippets/config/apiv1/Client/LockDeployment/main.go +++ b/internal/generated/snippets/config/apiv1/Client/LockDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/SetIamPolicy/main.go b/internal/generated/snippets/config/apiv1/Client/SetIamPolicy/main.go index ac167e1a22d1..432b7bb13ac4 100644 --- a/internal/generated/snippets/config/apiv1/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/config/apiv1/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/TestIamPermissions/main.go b/internal/generated/snippets/config/apiv1/Client/TestIamPermissions/main.go index 1aaa3077fca8..579b1b0d3410 100644 --- a/internal/generated/snippets/config/apiv1/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/config/apiv1/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/UnlockDeployment/main.go b/internal/generated/snippets/config/apiv1/Client/UnlockDeployment/main.go index 5912be5d8920..12a38b881d5a 100644 --- a/internal/generated/snippets/config/apiv1/Client/UnlockDeployment/main.go +++ b/internal/generated/snippets/config/apiv1/Client/UnlockDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/Client/UpdateDeployment/main.go b/internal/generated/snippets/config/apiv1/Client/UpdateDeployment/main.go index db132615bc87..e553748ee14d 100644 --- a/internal/generated/snippets/config/apiv1/Client/UpdateDeployment/main.go +++ b/internal/generated/snippets/config/apiv1/Client/UpdateDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/config/apiv1/snippet_metadata.google.cloud.config.v1.json b/internal/generated/snippets/config/apiv1/snippet_metadata.google.cloud.config.v1.json index 8ce521232193..c4cb59c1d8d1 100644 --- a/internal/generated/snippets/config/apiv1/snippet_metadata.google.cloud.config.v1.json +++ b/internal/generated/snippets/config/apiv1/snippet_metadata.google.cloud.config.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/config/apiv1", - "version": "1.2.0", + "version": "1.2.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/BulkAnalyzeConversations/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/BulkAnalyzeConversations/main.go index b8e191617586..997abae1dfe2 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/BulkAnalyzeConversations/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/BulkAnalyzeConversations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/BulkDeleteConversations/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/BulkDeleteConversations/main.go index 494d0dd74a0c..4735b670f0b9 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/BulkDeleteConversations/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/BulkDeleteConversations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/BulkDownloadFeedbackLabels/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/BulkDownloadFeedbackLabels/main.go index ef5444c8a843..f496006c091e 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/BulkDownloadFeedbackLabels/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/BulkDownloadFeedbackLabels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/BulkUploadFeedbackLabels/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/BulkUploadFeedbackLabels/main.go index 21ccbddf859e..844f4a2c5745 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/BulkUploadFeedbackLabels/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/BulkUploadFeedbackLabels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/CalculateIssueModelStats/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/CalculateIssueModelStats/main.go index 12da82ff9cd4..1bccd9c5b6a0 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/CalculateIssueModelStats/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/CalculateIssueModelStats/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/CalculateStats/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/CalculateStats/main.go index 22a92bf4b049..0e35c90ae370 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/CalculateStats/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/CalculateStats/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/CancelOperation/main.go index b26f7652953f..4a94adf81ce1 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateAnalysis/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateAnalysis/main.go index a47d9a248d75..bb981167279f 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateAnalysis/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateAnalysis/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateAnalysisRule/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateAnalysisRule/main.go index 872f96e0555d..963d9ea34d75 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateAnalysisRule/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateAnalysisRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateConversation/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateConversation/main.go index 3488170262f2..8155b79a14c3 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateConversation/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateConversation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateFeedbackLabel/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateFeedbackLabel/main.go index bb11e70b6c9c..c93bd6483ef4 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateFeedbackLabel/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateFeedbackLabel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateIssueModel/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateIssueModel/main.go index 8af8913c3e55..1f644ae8ea75 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateIssueModel/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateIssueModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreatePhraseMatcher/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreatePhraseMatcher/main.go index 4370f3d12f72..bdb7d3714e0c 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreatePhraseMatcher/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreatePhraseMatcher/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateQaQuestion/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateQaQuestion/main.go index 88594e5fecb4..a8c5091fe2a0 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateQaQuestion/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateQaQuestion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateQaScorecard/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateQaScorecard/main.go index 6a7d1e834f0d..2a2bd454ef19 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateQaScorecard/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateQaScorecard/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateQaScorecardRevision/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateQaScorecardRevision/main.go index 97a0f6a02b8a..b382364f411a 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateQaScorecardRevision/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateQaScorecardRevision/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateView/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateView/main.go index 9ad72e8f573b..2a9a31b6f53e 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateView/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/CreateView/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteAnalysis/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteAnalysis/main.go index 39d32493903f..c099ae3b844e 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteAnalysis/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteAnalysis/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteAnalysisRule/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteAnalysisRule/main.go index 761850508cde..603dfe34847c 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteAnalysisRule/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteAnalysisRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteConversation/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteConversation/main.go index 80c35120b7a5..94acac7d50fa 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteConversation/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteConversation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteFeedbackLabel/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteFeedbackLabel/main.go index 3b41e2c65382..1d321870a3da 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteFeedbackLabel/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteFeedbackLabel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteIssue/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteIssue/main.go index e26b2ee080cd..71a2c7bca5a2 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteIssue/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteIssue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteIssueModel/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteIssueModel/main.go index e19a4850b2eb..db84d9d47075 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteIssueModel/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteIssueModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeletePhraseMatcher/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeletePhraseMatcher/main.go index f997e739daca..f51d861a788c 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeletePhraseMatcher/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeletePhraseMatcher/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteQaQuestion/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteQaQuestion/main.go index 6441f1195df3..37c9ee598707 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteQaQuestion/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteQaQuestion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteQaScorecard/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteQaScorecard/main.go index 11c99eb7548a..010e4a30115f 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteQaScorecard/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteQaScorecard/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteQaScorecardRevision/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteQaScorecardRevision/main.go index 08142684723c..e215b5abfc81 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteQaScorecardRevision/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteQaScorecardRevision/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteView/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteView/main.go index 56f78b4695df..9730834ac268 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteView/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeleteView/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeployIssueModel/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeployIssueModel/main.go index 69ab5048b4d9..55afc4d08c56 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeployIssueModel/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeployIssueModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeployQaScorecardRevision/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeployQaScorecardRevision/main.go index fa6ac4931b3b..53ee1b9055a4 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeployQaScorecardRevision/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/DeployQaScorecardRevision/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ExportInsightsData/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ExportInsightsData/main.go index b7820704870a..3369ff64e4b3 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ExportInsightsData/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ExportInsightsData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ExportIssueModel/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ExportIssueModel/main.go index 97345de4aefc..253a6ee08f67 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ExportIssueModel/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ExportIssueModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetAnalysis/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetAnalysis/main.go index 3879a81b6ec6..feddf30689d8 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetAnalysis/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetAnalysis/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetAnalysisRule/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetAnalysisRule/main.go index 7afe54b1750a..8ffe9957fc75 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetAnalysisRule/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetAnalysisRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetConversation/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetConversation/main.go index aa7f9789cd37..bced896c7086 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetConversation/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetConversation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetEncryptionSpec/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetEncryptionSpec/main.go index 6c0f3e26da72..a7962bf7fb17 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetEncryptionSpec/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetEncryptionSpec/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetFeedbackLabel/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetFeedbackLabel/main.go index 3a8dffa3214d..daa9735e5d29 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetFeedbackLabel/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetFeedbackLabel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetIssue/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetIssue/main.go index 5c3ec55ed5de..8df070400c26 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetIssue/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetIssue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetIssueModel/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetIssueModel/main.go index d5f74ee88944..5f1e6415c8e5 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetIssueModel/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetIssueModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetOperation/main.go index 7e59ed41e99d..3e557ff2441e 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetPhraseMatcher/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetPhraseMatcher/main.go index 94bfcf8f2b61..210c7bcb020f 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetPhraseMatcher/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetPhraseMatcher/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetQaQuestion/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetQaQuestion/main.go index 4e2445512470..998256d3bb04 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetQaQuestion/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetQaQuestion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetQaScorecard/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetQaScorecard/main.go index 0fb57d52f60f..9150ba50b54a 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetQaScorecard/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetQaScorecard/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetQaScorecardRevision/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetQaScorecardRevision/main.go index f88283e83158..f13dbf63ecdb 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetQaScorecardRevision/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetQaScorecardRevision/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetSettings/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetSettings/main.go index 0632ae34fa52..fde70340a3ed 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetSettings/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetView/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetView/main.go index 7a6f177bfc9d..23ed3313249d 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetView/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/GetView/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ImportIssueModel/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ImportIssueModel/main.go index b39609fbe991..9fc446ddaba3 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ImportIssueModel/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ImportIssueModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/IngestConversations/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/IngestConversations/main.go index f55f992a8744..27a7e53f5d21 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/IngestConversations/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/IngestConversations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/InitializeEncryptionSpec/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/InitializeEncryptionSpec/main.go index 5ca884d10316..a5dcb0a3e126 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/InitializeEncryptionSpec/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/InitializeEncryptionSpec/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListAllFeedbackLabels/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListAllFeedbackLabels/main.go index 94dc9dfdf2d4..71ebbf467ea2 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListAllFeedbackLabels/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListAllFeedbackLabels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListAnalyses/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListAnalyses/main.go index 9f43ff65276b..e4992aed4eb5 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListAnalyses/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListAnalyses/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListAnalysisRules/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListAnalysisRules/main.go index 882fc0b5f234..44bb0375afe5 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListAnalysisRules/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListAnalysisRules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListConversations/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListConversations/main.go index 6b84bba00d51..d222c06e4ec1 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListConversations/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListConversations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListFeedbackLabels/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListFeedbackLabels/main.go index 6aff095a3435..359b5781df05 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListFeedbackLabels/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListFeedbackLabels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListIssueModels/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListIssueModels/main.go index faa13e305734..79e3de3cce28 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListIssueModels/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListIssueModels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListIssues/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListIssues/main.go index 3f967588ff29..5a229ee15bd1 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListIssues/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListIssues/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListOperations/main.go index e1c6d963b58b..e805484f7974 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListPhraseMatchers/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListPhraseMatchers/main.go index e53408a29959..0b9bd627ad2f 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListPhraseMatchers/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListPhraseMatchers/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListQaQuestions/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListQaQuestions/main.go index d95c2af72cd1..60d678deff04 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListQaQuestions/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListQaQuestions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListQaScorecardRevisions/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListQaScorecardRevisions/main.go index b325025c4bca..c63732f5161c 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListQaScorecardRevisions/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListQaScorecardRevisions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListQaScorecards/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListQaScorecards/main.go index c316215dea2f..44baea773aca 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListQaScorecards/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListQaScorecards/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListViews/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListViews/main.go index 82946846b4cc..b37a400612b4 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListViews/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/ListViews/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/QueryMetrics/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/QueryMetrics/main.go index 8b768620f5a7..45da323f3b36 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/QueryMetrics/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/QueryMetrics/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/TuneQaScorecardRevision/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/TuneQaScorecardRevision/main.go index 21e4b549cc06..04bda797b150 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/TuneQaScorecardRevision/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/TuneQaScorecardRevision/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/UndeployIssueModel/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/UndeployIssueModel/main.go index bf478bf44a1d..b170990c0053 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/UndeployIssueModel/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/UndeployIssueModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/UndeployQaScorecardRevision/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/UndeployQaScorecardRevision/main.go index fd11e24b5e22..a9af70fb949d 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/UndeployQaScorecardRevision/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/UndeployQaScorecardRevision/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateAnalysisRule/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateAnalysisRule/main.go index e8a356d608aa..c4b03c500e9a 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateAnalysisRule/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateAnalysisRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateConversation/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateConversation/main.go index d7c7d7effb42..e5ea697881f1 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateConversation/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateConversation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateFeedbackLabel/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateFeedbackLabel/main.go index 7c7e5ee44932..6cedb329fbd2 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateFeedbackLabel/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateFeedbackLabel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateIssue/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateIssue/main.go index d75f0a928dd1..8adb175fc741 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateIssue/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateIssue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateIssueModel/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateIssueModel/main.go index cf838e5b3c42..53c413160ec1 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateIssueModel/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateIssueModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdatePhraseMatcher/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdatePhraseMatcher/main.go index e604532a2d08..d79b4a0aec55 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdatePhraseMatcher/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdatePhraseMatcher/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateQaQuestion/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateQaQuestion/main.go index 291a2b2c728b..e0c3232943e5 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateQaQuestion/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateQaQuestion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateQaScorecard/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateQaScorecard/main.go index 6ed51625ea05..55edd350e477 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateQaScorecard/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateQaScorecard/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateSettings/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateSettings/main.go index b19dacd76861..7cbe57efa41e 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateSettings/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateView/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateView/main.go index c58e26dee4ca..dc4ef169133a 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateView/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/UpdateView/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/Client/UploadConversation/main.go b/internal/generated/snippets/contactcenterinsights/apiv1/Client/UploadConversation/main.go index 4b30bb60cfea..e0dc0e1dd4c0 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/Client/UploadConversation/main.go +++ b/internal/generated/snippets/contactcenterinsights/apiv1/Client/UploadConversation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/contactcenterinsights/apiv1/snippet_metadata.google.cloud.contactcenterinsights.v1.json b/internal/generated/snippets/contactcenterinsights/apiv1/snippet_metadata.google.cloud.contactcenterinsights.v1.json index 49cddeb33a5a..13f9dcaa623f 100644 --- a/internal/generated/snippets/contactcenterinsights/apiv1/snippet_metadata.google.cloud.contactcenterinsights.v1.json +++ b/internal/generated/snippets/contactcenterinsights/apiv1/snippet_metadata.google.cloud.contactcenterinsights.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/contactcenterinsights/apiv1", - "version": "1.17.0", + "version": "1.17.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/CancelOperation/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/CancelOperation/main.go index 5bc22cbc329e..5a966946fa67 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/CancelOperation/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/CheckAutopilotCompatibility/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/CheckAutopilotCompatibility/main.go index 302e91daefd1..3ba94fb75a50 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/CheckAutopilotCompatibility/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/CheckAutopilotCompatibility/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/CompleteIPRotation/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/CompleteIPRotation/main.go index 6751ca6acb6b..8e7ab834207b 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/CompleteIPRotation/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/CompleteIPRotation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/CompleteNodePoolUpgrade/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/CompleteNodePoolUpgrade/main.go index df8963233c0c..df556fe78111 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/CompleteNodePoolUpgrade/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/CompleteNodePoolUpgrade/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/CreateCluster/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/CreateCluster/main.go index b2ce27473089..afda6d5e154a 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/CreateCluster/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/CreateCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/CreateNodePool/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/CreateNodePool/main.go index 14cf8962cc4f..a15fc9563698 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/CreateNodePool/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/CreateNodePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/DeleteCluster/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/DeleteCluster/main.go index 01e81f776be1..569904bb386e 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/DeleteCluster/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/DeleteCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/DeleteNodePool/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/DeleteNodePool/main.go index 8a6c972598b3..a214146a2c22 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/DeleteNodePool/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/DeleteNodePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/GetCluster/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/GetCluster/main.go index d665ecbad4ea..844626e7e3cc 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/GetCluster/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/GetCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/GetJSONWebKeys/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/GetJSONWebKeys/main.go index 831e57cdb9b1..31df920831c3 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/GetJSONWebKeys/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/GetJSONWebKeys/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/GetNodePool/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/GetNodePool/main.go index 7d918f3cf2bf..dc4fb4e770b7 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/GetNodePool/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/GetNodePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/GetOperation/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/GetOperation/main.go index 059e0ca00d5c..af7fcda5f7e3 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/GetOperation/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/GetServerConfig/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/GetServerConfig/main.go index 10b2897ba4e9..446341795dd9 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/GetServerConfig/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/GetServerConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/ListClusters/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/ListClusters/main.go index 95b555327072..c19a970bea37 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/ListClusters/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/ListClusters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/ListNodePools/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/ListNodePools/main.go index a199f5fc65ec..cead4585f18f 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/ListNodePools/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/ListNodePools/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/ListOperations/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/ListOperations/main.go index d27721f3a313..a99f6dc0877b 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/ListOperations/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/ListUsableSubnetworks/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/ListUsableSubnetworks/main.go index 1d45264b0cd0..3beb634e6c59 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/ListUsableSubnetworks/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/ListUsableSubnetworks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/RollbackNodePoolUpgrade/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/RollbackNodePoolUpgrade/main.go index 6d05c4277067..e76620d421a8 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/RollbackNodePoolUpgrade/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/RollbackNodePoolUpgrade/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetAddonsConfig/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetAddonsConfig/main.go index 80860085de7b..1291118f1fe3 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetAddonsConfig/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetAddonsConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetLabels/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetLabels/main.go index adc4083ac4a7..c14f785e7fb7 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetLabels/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetLabels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetLegacyAbac/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetLegacyAbac/main.go index 579051bf5593..1fe0492048ca 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetLegacyAbac/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetLegacyAbac/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetLocations/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetLocations/main.go index b5ae84957a8a..341efba1357f 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetLocations/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetLoggingService/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetLoggingService/main.go index 70ffd48f9441..4a5221b73ca0 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetLoggingService/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetLoggingService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetMaintenancePolicy/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetMaintenancePolicy/main.go index dc14c89772e4..debd74ccf118 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetMaintenancePolicy/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetMaintenancePolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetMasterAuth/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetMasterAuth/main.go index f48fb3e61d39..e718f6f8a22a 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetMasterAuth/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetMasterAuth/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetMonitoringService/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetMonitoringService/main.go index aed52d62ecfa..79ae3afbed78 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetMonitoringService/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetMonitoringService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetNetworkPolicy/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetNetworkPolicy/main.go index 8d4ba594fb0c..0a4b43a4fe4b 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetNetworkPolicy/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetNetworkPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetNodePoolAutoscaling/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetNodePoolAutoscaling/main.go index 4443ce7a4247..90cbf9710522 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetNodePoolAutoscaling/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetNodePoolAutoscaling/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetNodePoolManagement/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetNodePoolManagement/main.go index fba7a363c8df..dec5bcb2faa0 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetNodePoolManagement/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetNodePoolManagement/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetNodePoolSize/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetNodePoolSize/main.go index 5a065ff2c247..c4245342a74b 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetNodePoolSize/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/SetNodePoolSize/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/StartIPRotation/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/StartIPRotation/main.go index 9d1228939522..467be5e054a5 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/StartIPRotation/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/StartIPRotation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/UpdateCluster/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/UpdateCluster/main.go index 8466085597c0..b86ebf071ae1 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/UpdateCluster/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/UpdateCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/UpdateMaster/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/UpdateMaster/main.go index 12bbf4c5ba68..3728eb1a7b11 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/UpdateMaster/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/UpdateMaster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/ClusterManagerClient/UpdateNodePool/main.go b/internal/generated/snippets/container/apiv1/ClusterManagerClient/UpdateNodePool/main.go index 2ffff2755596..9f5858775deb 100644 --- a/internal/generated/snippets/container/apiv1/ClusterManagerClient/UpdateNodePool/main.go +++ b/internal/generated/snippets/container/apiv1/ClusterManagerClient/UpdateNodePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/container/apiv1/snippet_metadata.google.container.v1.json b/internal/generated/snippets/container/apiv1/snippet_metadata.google.container.v1.json index 531740734223..21e9d5b15c2c 100644 --- a/internal/generated/snippets/container/apiv1/snippet_metadata.google.container.v1.json +++ b/internal/generated/snippets/container/apiv1/snippet_metadata.google.container.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/container/apiv1", - "version": "1.42.0", + "version": "1.42.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/containeranalysis/apiv1beta1/ContainerAnalysisV1Beta1Client/ExportSBOM/main.go b/internal/generated/snippets/containeranalysis/apiv1beta1/ContainerAnalysisV1Beta1Client/ExportSBOM/main.go index f5e805cfc35c..5d1ee9d7cf34 100644 --- a/internal/generated/snippets/containeranalysis/apiv1beta1/ContainerAnalysisV1Beta1Client/ExportSBOM/main.go +++ b/internal/generated/snippets/containeranalysis/apiv1beta1/ContainerAnalysisV1Beta1Client/ExportSBOM/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/containeranalysis/apiv1beta1/ContainerAnalysisV1Beta1Client/GeneratePackagesSummary/main.go b/internal/generated/snippets/containeranalysis/apiv1beta1/ContainerAnalysisV1Beta1Client/GeneratePackagesSummary/main.go index 59b5bad73c9f..70a232d20a0a 100644 --- a/internal/generated/snippets/containeranalysis/apiv1beta1/ContainerAnalysisV1Beta1Client/GeneratePackagesSummary/main.go +++ b/internal/generated/snippets/containeranalysis/apiv1beta1/ContainerAnalysisV1Beta1Client/GeneratePackagesSummary/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/containeranalysis/apiv1beta1/ContainerAnalysisV1Beta1Client/GetIamPolicy/main.go b/internal/generated/snippets/containeranalysis/apiv1beta1/ContainerAnalysisV1Beta1Client/GetIamPolicy/main.go index 72c80ac47ccb..96c38bdb9cce 100644 --- a/internal/generated/snippets/containeranalysis/apiv1beta1/ContainerAnalysisV1Beta1Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/containeranalysis/apiv1beta1/ContainerAnalysisV1Beta1Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/containeranalysis/apiv1beta1/ContainerAnalysisV1Beta1Client/SetIamPolicy/main.go b/internal/generated/snippets/containeranalysis/apiv1beta1/ContainerAnalysisV1Beta1Client/SetIamPolicy/main.go index 528685d21b91..60bc902757a0 100644 --- a/internal/generated/snippets/containeranalysis/apiv1beta1/ContainerAnalysisV1Beta1Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/containeranalysis/apiv1beta1/ContainerAnalysisV1Beta1Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/containeranalysis/apiv1beta1/ContainerAnalysisV1Beta1Client/TestIamPermissions/main.go b/internal/generated/snippets/containeranalysis/apiv1beta1/ContainerAnalysisV1Beta1Client/TestIamPermissions/main.go index 69018c9d6e66..7d8bd58104bb 100644 --- a/internal/generated/snippets/containeranalysis/apiv1beta1/ContainerAnalysisV1Beta1Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/containeranalysis/apiv1beta1/ContainerAnalysisV1Beta1Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/BatchCreateNotes/main.go b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/BatchCreateNotes/main.go index 0e874c1cca6c..b7d1c935fadc 100644 --- a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/BatchCreateNotes/main.go +++ b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/BatchCreateNotes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/BatchCreateOccurrences/main.go b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/BatchCreateOccurrences/main.go index 41a62239c343..5699be903ee0 100644 --- a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/BatchCreateOccurrences/main.go +++ b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/BatchCreateOccurrences/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/CreateNote/main.go b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/CreateNote/main.go index e61ae96bf220..9f4f75e377bd 100644 --- a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/CreateNote/main.go +++ b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/CreateNote/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/CreateOccurrence/main.go b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/CreateOccurrence/main.go index 3b106d529fc6..f387e772855d 100644 --- a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/CreateOccurrence/main.go +++ b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/CreateOccurrence/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/DeleteNote/main.go b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/DeleteNote/main.go index 23e85da8d44c..0a9016020430 100644 --- a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/DeleteNote/main.go +++ b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/DeleteNote/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/DeleteOccurrence/main.go b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/DeleteOccurrence/main.go index bc15e887f2ef..8e2f964db54e 100644 --- a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/DeleteOccurrence/main.go +++ b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/DeleteOccurrence/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/GetNote/main.go b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/GetNote/main.go index 351ad597f3ac..6195fdb44b3c 100644 --- a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/GetNote/main.go +++ b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/GetNote/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/GetOccurrence/main.go b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/GetOccurrence/main.go index 879509a2e9bb..f27a690e33d1 100644 --- a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/GetOccurrence/main.go +++ b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/GetOccurrence/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/GetOccurrenceNote/main.go b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/GetOccurrenceNote/main.go index 8aaa7478e3f4..83f0b49c6dac 100644 --- a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/GetOccurrenceNote/main.go +++ b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/GetOccurrenceNote/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/GetVulnerabilityOccurrencesSummary/main.go b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/GetVulnerabilityOccurrencesSummary/main.go index bf37f31122d4..641c2aefa8bf 100644 --- a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/GetVulnerabilityOccurrencesSummary/main.go +++ b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/GetVulnerabilityOccurrencesSummary/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/ListNoteOccurrences/main.go b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/ListNoteOccurrences/main.go index dcab087b0ed0..97996cb778ca 100644 --- a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/ListNoteOccurrences/main.go +++ b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/ListNoteOccurrences/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/ListNotes/main.go b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/ListNotes/main.go index 74e3e22452e8..8eb0852c84fe 100644 --- a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/ListNotes/main.go +++ b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/ListNotes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/ListOccurrences/main.go b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/ListOccurrences/main.go index 009d2a742394..7edaec6c253a 100644 --- a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/ListOccurrences/main.go +++ b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/ListOccurrences/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/UpdateNote/main.go b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/UpdateNote/main.go index a72d26135dd6..3341c7b7c423 100644 --- a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/UpdateNote/main.go +++ b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/UpdateNote/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/UpdateOccurrence/main.go b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/UpdateOccurrence/main.go index 9dd514dd4df7..1927f03d0eaa 100644 --- a/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/UpdateOccurrence/main.go +++ b/internal/generated/snippets/containeranalysis/apiv1beta1/GrafeasV1Beta1Client/UpdateOccurrence/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/containeranalysis/apiv1beta1/snippet_metadata.google.devtools.containeranalysis.v1beta1.json b/internal/generated/snippets/containeranalysis/apiv1beta1/snippet_metadata.google.devtools.containeranalysis.v1beta1.json index 032529a94fd6..453cbbf26059 100644 --- a/internal/generated/snippets/containeranalysis/apiv1beta1/snippet_metadata.google.devtools.containeranalysis.v1beta1.json +++ b/internal/generated/snippets/containeranalysis/apiv1beta1/snippet_metadata.google.devtools.containeranalysis.v1beta1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/containeranalysis/apiv1beta1", - "version": "0.13.2", + "version": "0.13.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/CancelOperation/main.go index 323b714fb7bb..5ab9237cf8e4 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/CreateEntry/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/CreateEntry/main.go index 7e476f074fe3..444ec06a644f 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/CreateEntry/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/CreateEntry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/CreateEntryGroup/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/CreateEntryGroup/main.go index 0207b2d66937..a13be4af49bc 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/CreateEntryGroup/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/CreateEntryGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/CreateTag/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/CreateTag/main.go index eddda41ea682..f5f14b9b58b8 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/CreateTag/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/CreateTag/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/CreateTagTemplate/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/CreateTagTemplate/main.go index 3c9986325876..327a303ec889 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/CreateTagTemplate/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/CreateTagTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/CreateTagTemplateField/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/CreateTagTemplateField/main.go index e05d7cf61230..7657d5fddda2 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/CreateTagTemplateField/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/CreateTagTemplateField/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/DeleteEntry/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/DeleteEntry/main.go index fa68c62d3cb1..5899f100c05e 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/DeleteEntry/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/DeleteEntry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/DeleteEntryGroup/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/DeleteEntryGroup/main.go index 242fbb63ce93..e959815801fc 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/DeleteEntryGroup/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/DeleteEntryGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/DeleteOperation/main.go index e541ee671f5b..56189b3ba13d 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/DeleteTag/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/DeleteTag/main.go index f76351a1e0dd..6572d2a93e0c 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/DeleteTag/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/DeleteTag/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/DeleteTagTemplate/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/DeleteTagTemplate/main.go index c0b4dbd43287..646eba82c7d8 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/DeleteTagTemplate/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/DeleteTagTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/DeleteTagTemplateField/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/DeleteTagTemplateField/main.go index 9ba7a2019c36..ed8aefa1cb84 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/DeleteTagTemplateField/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/DeleteTagTemplateField/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/GetEntry/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/GetEntry/main.go index 7449bab62ac8..46319b2c5a17 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/GetEntry/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/GetEntry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/GetEntryGroup/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/GetEntryGroup/main.go index d4b7af75fcea..3927412ce7f7 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/GetEntryGroup/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/GetEntryGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/GetIamPolicy/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/GetIamPolicy/main.go index 399fb4c47ba2..51dc470aa923 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/GetOperation/main.go index 154e34414cc3..5e2e1e81eaaa 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/GetTagTemplate/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/GetTagTemplate/main.go index 0ed49f535d3f..c05672bcf6cc 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/GetTagTemplate/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/GetTagTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/ImportEntries/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/ImportEntries/main.go index c0fc28347a42..dbf25d150180 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/ImportEntries/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/ImportEntries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/ListEntries/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/ListEntries/main.go index b8d4cab8cf76..2056cea5fa1b 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/ListEntries/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/ListEntries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/ListEntryGroups/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/ListEntryGroups/main.go index 7308e3ee2eaa..8672a14d64f9 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/ListEntryGroups/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/ListEntryGroups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/ListOperations/main.go index 3d9cefb873bf..eb363fe83883 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/ListTags/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/ListTags/main.go index 09106e6b7f25..174c32784460 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/ListTags/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/ListTags/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/LookupEntry/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/LookupEntry/main.go index f265924c8ccc..1173dd3b9063 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/LookupEntry/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/LookupEntry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/ModifyEntryContacts/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/ModifyEntryContacts/main.go index 986f7483b1c5..3cfb598e8d20 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/ModifyEntryContacts/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/ModifyEntryContacts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/ModifyEntryOverview/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/ModifyEntryOverview/main.go index f660e8066358..1962671b5fde 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/ModifyEntryOverview/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/ModifyEntryOverview/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/ReconcileTags/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/ReconcileTags/main.go index 7c0b85a78d0a..d16bf877fc65 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/ReconcileTags/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/ReconcileTags/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/RenameTagTemplateField/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/RenameTagTemplateField/main.go index 0bdbb27b348a..f34b58d7237f 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/RenameTagTemplateField/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/RenameTagTemplateField/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/RenameTagTemplateFieldEnumValue/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/RenameTagTemplateFieldEnumValue/main.go index b73d92886a3e..3ff949039ed2 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/RenameTagTemplateFieldEnumValue/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/RenameTagTemplateFieldEnumValue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/RetrieveConfig/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/RetrieveConfig/main.go index b865b2d75258..27ce1f13f791 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/RetrieveConfig/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/RetrieveConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/RetrieveEffectiveConfig/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/RetrieveEffectiveConfig/main.go index 24bf9e9fa274..48bee1581f57 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/RetrieveEffectiveConfig/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/RetrieveEffectiveConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/SearchCatalog/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/SearchCatalog/main.go index 6d4cfe932e86..fc42e205648a 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/SearchCatalog/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/SearchCatalog/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/SetConfig/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/SetConfig/main.go index b8a24607c42e..426a09fdb897 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/SetConfig/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/SetConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/SetIamPolicy/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/SetIamPolicy/main.go index 2ef25c228748..52dace11bc69 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/StarEntry/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/StarEntry/main.go index 2182e2dc65ac..65ebe736c95b 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/StarEntry/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/StarEntry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/TestIamPermissions/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/TestIamPermissions/main.go index 3b4f85f01a75..d1bef46be3f7 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/UnstarEntry/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/UnstarEntry/main.go index 85068aaa8598..d72a856806c0 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/UnstarEntry/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/UnstarEntry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/UpdateEntry/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/UpdateEntry/main.go index 78a25c9fd447..0337110bf1cd 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/UpdateEntry/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/UpdateEntry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/UpdateEntryGroup/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/UpdateEntryGroup/main.go index 0283cddc1106..edf0f5aab00b 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/UpdateEntryGroup/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/UpdateEntryGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/UpdateTag/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/UpdateTag/main.go index 53ee0b7b60ef..304e9609574e 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/UpdateTag/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/UpdateTag/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/UpdateTagTemplate/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/UpdateTagTemplate/main.go index 88da4a9a4b20..ed036a636468 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/UpdateTagTemplate/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/UpdateTagTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/Client/UpdateTagTemplateField/main.go b/internal/generated/snippets/datacatalog/apiv1/Client/UpdateTagTemplateField/main.go index 67184b80fece..27d3d66d704b 100644 --- a/internal/generated/snippets/datacatalog/apiv1/Client/UpdateTagTemplateField/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/Client/UpdateTagTemplateField/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/CancelOperation/main.go b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/CancelOperation/main.go index aab25929d095..2993bf022275 100644 --- a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/CancelOperation/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/CreatePolicyTag/main.go b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/CreatePolicyTag/main.go index 38e65276c395..582ecef4cce2 100644 --- a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/CreatePolicyTag/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/CreatePolicyTag/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/CreateTaxonomy/main.go b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/CreateTaxonomy/main.go index 013164057d12..027a4a3d67d1 100644 --- a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/CreateTaxonomy/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/CreateTaxonomy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/DeleteOperation/main.go b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/DeleteOperation/main.go index 22f949c52c5d..8dfafc579944 100644 --- a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/DeleteOperation/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/DeletePolicyTag/main.go b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/DeletePolicyTag/main.go index be7ee83cbcc4..500b91ecbf68 100644 --- a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/DeletePolicyTag/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/DeletePolicyTag/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/DeleteTaxonomy/main.go b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/DeleteTaxonomy/main.go index fa634ec7e45e..4c5cc3312dca 100644 --- a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/DeleteTaxonomy/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/DeleteTaxonomy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/GetIamPolicy/main.go b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/GetIamPolicy/main.go index fe582ea96c0d..2f51f18a43df 100644 --- a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/GetOperation/main.go b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/GetOperation/main.go index 9639c0e81dd0..fe2f174c608e 100644 --- a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/GetOperation/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/GetPolicyTag/main.go b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/GetPolicyTag/main.go index 77ff022c954c..69188051dc9b 100644 --- a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/GetPolicyTag/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/GetPolicyTag/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/GetTaxonomy/main.go b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/GetTaxonomy/main.go index 6545d6cc179d..88ea9d0c37f8 100644 --- a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/GetTaxonomy/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/GetTaxonomy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/ListOperations/main.go b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/ListOperations/main.go index 3036e8bf6121..296b4f0e4cc6 100644 --- a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/ListOperations/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/ListPolicyTags/main.go b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/ListPolicyTags/main.go index 3aa12cc2d9d5..1a5fda391845 100644 --- a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/ListPolicyTags/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/ListPolicyTags/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/ListTaxonomies/main.go b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/ListTaxonomies/main.go index 224febe7d89c..b527343a386d 100644 --- a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/ListTaxonomies/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/ListTaxonomies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/SetIamPolicy/main.go b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/SetIamPolicy/main.go index 995a79d6502b..837da2579a61 100644 --- a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/TestIamPermissions/main.go b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/TestIamPermissions/main.go index 4c95808be870..42919838c52d 100644 --- a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/UpdatePolicyTag/main.go b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/UpdatePolicyTag/main.go index 3815f6925f84..bda832fbab55 100644 --- a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/UpdatePolicyTag/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/UpdatePolicyTag/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/UpdateTaxonomy/main.go b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/UpdateTaxonomy/main.go index 920c76910624..4b2ba831ed59 100644 --- a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/UpdateTaxonomy/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerClient/UpdateTaxonomy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerSerializationClient/CancelOperation/main.go b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerSerializationClient/CancelOperation/main.go index 2f5a4eeb1b54..a6aeff484040 100644 --- a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerSerializationClient/CancelOperation/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerSerializationClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerSerializationClient/DeleteOperation/main.go b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerSerializationClient/DeleteOperation/main.go index 1294a526cf48..5c7b5331161b 100644 --- a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerSerializationClient/DeleteOperation/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerSerializationClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerSerializationClient/ExportTaxonomies/main.go b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerSerializationClient/ExportTaxonomies/main.go index 6c1194995524..cb995d8a0f7c 100644 --- a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerSerializationClient/ExportTaxonomies/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerSerializationClient/ExportTaxonomies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerSerializationClient/GetOperation/main.go b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerSerializationClient/GetOperation/main.go index 2578859e9395..b9fdc7b33de0 100644 --- a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerSerializationClient/GetOperation/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerSerializationClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerSerializationClient/ImportTaxonomies/main.go b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerSerializationClient/ImportTaxonomies/main.go index a94b640f60f9..dd2054388a6f 100644 --- a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerSerializationClient/ImportTaxonomies/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerSerializationClient/ImportTaxonomies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerSerializationClient/ListOperations/main.go b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerSerializationClient/ListOperations/main.go index 4d6104ea2176..973d9d226e76 100644 --- a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerSerializationClient/ListOperations/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerSerializationClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerSerializationClient/ReplaceTaxonomy/main.go b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerSerializationClient/ReplaceTaxonomy/main.go index adfd24669b05..5fb632a1524d 100644 --- a/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerSerializationClient/ReplaceTaxonomy/main.go +++ b/internal/generated/snippets/datacatalog/apiv1/PolicyTagManagerSerializationClient/ReplaceTaxonomy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1/snippet_metadata.google.cloud.datacatalog.v1.json b/internal/generated/snippets/datacatalog/apiv1/snippet_metadata.google.cloud.datacatalog.v1.json index c55bf51e77f1..0bde98251392 100644 --- a/internal/generated/snippets/datacatalog/apiv1/snippet_metadata.google.cloud.datacatalog.v1.json +++ b/internal/generated/snippets/datacatalog/apiv1/snippet_metadata.google.cloud.datacatalog.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/datacatalog/apiv1", - "version": "1.24.1", + "version": "1.24.2", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/Client/CreateEntry/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/Client/CreateEntry/main.go index 503e6896284b..c61e510819be 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/Client/CreateEntry/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/Client/CreateEntry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/Client/CreateEntryGroup/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/Client/CreateEntryGroup/main.go index 5393d00fbd5b..cd8f8d1a21a7 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/Client/CreateEntryGroup/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/Client/CreateEntryGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/Client/CreateTag/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/Client/CreateTag/main.go index a896bd92da3e..a9b4a2fcb8a8 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/Client/CreateTag/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/Client/CreateTag/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/Client/CreateTagTemplate/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/Client/CreateTagTemplate/main.go index 08157aaa6479..95aaf3e86f99 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/Client/CreateTagTemplate/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/Client/CreateTagTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/Client/CreateTagTemplateField/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/Client/CreateTagTemplateField/main.go index 6f6200b3e895..02fa84a84964 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/Client/CreateTagTemplateField/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/Client/CreateTagTemplateField/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/Client/DeleteEntry/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/Client/DeleteEntry/main.go index 340b308d6ffa..e030c02fcbc9 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/Client/DeleteEntry/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/Client/DeleteEntry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/Client/DeleteEntryGroup/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/Client/DeleteEntryGroup/main.go index b374ac79776d..2df5348abe27 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/Client/DeleteEntryGroup/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/Client/DeleteEntryGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/Client/DeleteTag/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/Client/DeleteTag/main.go index 931ec64357aa..ce4558863419 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/Client/DeleteTag/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/Client/DeleteTag/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/Client/DeleteTagTemplate/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/Client/DeleteTagTemplate/main.go index de3790b81707..c0472f7efb47 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/Client/DeleteTagTemplate/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/Client/DeleteTagTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/Client/DeleteTagTemplateField/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/Client/DeleteTagTemplateField/main.go index a2ac92797c5c..c487ae558d4c 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/Client/DeleteTagTemplateField/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/Client/DeleteTagTemplateField/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/Client/GetEntry/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/Client/GetEntry/main.go index 1ad050d5726e..87417c091eb0 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/Client/GetEntry/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/Client/GetEntry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/Client/GetEntryGroup/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/Client/GetEntryGroup/main.go index b6d42b4dd358..e21ccd1efedb 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/Client/GetEntryGroup/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/Client/GetEntryGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/Client/GetIamPolicy/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/Client/GetIamPolicy/main.go index 2ff9af18d082..ed64f51d6c73 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/Client/GetTagTemplate/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/Client/GetTagTemplate/main.go index d6436cb0b133..dc154ec9a010 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/Client/GetTagTemplate/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/Client/GetTagTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/Client/ListEntries/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/Client/ListEntries/main.go index 229db8916845..a49007ba84bf 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/Client/ListEntries/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/Client/ListEntries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/Client/ListEntryGroups/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/Client/ListEntryGroups/main.go index f1b80aaccc2c..40605ec33acd 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/Client/ListEntryGroups/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/Client/ListEntryGroups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/Client/ListTags/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/Client/ListTags/main.go index c53acdac3328..b11fd48fcac0 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/Client/ListTags/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/Client/ListTags/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/Client/LookupEntry/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/Client/LookupEntry/main.go index 26a231441817..0542775820eb 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/Client/LookupEntry/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/Client/LookupEntry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/Client/RenameTagTemplateField/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/Client/RenameTagTemplateField/main.go index 1ea6c5636b52..0cb8c68a2ecd 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/Client/RenameTagTemplateField/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/Client/RenameTagTemplateField/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/Client/RenameTagTemplateFieldEnumValue/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/Client/RenameTagTemplateFieldEnumValue/main.go index 98501e4406ba..768255268fb3 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/Client/RenameTagTemplateFieldEnumValue/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/Client/RenameTagTemplateFieldEnumValue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/Client/SearchCatalog/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/Client/SearchCatalog/main.go index f97496a5607d..d4019aa2b8ca 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/Client/SearchCatalog/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/Client/SearchCatalog/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/Client/SetIamPolicy/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/Client/SetIamPolicy/main.go index 23ad2e85d33c..18caac2f60ed 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/Client/TestIamPermissions/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/Client/TestIamPermissions/main.go index 4ad9141bec55..ae1e06cb3d7f 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/Client/UpdateEntry/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/Client/UpdateEntry/main.go index 8c4b224f9664..14bb16f201d6 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/Client/UpdateEntry/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/Client/UpdateEntry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/Client/UpdateEntryGroup/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/Client/UpdateEntryGroup/main.go index 9de5a64af474..2913116104fb 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/Client/UpdateEntryGroup/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/Client/UpdateEntryGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/Client/UpdateTag/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/Client/UpdateTag/main.go index 3f31e17c5121..dd0f36514b3a 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/Client/UpdateTag/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/Client/UpdateTag/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/Client/UpdateTagTemplate/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/Client/UpdateTagTemplate/main.go index c4c3effb0b25..fb00303c0492 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/Client/UpdateTagTemplate/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/Client/UpdateTagTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/Client/UpdateTagTemplateField/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/Client/UpdateTagTemplateField/main.go index 6b0ec9fceaf7..ef3a04089778 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/Client/UpdateTagTemplateField/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/Client/UpdateTagTemplateField/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/CreatePolicyTag/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/CreatePolicyTag/main.go index d838479d5a83..c77654db9d6e 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/CreatePolicyTag/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/CreatePolicyTag/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/CreateTaxonomy/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/CreateTaxonomy/main.go index 1d1411f08a12..f923987cf282 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/CreateTaxonomy/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/CreateTaxonomy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/DeletePolicyTag/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/DeletePolicyTag/main.go index 1282206f5f69..25b4ea3f7820 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/DeletePolicyTag/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/DeletePolicyTag/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/DeleteTaxonomy/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/DeleteTaxonomy/main.go index 4fba2e605ee2..c026421b4e6c 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/DeleteTaxonomy/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/DeleteTaxonomy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/GetIamPolicy/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/GetIamPolicy/main.go index 923ace98b0ee..7be00a70704e 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/GetPolicyTag/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/GetPolicyTag/main.go index 33ec42aacc1b..630350e70ebd 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/GetPolicyTag/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/GetPolicyTag/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/GetTaxonomy/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/GetTaxonomy/main.go index 71bcc41939f7..371ecc1de0a7 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/GetTaxonomy/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/GetTaxonomy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/ListPolicyTags/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/ListPolicyTags/main.go index cca3326204df..e819946fc9ce 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/ListPolicyTags/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/ListPolicyTags/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/ListTaxonomies/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/ListTaxonomies/main.go index b91dfcd2b563..9698a807cdb2 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/ListTaxonomies/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/ListTaxonomies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/SetIamPolicy/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/SetIamPolicy/main.go index 9c2bb0159afc..8930c6ea2b8a 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/TestIamPermissions/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/TestIamPermissions/main.go index 388a1938ba56..091964197908 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/UpdatePolicyTag/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/UpdatePolicyTag/main.go index c77854e319c0..656465821006 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/UpdatePolicyTag/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/UpdatePolicyTag/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/UpdateTaxonomy/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/UpdateTaxonomy/main.go index d01859f035de..281aeb8c3591 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/UpdateTaxonomy/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerClient/UpdateTaxonomy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerSerializationClient/ExportTaxonomies/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerSerializationClient/ExportTaxonomies/main.go index 4368dbfbc4eb..89c663c77b5b 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerSerializationClient/ExportTaxonomies/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerSerializationClient/ExportTaxonomies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerSerializationClient/ImportTaxonomies/main.go b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerSerializationClient/ImportTaxonomies/main.go index 9e5ff25f383b..3fc19af5f68c 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerSerializationClient/ImportTaxonomies/main.go +++ b/internal/generated/snippets/datacatalog/apiv1beta1/PolicyTagManagerSerializationClient/ImportTaxonomies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/apiv1beta1/snippet_metadata.google.cloud.datacatalog.v1beta1.json b/internal/generated/snippets/datacatalog/apiv1beta1/snippet_metadata.google.cloud.datacatalog.v1beta1.json index e59d4e9002ab..393d80500755 100644 --- a/internal/generated/snippets/datacatalog/apiv1beta1/snippet_metadata.google.cloud.datacatalog.v1beta1.json +++ b/internal/generated/snippets/datacatalog/apiv1beta1/snippet_metadata.google.cloud.datacatalog.v1beta1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/datacatalog/apiv1beta1", - "version": "1.24.1", + "version": "1.24.2", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/BatchSearchLinkProcesses/main.go b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/BatchSearchLinkProcesses/main.go index 32a20c2d20fa..90de5388fbf1 100644 --- a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/BatchSearchLinkProcesses/main.go +++ b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/BatchSearchLinkProcesses/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/CancelOperation/main.go index 7d1f272efc6c..a7be78e9fc84 100644 --- a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/CreateLineageEvent/main.go b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/CreateLineageEvent/main.go index bf2c4dfc11c7..89ac9ca4a0d0 100644 --- a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/CreateLineageEvent/main.go +++ b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/CreateLineageEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/CreateProcess/main.go b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/CreateProcess/main.go index b49f5dae904f..a6bb0a608b10 100644 --- a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/CreateProcess/main.go +++ b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/CreateProcess/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/CreateRun/main.go b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/CreateRun/main.go index b6c12fab3af2..61639137b84c 100644 --- a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/CreateRun/main.go +++ b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/CreateRun/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/DeleteLineageEvent/main.go b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/DeleteLineageEvent/main.go index 0ef0915c0859..a73af69a748b 100644 --- a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/DeleteLineageEvent/main.go +++ b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/DeleteLineageEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/DeleteOperation/main.go index 266d19105cf6..ed806027b48a 100644 --- a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/DeleteProcess/main.go b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/DeleteProcess/main.go index e83626385efa..b4a9ef7939a6 100644 --- a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/DeleteProcess/main.go +++ b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/DeleteProcess/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/DeleteRun/main.go b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/DeleteRun/main.go index aa731937b504..3f3257b6b799 100644 --- a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/DeleteRun/main.go +++ b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/DeleteRun/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/GetLineageEvent/main.go b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/GetLineageEvent/main.go index d1168c003050..773d79b69f37 100644 --- a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/GetLineageEvent/main.go +++ b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/GetLineageEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/GetOperation/main.go index c4d5b5fdc469..e56a24daf6d5 100644 --- a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/GetProcess/main.go b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/GetProcess/main.go index 7cc95c2c7fb3..23dbc08d47f0 100644 --- a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/GetProcess/main.go +++ b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/GetProcess/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/GetRun/main.go b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/GetRun/main.go index 104f9d1d2d35..5969f0a1709c 100644 --- a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/GetRun/main.go +++ b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/GetRun/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/ListLineageEvents/main.go b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/ListLineageEvents/main.go index 921f8a80a800..583242529cab 100644 --- a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/ListLineageEvents/main.go +++ b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/ListLineageEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/ListOperations/main.go index 7f0b820775d4..572cdee93a2b 100644 --- a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/ListProcesses/main.go b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/ListProcesses/main.go index 6ef7dc515b2d..7f9a248801b1 100644 --- a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/ListProcesses/main.go +++ b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/ListProcesses/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/ListRuns/main.go b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/ListRuns/main.go index 8bcec7db48c0..75796ceb0aa2 100644 --- a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/ListRuns/main.go +++ b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/ListRuns/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/ProcessOpenLineageRunEvent/main.go b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/ProcessOpenLineageRunEvent/main.go index 5efbd0767aef..e2fb32654125 100644 --- a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/ProcessOpenLineageRunEvent/main.go +++ b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/ProcessOpenLineageRunEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/SearchLinks/main.go b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/SearchLinks/main.go index 87c3d927190e..4af4caf0ea6b 100644 --- a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/SearchLinks/main.go +++ b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/SearchLinks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/UpdateProcess/main.go b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/UpdateProcess/main.go index 3fef71677f03..9f9d287eb1e9 100644 --- a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/UpdateProcess/main.go +++ b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/UpdateProcess/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/UpdateRun/main.go b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/UpdateRun/main.go index c655f3ef3086..9599a2090e2b 100644 --- a/internal/generated/snippets/datacatalog/lineage/apiv1/Client/UpdateRun/main.go +++ b/internal/generated/snippets/datacatalog/lineage/apiv1/Client/UpdateRun/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datacatalog/lineage/apiv1/snippet_metadata.google.cloud.datacatalog.lineage.v1.json b/internal/generated/snippets/datacatalog/lineage/apiv1/snippet_metadata.google.cloud.datacatalog.lineage.v1.json index 48bb8907ab43..d73ee868b710 100644 --- a/internal/generated/snippets/datacatalog/lineage/apiv1/snippet_metadata.google.cloud.datacatalog.lineage.v1.json +++ b/internal/generated/snippets/datacatalog/lineage/apiv1/snippet_metadata.google.cloud.datacatalog.lineage.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/datacatalog/lineage/apiv1", - "version": "1.24.1", + "version": "1.24.2", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/dataflow/apiv1beta3/FlexTemplatesClient/LaunchFlexTemplate/main.go b/internal/generated/snippets/dataflow/apiv1beta3/FlexTemplatesClient/LaunchFlexTemplate/main.go index e6c1b185db9e..e66fa1333d0a 100644 --- a/internal/generated/snippets/dataflow/apiv1beta3/FlexTemplatesClient/LaunchFlexTemplate/main.go +++ b/internal/generated/snippets/dataflow/apiv1beta3/FlexTemplatesClient/LaunchFlexTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataflow/apiv1beta3/JobsV1Beta3Client/AggregatedListJobs/main.go b/internal/generated/snippets/dataflow/apiv1beta3/JobsV1Beta3Client/AggregatedListJobs/main.go index 00438ec4f274..f1a8695b2f74 100644 --- a/internal/generated/snippets/dataflow/apiv1beta3/JobsV1Beta3Client/AggregatedListJobs/main.go +++ b/internal/generated/snippets/dataflow/apiv1beta3/JobsV1Beta3Client/AggregatedListJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataflow/apiv1beta3/JobsV1Beta3Client/CheckActiveJobs/main.go b/internal/generated/snippets/dataflow/apiv1beta3/JobsV1Beta3Client/CheckActiveJobs/main.go index fb173c0a1ccc..745e17513a2f 100644 --- a/internal/generated/snippets/dataflow/apiv1beta3/JobsV1Beta3Client/CheckActiveJobs/main.go +++ b/internal/generated/snippets/dataflow/apiv1beta3/JobsV1Beta3Client/CheckActiveJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataflow/apiv1beta3/JobsV1Beta3Client/CreateJob/main.go b/internal/generated/snippets/dataflow/apiv1beta3/JobsV1Beta3Client/CreateJob/main.go index a4b5fe4337e8..12191b0433f5 100644 --- a/internal/generated/snippets/dataflow/apiv1beta3/JobsV1Beta3Client/CreateJob/main.go +++ b/internal/generated/snippets/dataflow/apiv1beta3/JobsV1Beta3Client/CreateJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataflow/apiv1beta3/JobsV1Beta3Client/GetJob/main.go b/internal/generated/snippets/dataflow/apiv1beta3/JobsV1Beta3Client/GetJob/main.go index 8f5885c72195..8128cf9199c6 100644 --- a/internal/generated/snippets/dataflow/apiv1beta3/JobsV1Beta3Client/GetJob/main.go +++ b/internal/generated/snippets/dataflow/apiv1beta3/JobsV1Beta3Client/GetJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataflow/apiv1beta3/JobsV1Beta3Client/ListJobs/main.go b/internal/generated/snippets/dataflow/apiv1beta3/JobsV1Beta3Client/ListJobs/main.go index 26ead881128c..f78e911f627e 100644 --- a/internal/generated/snippets/dataflow/apiv1beta3/JobsV1Beta3Client/ListJobs/main.go +++ b/internal/generated/snippets/dataflow/apiv1beta3/JobsV1Beta3Client/ListJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataflow/apiv1beta3/JobsV1Beta3Client/SnapshotJob/main.go b/internal/generated/snippets/dataflow/apiv1beta3/JobsV1Beta3Client/SnapshotJob/main.go index 904f5c378f64..473a95837da1 100644 --- a/internal/generated/snippets/dataflow/apiv1beta3/JobsV1Beta3Client/SnapshotJob/main.go +++ b/internal/generated/snippets/dataflow/apiv1beta3/JobsV1Beta3Client/SnapshotJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataflow/apiv1beta3/JobsV1Beta3Client/UpdateJob/main.go b/internal/generated/snippets/dataflow/apiv1beta3/JobsV1Beta3Client/UpdateJob/main.go index 4b688b249c97..2ecd98b6e7f9 100644 --- a/internal/generated/snippets/dataflow/apiv1beta3/JobsV1Beta3Client/UpdateJob/main.go +++ b/internal/generated/snippets/dataflow/apiv1beta3/JobsV1Beta3Client/UpdateJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataflow/apiv1beta3/MessagesV1Beta3Client/ListJobMessages/main.go b/internal/generated/snippets/dataflow/apiv1beta3/MessagesV1Beta3Client/ListJobMessages/main.go index a73d7ee1c695..736bd9244fa3 100644 --- a/internal/generated/snippets/dataflow/apiv1beta3/MessagesV1Beta3Client/ListJobMessages/main.go +++ b/internal/generated/snippets/dataflow/apiv1beta3/MessagesV1Beta3Client/ListJobMessages/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataflow/apiv1beta3/MetricsV1Beta3Client/GetJobExecutionDetails/main.go b/internal/generated/snippets/dataflow/apiv1beta3/MetricsV1Beta3Client/GetJobExecutionDetails/main.go index 928c88cd9a9b..27700781cc1d 100644 --- a/internal/generated/snippets/dataflow/apiv1beta3/MetricsV1Beta3Client/GetJobExecutionDetails/main.go +++ b/internal/generated/snippets/dataflow/apiv1beta3/MetricsV1Beta3Client/GetJobExecutionDetails/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataflow/apiv1beta3/MetricsV1Beta3Client/GetJobMetrics/main.go b/internal/generated/snippets/dataflow/apiv1beta3/MetricsV1Beta3Client/GetJobMetrics/main.go index 4460fa42900d..6178baed835e 100644 --- a/internal/generated/snippets/dataflow/apiv1beta3/MetricsV1Beta3Client/GetJobMetrics/main.go +++ b/internal/generated/snippets/dataflow/apiv1beta3/MetricsV1Beta3Client/GetJobMetrics/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataflow/apiv1beta3/MetricsV1Beta3Client/GetStageExecutionDetails/main.go b/internal/generated/snippets/dataflow/apiv1beta3/MetricsV1Beta3Client/GetStageExecutionDetails/main.go index 9e8507203b4f..6e673fb31943 100644 --- a/internal/generated/snippets/dataflow/apiv1beta3/MetricsV1Beta3Client/GetStageExecutionDetails/main.go +++ b/internal/generated/snippets/dataflow/apiv1beta3/MetricsV1Beta3Client/GetStageExecutionDetails/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataflow/apiv1beta3/SnapshotsV1Beta3Client/DeleteSnapshot/main.go b/internal/generated/snippets/dataflow/apiv1beta3/SnapshotsV1Beta3Client/DeleteSnapshot/main.go index 41c948204b91..c5bc90166021 100644 --- a/internal/generated/snippets/dataflow/apiv1beta3/SnapshotsV1Beta3Client/DeleteSnapshot/main.go +++ b/internal/generated/snippets/dataflow/apiv1beta3/SnapshotsV1Beta3Client/DeleteSnapshot/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataflow/apiv1beta3/SnapshotsV1Beta3Client/GetSnapshot/main.go b/internal/generated/snippets/dataflow/apiv1beta3/SnapshotsV1Beta3Client/GetSnapshot/main.go index 700ee3b03d2c..c20d27df6dce 100644 --- a/internal/generated/snippets/dataflow/apiv1beta3/SnapshotsV1Beta3Client/GetSnapshot/main.go +++ b/internal/generated/snippets/dataflow/apiv1beta3/SnapshotsV1Beta3Client/GetSnapshot/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataflow/apiv1beta3/SnapshotsV1Beta3Client/ListSnapshots/main.go b/internal/generated/snippets/dataflow/apiv1beta3/SnapshotsV1Beta3Client/ListSnapshots/main.go index 76a38ce6cddf..569d0e5bc8de 100644 --- a/internal/generated/snippets/dataflow/apiv1beta3/SnapshotsV1Beta3Client/ListSnapshots/main.go +++ b/internal/generated/snippets/dataflow/apiv1beta3/SnapshotsV1Beta3Client/ListSnapshots/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataflow/apiv1beta3/TemplatesClient/CreateJobFromTemplate/main.go b/internal/generated/snippets/dataflow/apiv1beta3/TemplatesClient/CreateJobFromTemplate/main.go index 23b02b5e2d26..f1fcb2834f7d 100644 --- a/internal/generated/snippets/dataflow/apiv1beta3/TemplatesClient/CreateJobFromTemplate/main.go +++ b/internal/generated/snippets/dataflow/apiv1beta3/TemplatesClient/CreateJobFromTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataflow/apiv1beta3/TemplatesClient/GetTemplate/main.go b/internal/generated/snippets/dataflow/apiv1beta3/TemplatesClient/GetTemplate/main.go index 629025a8c7cc..a2437cedbf3c 100644 --- a/internal/generated/snippets/dataflow/apiv1beta3/TemplatesClient/GetTemplate/main.go +++ b/internal/generated/snippets/dataflow/apiv1beta3/TemplatesClient/GetTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataflow/apiv1beta3/TemplatesClient/LaunchTemplate/main.go b/internal/generated/snippets/dataflow/apiv1beta3/TemplatesClient/LaunchTemplate/main.go index f890390de03d..849f6c67d138 100644 --- a/internal/generated/snippets/dataflow/apiv1beta3/TemplatesClient/LaunchTemplate/main.go +++ b/internal/generated/snippets/dataflow/apiv1beta3/TemplatesClient/LaunchTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/CancelWorkflowInvocation/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/CancelWorkflowInvocation/main.go index 78c5281e0758..47c7aa1ac675 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/CancelWorkflowInvocation/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/CancelWorkflowInvocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/CommitWorkspaceChanges/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/CommitWorkspaceChanges/main.go index a26f8afdb012..7c0df14ce897 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/CommitWorkspaceChanges/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/CommitWorkspaceChanges/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/CreateCompilationResult/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/CreateCompilationResult/main.go index dec4c3b095e6..400a473b6481 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/CreateCompilationResult/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/CreateCompilationResult/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/CreateRepository/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/CreateRepository/main.go index 5e451c4a92fe..0e0eaf7e661a 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/CreateRepository/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/CreateRepository/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/CreateWorkflowInvocation/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/CreateWorkflowInvocation/main.go index ae2bb9cccd96..a4b7aa31d0ec 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/CreateWorkflowInvocation/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/CreateWorkflowInvocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/CreateWorkspace/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/CreateWorkspace/main.go index 43177eb48f8f..c48958aa9da8 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/CreateWorkspace/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/CreateWorkspace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/DeleteRepository/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/DeleteRepository/main.go index 66dceead7bef..8cb2cde6ad9d 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/DeleteRepository/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/DeleteRepository/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/DeleteWorkflowInvocation/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/DeleteWorkflowInvocation/main.go index 7409969a63f5..8dffb08e0afc 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/DeleteWorkflowInvocation/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/DeleteWorkflowInvocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/DeleteWorkspace/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/DeleteWorkspace/main.go index c8e607386c90..fabdfca7c763 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/DeleteWorkspace/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/DeleteWorkspace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/FetchFileDiff/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/FetchFileDiff/main.go index 2a53bcee7284..c65482ec8346 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/FetchFileDiff/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/FetchFileDiff/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/FetchFileGitStatuses/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/FetchFileGitStatuses/main.go index 755f33db17a2..f5b496946610 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/FetchFileGitStatuses/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/FetchFileGitStatuses/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/FetchGitAheadBehind/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/FetchGitAheadBehind/main.go index 446448625f38..9fb6b19b4949 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/FetchGitAheadBehind/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/FetchGitAheadBehind/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/FetchRemoteBranches/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/FetchRemoteBranches/main.go index 8c486f653882..a8031e528cfd 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/FetchRemoteBranches/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/FetchRemoteBranches/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/GetCompilationResult/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/GetCompilationResult/main.go index d5ab662ceafe..8b9ceb6a8eb6 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/GetCompilationResult/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/GetCompilationResult/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/GetIamPolicy/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/GetIamPolicy/main.go index 616c8010dbcd..14a9e974be10 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/GetLocation/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/GetLocation/main.go index 13e764277791..f46c08439457 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/GetLocation/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/GetRepository/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/GetRepository/main.go index 96e6dff15d35..205bb179b06c 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/GetRepository/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/GetRepository/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/GetWorkflowInvocation/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/GetWorkflowInvocation/main.go index 1e022b81fc56..28d8eac73486 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/GetWorkflowInvocation/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/GetWorkflowInvocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/GetWorkspace/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/GetWorkspace/main.go index 91ddd692c4b6..87263be68a61 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/GetWorkspace/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/GetWorkspace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/InstallNpmPackages/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/InstallNpmPackages/main.go index c3ef469d4b50..1de18c849363 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/InstallNpmPackages/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/InstallNpmPackages/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/ListCompilationResults/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/ListCompilationResults/main.go index 57eca00e4de7..723eff91033b 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/ListCompilationResults/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/ListCompilationResults/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/ListLocations/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/ListLocations/main.go index 507ac30dc432..d005c8bbf1f8 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/ListLocations/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/ListRepositories/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/ListRepositories/main.go index 762e9514c085..16fc44e2c45c 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/ListRepositories/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/ListRepositories/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/ListWorkflowInvocations/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/ListWorkflowInvocations/main.go index b52928776bb0..fdfe4525fd5f 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/ListWorkflowInvocations/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/ListWorkflowInvocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/ListWorkspaces/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/ListWorkspaces/main.go index df08ca801012..38fa29828fd9 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/ListWorkspaces/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/ListWorkspaces/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/MakeDirectory/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/MakeDirectory/main.go index 72e9032fba1e..1b57468c2a38 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/MakeDirectory/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/MakeDirectory/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/MoveDirectory/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/MoveDirectory/main.go index e7f0f2016ff2..e2e130c5c7e4 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/MoveDirectory/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/MoveDirectory/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/MoveFile/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/MoveFile/main.go index 0f054320f7c1..ad3cde3ae6a7 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/MoveFile/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/MoveFile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/PullGitCommits/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/PullGitCommits/main.go index 85e23357b37a..a8a6dd22a97e 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/PullGitCommits/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/PullGitCommits/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/PushGitCommits/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/PushGitCommits/main.go index 3942adc0771d..e60a0c4da0b3 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/PushGitCommits/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/PushGitCommits/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/QueryCompilationResultActions/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/QueryCompilationResultActions/main.go index 7aa53440513f..a4a01976e074 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/QueryCompilationResultActions/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/QueryCompilationResultActions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/QueryDirectoryContents/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/QueryDirectoryContents/main.go index 7ee5e5f8299d..abad0e981cfd 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/QueryDirectoryContents/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/QueryDirectoryContents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/QueryWorkflowInvocationActions/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/QueryWorkflowInvocationActions/main.go index 5afca12a5649..8dc9c80bf058 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/QueryWorkflowInvocationActions/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/QueryWorkflowInvocationActions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/ReadFile/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/ReadFile/main.go index cc3e050bb62e..19d9a29b7777 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/ReadFile/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/ReadFile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/RemoveDirectory/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/RemoveDirectory/main.go index 799fa1daaa33..0dc1cff0e55b 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/RemoveDirectory/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/RemoveDirectory/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/RemoveFile/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/RemoveFile/main.go index c09d253a2449..3209e4828963 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/RemoveFile/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/RemoveFile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/ResetWorkspaceChanges/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/ResetWorkspaceChanges/main.go index a23cf6d4c7a4..e929a7b82274 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/ResetWorkspaceChanges/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/ResetWorkspaceChanges/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/SetIamPolicy/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/SetIamPolicy/main.go index 13f708cde2dc..1b571fa4c7c3 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/TestIamPermissions/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/TestIamPermissions/main.go index 81913742d085..b1e801cfa02b 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/UpdateRepository/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/UpdateRepository/main.go index a8a829943372..00e462c9b3e8 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/UpdateRepository/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/UpdateRepository/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/Client/WriteFile/main.go b/internal/generated/snippets/dataform/apiv1alpha2/Client/WriteFile/main.go index c62e8d834880..2a4c7c47cbce 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/Client/WriteFile/main.go +++ b/internal/generated/snippets/dataform/apiv1alpha2/Client/WriteFile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1alpha2/snippet_metadata.google.cloud.dataform.v1alpha2.json b/internal/generated/snippets/dataform/apiv1alpha2/snippet_metadata.google.cloud.dataform.v1alpha2.json index 0dfe62aa4d68..f4f0da827bc8 100644 --- a/internal/generated/snippets/dataform/apiv1alpha2/snippet_metadata.google.cloud.dataform.v1alpha2.json +++ b/internal/generated/snippets/dataform/apiv1alpha2/snippet_metadata.google.cloud.dataform.v1alpha2.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/dataform/apiv1alpha2", - "version": "0.10.2", + "version": "0.10.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/CancelWorkflowInvocation/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/CancelWorkflowInvocation/main.go index 81482b19fd55..feab3e2443c9 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/CancelWorkflowInvocation/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/CancelWorkflowInvocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/CommitRepositoryChanges/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/CommitRepositoryChanges/main.go index 1e06763b430e..867231fa06f6 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/CommitRepositoryChanges/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/CommitRepositoryChanges/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/CommitWorkspaceChanges/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/CommitWorkspaceChanges/main.go index f7f2a2044068..e9d2992e65c2 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/CommitWorkspaceChanges/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/CommitWorkspaceChanges/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/ComputeRepositoryAccessTokenStatus/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/ComputeRepositoryAccessTokenStatus/main.go index 636121c94cb9..c3803757b7b5 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/ComputeRepositoryAccessTokenStatus/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/ComputeRepositoryAccessTokenStatus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/CreateCompilationResult/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/CreateCompilationResult/main.go index ffbc0eb6abc6..80e69a06673d 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/CreateCompilationResult/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/CreateCompilationResult/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/CreateReleaseConfig/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/CreateReleaseConfig/main.go index cda1e0b8378b..f79ef90bc069 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/CreateReleaseConfig/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/CreateReleaseConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/CreateRepository/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/CreateRepository/main.go index e9034057bcde..2cc2a5db9a88 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/CreateRepository/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/CreateRepository/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/CreateWorkflowConfig/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/CreateWorkflowConfig/main.go index c4aabe870132..c3ae8f9ce7b7 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/CreateWorkflowConfig/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/CreateWorkflowConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/CreateWorkflowInvocation/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/CreateWorkflowInvocation/main.go index f8c636f1edfe..4412254fdf2c 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/CreateWorkflowInvocation/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/CreateWorkflowInvocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/CreateWorkspace/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/CreateWorkspace/main.go index cf3d79fc7907..747493b6c322 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/CreateWorkspace/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/CreateWorkspace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/DeleteReleaseConfig/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/DeleteReleaseConfig/main.go index e1167915d2f8..973ac6fd8bad 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/DeleteReleaseConfig/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/DeleteReleaseConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/DeleteRepository/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/DeleteRepository/main.go index 3bc28c734b74..3c3ce3f3a92e 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/DeleteRepository/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/DeleteRepository/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/DeleteWorkflowConfig/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/DeleteWorkflowConfig/main.go index 10a70374b922..310a042af3c4 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/DeleteWorkflowConfig/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/DeleteWorkflowConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/DeleteWorkflowInvocation/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/DeleteWorkflowInvocation/main.go index 5a4b4726ffc8..4d869f04cfb5 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/DeleteWorkflowInvocation/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/DeleteWorkflowInvocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/DeleteWorkspace/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/DeleteWorkspace/main.go index 710502c671e4..3a9164a70c37 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/DeleteWorkspace/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/DeleteWorkspace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/FetchFileDiff/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/FetchFileDiff/main.go index 09a567025e8f..19634a957618 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/FetchFileDiff/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/FetchFileDiff/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/FetchFileGitStatuses/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/FetchFileGitStatuses/main.go index 6915d53378c9..d3926cbc4757 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/FetchFileGitStatuses/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/FetchFileGitStatuses/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/FetchGitAheadBehind/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/FetchGitAheadBehind/main.go index 435cce7b4140..19cb4e087132 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/FetchGitAheadBehind/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/FetchGitAheadBehind/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/FetchRemoteBranches/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/FetchRemoteBranches/main.go index a1f8dd0238a5..8468110e32f9 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/FetchRemoteBranches/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/FetchRemoteBranches/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/FetchRepositoryHistory/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/FetchRepositoryHistory/main.go index 95fa8e8d0c5f..1daf1074d0d1 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/FetchRepositoryHistory/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/FetchRepositoryHistory/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/GetCompilationResult/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/GetCompilationResult/main.go index 6f6aa405466f..47c3d78709a0 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/GetCompilationResult/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/GetCompilationResult/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/GetIamPolicy/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/GetIamPolicy/main.go index dfcdaeb8753a..8ec4707b09d8 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/GetLocation/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/GetLocation/main.go index a68e5c16a94d..4110721fc40e 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/GetLocation/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/GetReleaseConfig/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/GetReleaseConfig/main.go index 732eb82cdb8c..791deb7d1fb9 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/GetReleaseConfig/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/GetReleaseConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/GetRepository/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/GetRepository/main.go index c7cd1b1d70f9..244fe56df2fe 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/GetRepository/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/GetRepository/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/GetWorkflowConfig/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/GetWorkflowConfig/main.go index 2cf8809dcc14..5d7647ee8887 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/GetWorkflowConfig/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/GetWorkflowConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/GetWorkflowInvocation/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/GetWorkflowInvocation/main.go index b7817460b435..35f3e28687a7 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/GetWorkflowInvocation/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/GetWorkflowInvocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/GetWorkspace/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/GetWorkspace/main.go index d43b51f9c7da..1c8567f74314 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/GetWorkspace/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/GetWorkspace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/InstallNpmPackages/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/InstallNpmPackages/main.go index 9432720a89d9..5ccdc3b9d713 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/InstallNpmPackages/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/InstallNpmPackages/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/ListCompilationResults/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/ListCompilationResults/main.go index 6c2e6421970b..3c471a123577 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/ListCompilationResults/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/ListCompilationResults/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/ListLocations/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/ListLocations/main.go index 58ab4a064678..7c167e518a04 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/ListLocations/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/ListReleaseConfigs/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/ListReleaseConfigs/main.go index 8ea1d1b3eef7..a5864d99ad02 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/ListReleaseConfigs/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/ListReleaseConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/ListRepositories/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/ListRepositories/main.go index feb7abbd9706..9b31b8163bd2 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/ListRepositories/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/ListRepositories/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/ListWorkflowConfigs/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/ListWorkflowConfigs/main.go index 4b8fe80fca01..e88f489e4bdc 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/ListWorkflowConfigs/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/ListWorkflowConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/ListWorkflowInvocations/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/ListWorkflowInvocations/main.go index 18561d3e32bd..cea7419896a6 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/ListWorkflowInvocations/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/ListWorkflowInvocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/ListWorkspaces/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/ListWorkspaces/main.go index f00bff7a88ae..aee1c6a3c7ae 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/ListWorkspaces/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/ListWorkspaces/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/MakeDirectory/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/MakeDirectory/main.go index 94df94e15309..c204b86e52da 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/MakeDirectory/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/MakeDirectory/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/MoveDirectory/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/MoveDirectory/main.go index 57f477ac5f0b..4381d2457d3a 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/MoveDirectory/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/MoveDirectory/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/MoveFile/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/MoveFile/main.go index 582750150c9e..ecee6fc1b8c1 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/MoveFile/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/MoveFile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/PullGitCommits/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/PullGitCommits/main.go index a843fcb9ce78..1d2db4244b53 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/PullGitCommits/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/PullGitCommits/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/PushGitCommits/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/PushGitCommits/main.go index 3d33ff86a18f..27f9bb0a86b2 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/PushGitCommits/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/PushGitCommits/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/QueryCompilationResultActions/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/QueryCompilationResultActions/main.go index 85ee17c13b38..a9d075bb10d7 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/QueryCompilationResultActions/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/QueryCompilationResultActions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/QueryDirectoryContents/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/QueryDirectoryContents/main.go index ffd1753fd1bf..9d02f612ee0e 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/QueryDirectoryContents/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/QueryDirectoryContents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/QueryRepositoryDirectoryContents/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/QueryRepositoryDirectoryContents/main.go index f6497a42a525..6dfbaae8a78e 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/QueryRepositoryDirectoryContents/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/QueryRepositoryDirectoryContents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/QueryWorkflowInvocationActions/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/QueryWorkflowInvocationActions/main.go index 3c703dbc22e0..44cf9aeb15cf 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/QueryWorkflowInvocationActions/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/QueryWorkflowInvocationActions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/ReadFile/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/ReadFile/main.go index 9ff8bd673f15..a1d592a0e5eb 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/ReadFile/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/ReadFile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/ReadRepositoryFile/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/ReadRepositoryFile/main.go index 11f3dff0e121..cb975c7efbd6 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/ReadRepositoryFile/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/ReadRepositoryFile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/RemoveDirectory/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/RemoveDirectory/main.go index 7962ca54e69b..096c8815df2c 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/RemoveDirectory/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/RemoveDirectory/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/RemoveFile/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/RemoveFile/main.go index 53058c227005..fa5ca7a07f45 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/RemoveFile/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/RemoveFile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/ResetWorkspaceChanges/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/ResetWorkspaceChanges/main.go index 804290b682cf..01855328eb89 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/ResetWorkspaceChanges/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/ResetWorkspaceChanges/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/SetIamPolicy/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/SetIamPolicy/main.go index d250531c0c44..7db0e4a5abc3 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/TestIamPermissions/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/TestIamPermissions/main.go index d31d57466e91..67e39eac51ee 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/UpdateReleaseConfig/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/UpdateReleaseConfig/main.go index dc6d9f0e892f..63b4c3599f52 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/UpdateReleaseConfig/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/UpdateReleaseConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/UpdateRepository/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/UpdateRepository/main.go index 8ee26111bc8a..65820ead82d5 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/UpdateRepository/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/UpdateRepository/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/UpdateWorkflowConfig/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/UpdateWorkflowConfig/main.go index 3bfc1c85ea4d..6fbeb006ce18 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/UpdateWorkflowConfig/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/UpdateWorkflowConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/Client/WriteFile/main.go b/internal/generated/snippets/dataform/apiv1beta1/Client/WriteFile/main.go index 1803207f8a15..854b9a6e17ff 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/Client/WriteFile/main.go +++ b/internal/generated/snippets/dataform/apiv1beta1/Client/WriteFile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataform/apiv1beta1/snippet_metadata.google.cloud.dataform.v1beta1.json b/internal/generated/snippets/dataform/apiv1beta1/snippet_metadata.google.cloud.dataform.v1beta1.json index 54a94169dd6b..5be43a5dc2fa 100644 --- a/internal/generated/snippets/dataform/apiv1beta1/snippet_metadata.google.cloud.dataform.v1beta1.json +++ b/internal/generated/snippets/dataform/apiv1beta1/snippet_metadata.google.cloud.dataform.v1beta1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/dataform/apiv1beta1", - "version": "0.10.2", + "version": "0.10.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/datafusion/apiv1/Client/CreateInstance/main.go b/internal/generated/snippets/datafusion/apiv1/Client/CreateInstance/main.go index 5d8c6e5ad495..81560a1fb42c 100644 --- a/internal/generated/snippets/datafusion/apiv1/Client/CreateInstance/main.go +++ b/internal/generated/snippets/datafusion/apiv1/Client/CreateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datafusion/apiv1/Client/DeleteInstance/main.go b/internal/generated/snippets/datafusion/apiv1/Client/DeleteInstance/main.go index 958ffe7f905c..3bef2086410e 100644 --- a/internal/generated/snippets/datafusion/apiv1/Client/DeleteInstance/main.go +++ b/internal/generated/snippets/datafusion/apiv1/Client/DeleteInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datafusion/apiv1/Client/GetInstance/main.go b/internal/generated/snippets/datafusion/apiv1/Client/GetInstance/main.go index 0479cbc1e4f4..f8e7fa3fcbce 100644 --- a/internal/generated/snippets/datafusion/apiv1/Client/GetInstance/main.go +++ b/internal/generated/snippets/datafusion/apiv1/Client/GetInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datafusion/apiv1/Client/ListAvailableVersions/main.go b/internal/generated/snippets/datafusion/apiv1/Client/ListAvailableVersions/main.go index 3c963d1b66f8..b20a68402575 100644 --- a/internal/generated/snippets/datafusion/apiv1/Client/ListAvailableVersions/main.go +++ b/internal/generated/snippets/datafusion/apiv1/Client/ListAvailableVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datafusion/apiv1/Client/ListInstances/main.go b/internal/generated/snippets/datafusion/apiv1/Client/ListInstances/main.go index dacd829423e6..fece736ae122 100644 --- a/internal/generated/snippets/datafusion/apiv1/Client/ListInstances/main.go +++ b/internal/generated/snippets/datafusion/apiv1/Client/ListInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datafusion/apiv1/Client/RestartInstance/main.go b/internal/generated/snippets/datafusion/apiv1/Client/RestartInstance/main.go index 3ec3a5b5f3a5..c2dce37807f2 100644 --- a/internal/generated/snippets/datafusion/apiv1/Client/RestartInstance/main.go +++ b/internal/generated/snippets/datafusion/apiv1/Client/RestartInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datafusion/apiv1/Client/UpdateInstance/main.go b/internal/generated/snippets/datafusion/apiv1/Client/UpdateInstance/main.go index c55717c5ea9e..9f0b2104e975 100644 --- a/internal/generated/snippets/datafusion/apiv1/Client/UpdateInstance/main.go +++ b/internal/generated/snippets/datafusion/apiv1/Client/UpdateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/CreateAnnotationSpecSet/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/CreateAnnotationSpecSet/main.go index 818b59ce99c3..6f01c96597e5 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/CreateAnnotationSpecSet/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/CreateAnnotationSpecSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/CreateDataset/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/CreateDataset/main.go index 6ce930c9adfe..c71e6753388f 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/CreateDataset/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/CreateDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/CreateEvaluationJob/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/CreateEvaluationJob/main.go index a98fbdba7b18..15a3acb46d23 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/CreateEvaluationJob/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/CreateEvaluationJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/CreateInstruction/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/CreateInstruction/main.go index 6755ce31ef8c..9bb71d50219c 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/CreateInstruction/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/CreateInstruction/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/DeleteAnnotatedDataset/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/DeleteAnnotatedDataset/main.go index 8253d73b1186..5899b213e8da 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/DeleteAnnotatedDataset/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/DeleteAnnotatedDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/DeleteAnnotationSpecSet/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/DeleteAnnotationSpecSet/main.go index 1316651fd89a..8b9fe5823292 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/DeleteAnnotationSpecSet/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/DeleteAnnotationSpecSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/DeleteDataset/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/DeleteDataset/main.go index 55751c25e064..0c56768a2eeb 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/DeleteDataset/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/DeleteDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/DeleteEvaluationJob/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/DeleteEvaluationJob/main.go index 15841d58ffba..02a5be31fd5b 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/DeleteEvaluationJob/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/DeleteEvaluationJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/DeleteInstruction/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/DeleteInstruction/main.go index 7e06b0d10157..7f015788399a 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/DeleteInstruction/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/DeleteInstruction/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/ExportData/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/ExportData/main.go index 3ef76a5c90e3..80e5fcbff0c9 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/ExportData/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/ExportData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetAnnotatedDataset/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetAnnotatedDataset/main.go index 78eb28097b6b..3658b493c95a 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetAnnotatedDataset/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetAnnotatedDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetAnnotationSpecSet/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetAnnotationSpecSet/main.go index da72b8a4d77b..8b029d19e7e8 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetAnnotationSpecSet/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetAnnotationSpecSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetDataItem/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetDataItem/main.go index 3d168062d8cc..617d1f62467b 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetDataItem/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetDataItem/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetDataset/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetDataset/main.go index 90a06a3cf285..b3300e31c84e 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetDataset/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetEvaluation/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetEvaluation/main.go index d51875c71408..d304e7ff20dd 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetEvaluation/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetEvaluation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetEvaluationJob/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetEvaluationJob/main.go index 899751fcaf0a..bb1778026f31 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetEvaluationJob/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetEvaluationJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetExample/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetExample/main.go index b94349224d5e..05a6c194d085 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetExample/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetExample/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetInstruction/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetInstruction/main.go index a3c1447d2dd7..67f254003b68 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetInstruction/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/GetInstruction/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/ImportData/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/ImportData/main.go index 515654f00b34..30792820d825 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/ImportData/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/ImportData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/LabelImage/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/LabelImage/main.go index b90341718ee8..b806bcde9f55 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/LabelImage/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/LabelImage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/LabelText/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/LabelText/main.go index 67b94391f7ca..9701ab4c7799 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/LabelText/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/LabelText/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/LabelVideo/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/LabelVideo/main.go index 54be0ac9bd7b..7dafc2dfdbfe 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/LabelVideo/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/LabelVideo/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/ListAnnotatedDatasets/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/ListAnnotatedDatasets/main.go index 7b005d9c0b54..735780dd0614 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/ListAnnotatedDatasets/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/ListAnnotatedDatasets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/ListAnnotationSpecSets/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/ListAnnotationSpecSets/main.go index 7166cf21764f..01fc675cf62e 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/ListAnnotationSpecSets/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/ListAnnotationSpecSets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/ListDataItems/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/ListDataItems/main.go index 12acdd829971..7ab3c492daa0 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/ListDataItems/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/ListDataItems/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/ListDatasets/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/ListDatasets/main.go index 04742a6f735f..967ea2178107 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/ListDatasets/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/ListDatasets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/ListEvaluationJobs/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/ListEvaluationJobs/main.go index c440fe3d00b9..1e4480f54f6a 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/ListEvaluationJobs/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/ListEvaluationJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/ListExamples/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/ListExamples/main.go index d67d85d871ca..585ca5d48bf6 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/ListExamples/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/ListExamples/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/ListInstructions/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/ListInstructions/main.go index 3feb7ea3606c..ac5218239559 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/ListInstructions/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/ListInstructions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/PauseEvaluationJob/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/PauseEvaluationJob/main.go index 1803f700b7bd..d873249464b1 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/PauseEvaluationJob/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/PauseEvaluationJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/ResumeEvaluationJob/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/ResumeEvaluationJob/main.go index b78f393a5c58..f10d22182ebf 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/ResumeEvaluationJob/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/ResumeEvaluationJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/SearchEvaluations/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/SearchEvaluations/main.go index f382cbcc573c..8a683c755717 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/SearchEvaluations/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/SearchEvaluations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/SearchExampleComparisons/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/SearchExampleComparisons/main.go index 36785f422e7a..e28e4fa203c6 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/SearchExampleComparisons/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/SearchExampleComparisons/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datalabeling/apiv1beta1/Client/UpdateEvaluationJob/main.go b/internal/generated/snippets/datalabeling/apiv1beta1/Client/UpdateEvaluationJob/main.go index 9f0fad02e0e1..aad3de5fb595 100644 --- a/internal/generated/snippets/datalabeling/apiv1beta1/Client/UpdateEvaluationJob/main.go +++ b/internal/generated/snippets/datalabeling/apiv1beta1/Client/UpdateEvaluationJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/CancelMetadataJob/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/CancelMetadataJob/main.go index 6f6f9064e48c..d69d0c13d530 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/CancelMetadataJob/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/CancelMetadataJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/CancelOperation/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/CancelOperation/main.go index f3541941f535..1d436b83e922 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/CancelOperation/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/CreateAspectType/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/CreateAspectType/main.go index 1a34b83ec4dc..4a295fc41924 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/CreateAspectType/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/CreateAspectType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/CreateEntry/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/CreateEntry/main.go index 7c791af57297..5c0d81de0fcb 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/CreateEntry/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/CreateEntry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/CreateEntryGroup/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/CreateEntryGroup/main.go index 8371064172c7..f87442100cec 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/CreateEntryGroup/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/CreateEntryGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/CreateEntryType/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/CreateEntryType/main.go index c3eefaec054b..c3ed050d8c3f 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/CreateEntryType/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/CreateEntryType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/CreateMetadataJob/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/CreateMetadataJob/main.go index ddc9aa227ceb..982f4a5205c4 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/CreateMetadataJob/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/CreateMetadataJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/DeleteAspectType/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/DeleteAspectType/main.go index 807a11448059..3e9091c91ebb 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/DeleteAspectType/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/DeleteAspectType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/DeleteEntry/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/DeleteEntry/main.go index f9d74e8b150e..bf20a404daec 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/DeleteEntry/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/DeleteEntry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/DeleteEntryGroup/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/DeleteEntryGroup/main.go index 5a09096c2ff9..4be5476e1dcf 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/DeleteEntryGroup/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/DeleteEntryGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/DeleteEntryType/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/DeleteEntryType/main.go index 5a1615aa8110..e5a19e57923b 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/DeleteEntryType/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/DeleteEntryType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/DeleteOperation/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/DeleteOperation/main.go index e4e048c1f3fe..c9951ace1cc3 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/DeleteOperation/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/GetAspectType/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/GetAspectType/main.go index 682d21264ecd..fd6d563febb7 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/GetAspectType/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/GetAspectType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/GetEntry/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/GetEntry/main.go index 759eacd6369e..dba950b50b49 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/GetEntry/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/GetEntry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/GetEntryGroup/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/GetEntryGroup/main.go index dee6beca5bbf..6ab434da9b7d 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/GetEntryGroup/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/GetEntryGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/GetEntryType/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/GetEntryType/main.go index 3e21df19ef95..0e9f3d93d335 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/GetEntryType/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/GetEntryType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/GetLocation/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/GetLocation/main.go index 4ddd180ca4bc..40e7e63b5f1f 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/GetLocation/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/GetMetadataJob/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/GetMetadataJob/main.go index 709e97850685..fa270c496d3d 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/GetMetadataJob/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/GetMetadataJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/GetOperation/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/GetOperation/main.go index f6bc53561dbc..72556620defc 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/GetOperation/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/ListAspectTypes/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/ListAspectTypes/main.go index 7bc0cf1b9f7d..64d0beafedcb 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/ListAspectTypes/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/ListAspectTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/ListEntries/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/ListEntries/main.go index 6b202453fc3d..b0f2a42d16ce 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/ListEntries/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/ListEntries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/ListEntryGroups/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/ListEntryGroups/main.go index 7c5fb6d983e1..2b40ada1a36d 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/ListEntryGroups/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/ListEntryGroups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/ListEntryTypes/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/ListEntryTypes/main.go index fb909400e901..a960de19be8e 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/ListEntryTypes/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/ListEntryTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/ListLocations/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/ListLocations/main.go index f52463b2c17e..907b3b579399 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/ListLocations/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/ListMetadataJobs/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/ListMetadataJobs/main.go index 9ebee4f464d4..7fcfa8402aee 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/ListMetadataJobs/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/ListMetadataJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/ListOperations/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/ListOperations/main.go index 7a5fafd0a706..51c92e1a9ce4 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/ListOperations/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/LookupEntry/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/LookupEntry/main.go index 7090ffc024d2..006e04a0692b 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/LookupEntry/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/LookupEntry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/SearchEntries/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/SearchEntries/main.go index dd4eb5f88655..1e1a50268e55 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/SearchEntries/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/SearchEntries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/UpdateAspectType/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/UpdateAspectType/main.go index 2465dd98c6a9..231d48cd145d 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/UpdateAspectType/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/UpdateAspectType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/UpdateEntry/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/UpdateEntry/main.go index bceafa8c03bc..fa8fb8e5dd79 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/UpdateEntry/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/UpdateEntry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/UpdateEntryGroup/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/UpdateEntryGroup/main.go index 845977f00376..6ef6d0d9ca28 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/UpdateEntryGroup/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/UpdateEntryGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/CatalogClient/UpdateEntryType/main.go b/internal/generated/snippets/dataplex/apiv1/CatalogClient/UpdateEntryType/main.go index 5abdcbc7b82c..cd48bd907f2b 100644 --- a/internal/generated/snippets/dataplex/apiv1/CatalogClient/UpdateEntryType/main.go +++ b/internal/generated/snippets/dataplex/apiv1/CatalogClient/UpdateEntryType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/CancelJob/main.go b/internal/generated/snippets/dataplex/apiv1/Client/CancelJob/main.go index a49dd232094a..b2e72f570f50 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/CancelJob/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/CancelJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/dataplex/apiv1/Client/CancelOperation/main.go index f5541cb2e4bb..afcfbb4aa326 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/CreateAsset/main.go b/internal/generated/snippets/dataplex/apiv1/Client/CreateAsset/main.go index 73af21d70a91..22849011c12e 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/CreateAsset/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/CreateAsset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/CreateEnvironment/main.go b/internal/generated/snippets/dataplex/apiv1/Client/CreateEnvironment/main.go index 9892960aeaa2..f7bbd1198b8f 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/CreateEnvironment/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/CreateEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/CreateLake/main.go b/internal/generated/snippets/dataplex/apiv1/Client/CreateLake/main.go index 39eaf5125c7c..2b3d3b195723 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/CreateLake/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/CreateLake/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/CreateTask/main.go b/internal/generated/snippets/dataplex/apiv1/Client/CreateTask/main.go index 0e63be71e2d5..5731bc60d85e 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/CreateTask/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/CreateTask/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/CreateZone/main.go b/internal/generated/snippets/dataplex/apiv1/Client/CreateZone/main.go index e5c8d3feffac..50dfc1e188ae 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/CreateZone/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/CreateZone/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/DeleteAsset/main.go b/internal/generated/snippets/dataplex/apiv1/Client/DeleteAsset/main.go index a4976fb35909..798f22da024f 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/DeleteAsset/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/DeleteAsset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/DeleteEnvironment/main.go b/internal/generated/snippets/dataplex/apiv1/Client/DeleteEnvironment/main.go index b6546d1525a2..78bbeb50e0fd 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/DeleteEnvironment/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/DeleteEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/DeleteLake/main.go b/internal/generated/snippets/dataplex/apiv1/Client/DeleteLake/main.go index 695ab4e2f50c..34bb0217a705 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/DeleteLake/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/DeleteLake/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/dataplex/apiv1/Client/DeleteOperation/main.go index b6c16f7027ed..268d0d9bc5dc 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/DeleteTask/main.go b/internal/generated/snippets/dataplex/apiv1/Client/DeleteTask/main.go index e590df6b983d..0efdcb5c9109 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/DeleteTask/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/DeleteTask/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/DeleteZone/main.go b/internal/generated/snippets/dataplex/apiv1/Client/DeleteZone/main.go index 92d6534028f3..ffbd30e69e5e 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/DeleteZone/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/DeleteZone/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/GetAsset/main.go b/internal/generated/snippets/dataplex/apiv1/Client/GetAsset/main.go index 6033e5fd2745..e721aae61989 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/GetAsset/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/GetAsset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/GetEnvironment/main.go b/internal/generated/snippets/dataplex/apiv1/Client/GetEnvironment/main.go index 36ea916645f2..46bd479d6b7f 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/GetEnvironment/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/GetEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/GetJob/main.go b/internal/generated/snippets/dataplex/apiv1/Client/GetJob/main.go index bd8db5602436..9b658872a242 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/GetJob/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/GetJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/GetLake/main.go b/internal/generated/snippets/dataplex/apiv1/Client/GetLake/main.go index 2c6126e9a435..3d32cb55aca5 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/GetLake/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/GetLake/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/dataplex/apiv1/Client/GetLocation/main.go index 491d701ff25f..2c955bdf36ca 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/dataplex/apiv1/Client/GetOperation/main.go index c0c1ed4bff1b..e8d7242248dd 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/GetTask/main.go b/internal/generated/snippets/dataplex/apiv1/Client/GetTask/main.go index a43d519ec758..07d30d6bb16f 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/GetTask/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/GetTask/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/GetZone/main.go b/internal/generated/snippets/dataplex/apiv1/Client/GetZone/main.go index 2608bf3fd240..b08c72865d23 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/GetZone/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/GetZone/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/ListAssetActions/main.go b/internal/generated/snippets/dataplex/apiv1/Client/ListAssetActions/main.go index 662e6b3b3fab..69e158d90545 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/ListAssetActions/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/ListAssetActions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/ListAssets/main.go b/internal/generated/snippets/dataplex/apiv1/Client/ListAssets/main.go index 12563b4cfe33..591fb8658f04 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/ListAssets/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/ListAssets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/ListEnvironments/main.go b/internal/generated/snippets/dataplex/apiv1/Client/ListEnvironments/main.go index 4b360abf455f..0150ff8c29a6 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/ListEnvironments/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/ListEnvironments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/ListJobs/main.go b/internal/generated/snippets/dataplex/apiv1/Client/ListJobs/main.go index c40177818777..7dd8ec5e90d6 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/ListJobs/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/ListJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/ListLakeActions/main.go b/internal/generated/snippets/dataplex/apiv1/Client/ListLakeActions/main.go index ee0a8de6b187..579198379d30 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/ListLakeActions/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/ListLakeActions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/ListLakes/main.go b/internal/generated/snippets/dataplex/apiv1/Client/ListLakes/main.go index bd2d3401aedc..6204c7f085e5 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/ListLakes/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/ListLakes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/dataplex/apiv1/Client/ListLocations/main.go index aa6670186d45..08a3c57c4ffc 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/dataplex/apiv1/Client/ListOperations/main.go index 5f437b4e23f1..6a867db7b44d 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/ListSessions/main.go b/internal/generated/snippets/dataplex/apiv1/Client/ListSessions/main.go index 7c1e8a1c09f1..81c1f1993674 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/ListSessions/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/ListSessions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/ListTasks/main.go b/internal/generated/snippets/dataplex/apiv1/Client/ListTasks/main.go index 57c4357c7bc1..9ab82fc862c2 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/ListTasks/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/ListTasks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/ListZoneActions/main.go b/internal/generated/snippets/dataplex/apiv1/Client/ListZoneActions/main.go index 70c4063fb779..b967f374bf2b 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/ListZoneActions/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/ListZoneActions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/ListZones/main.go b/internal/generated/snippets/dataplex/apiv1/Client/ListZones/main.go index e9bd00f923ec..e8a8021afc3c 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/ListZones/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/ListZones/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/RunTask/main.go b/internal/generated/snippets/dataplex/apiv1/Client/RunTask/main.go index c55988cc0b7c..70ec74bad80f 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/RunTask/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/RunTask/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/UpdateAsset/main.go b/internal/generated/snippets/dataplex/apiv1/Client/UpdateAsset/main.go index 62ccb6875c51..cc0553036ca8 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/UpdateAsset/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/UpdateAsset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/UpdateEnvironment/main.go b/internal/generated/snippets/dataplex/apiv1/Client/UpdateEnvironment/main.go index 6cd225fa1913..b38aaf9b3235 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/UpdateEnvironment/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/UpdateEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/UpdateLake/main.go b/internal/generated/snippets/dataplex/apiv1/Client/UpdateLake/main.go index a4e3076f5edd..91590e0c0111 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/UpdateLake/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/UpdateLake/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/UpdateTask/main.go b/internal/generated/snippets/dataplex/apiv1/Client/UpdateTask/main.go index d839a08b7b6c..7dbaa2e31b8e 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/UpdateTask/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/UpdateTask/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/Client/UpdateZone/main.go b/internal/generated/snippets/dataplex/apiv1/Client/UpdateZone/main.go index 37273e1d76d5..a95ae7ed8c11 100644 --- a/internal/generated/snippets/dataplex/apiv1/Client/UpdateZone/main.go +++ b/internal/generated/snippets/dataplex/apiv1/Client/UpdateZone/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/ContentClient/CancelOperation/main.go b/internal/generated/snippets/dataplex/apiv1/ContentClient/CancelOperation/main.go index 202795414477..c5872a382096 100644 --- a/internal/generated/snippets/dataplex/apiv1/ContentClient/CancelOperation/main.go +++ b/internal/generated/snippets/dataplex/apiv1/ContentClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/ContentClient/CreateContent/main.go b/internal/generated/snippets/dataplex/apiv1/ContentClient/CreateContent/main.go index df3a3a29a42a..c57047d0c202 100644 --- a/internal/generated/snippets/dataplex/apiv1/ContentClient/CreateContent/main.go +++ b/internal/generated/snippets/dataplex/apiv1/ContentClient/CreateContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/ContentClient/DeleteContent/main.go b/internal/generated/snippets/dataplex/apiv1/ContentClient/DeleteContent/main.go index 562663023aed..6744d77c77ce 100644 --- a/internal/generated/snippets/dataplex/apiv1/ContentClient/DeleteContent/main.go +++ b/internal/generated/snippets/dataplex/apiv1/ContentClient/DeleteContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/ContentClient/DeleteOperation/main.go b/internal/generated/snippets/dataplex/apiv1/ContentClient/DeleteOperation/main.go index 6b644de368de..14f848725d2f 100644 --- a/internal/generated/snippets/dataplex/apiv1/ContentClient/DeleteOperation/main.go +++ b/internal/generated/snippets/dataplex/apiv1/ContentClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/ContentClient/GetContent/main.go b/internal/generated/snippets/dataplex/apiv1/ContentClient/GetContent/main.go index a0f1f2284a3a..5f5b9f87b2b5 100644 --- a/internal/generated/snippets/dataplex/apiv1/ContentClient/GetContent/main.go +++ b/internal/generated/snippets/dataplex/apiv1/ContentClient/GetContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/ContentClient/GetIamPolicy/main.go b/internal/generated/snippets/dataplex/apiv1/ContentClient/GetIamPolicy/main.go index d4801f55ef2b..b316180db8e9 100644 --- a/internal/generated/snippets/dataplex/apiv1/ContentClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/dataplex/apiv1/ContentClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/ContentClient/GetLocation/main.go b/internal/generated/snippets/dataplex/apiv1/ContentClient/GetLocation/main.go index 2c41e58255f5..65d1397bc7a6 100644 --- a/internal/generated/snippets/dataplex/apiv1/ContentClient/GetLocation/main.go +++ b/internal/generated/snippets/dataplex/apiv1/ContentClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/ContentClient/GetOperation/main.go b/internal/generated/snippets/dataplex/apiv1/ContentClient/GetOperation/main.go index da94cc75e7ab..95f6aee33e4d 100644 --- a/internal/generated/snippets/dataplex/apiv1/ContentClient/GetOperation/main.go +++ b/internal/generated/snippets/dataplex/apiv1/ContentClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/ContentClient/ListContent/main.go b/internal/generated/snippets/dataplex/apiv1/ContentClient/ListContent/main.go index 870fbaacdf19..f3a4bd38bca5 100644 --- a/internal/generated/snippets/dataplex/apiv1/ContentClient/ListContent/main.go +++ b/internal/generated/snippets/dataplex/apiv1/ContentClient/ListContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/ContentClient/ListLocations/main.go b/internal/generated/snippets/dataplex/apiv1/ContentClient/ListLocations/main.go index 607a9e40a981..c46ba2be7f9d 100644 --- a/internal/generated/snippets/dataplex/apiv1/ContentClient/ListLocations/main.go +++ b/internal/generated/snippets/dataplex/apiv1/ContentClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/ContentClient/ListOperations/main.go b/internal/generated/snippets/dataplex/apiv1/ContentClient/ListOperations/main.go index 9e68cc36e101..23abde8bca96 100644 --- a/internal/generated/snippets/dataplex/apiv1/ContentClient/ListOperations/main.go +++ b/internal/generated/snippets/dataplex/apiv1/ContentClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/ContentClient/SetIamPolicy/main.go b/internal/generated/snippets/dataplex/apiv1/ContentClient/SetIamPolicy/main.go index d6e777750cd8..29120d033d7e 100644 --- a/internal/generated/snippets/dataplex/apiv1/ContentClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/dataplex/apiv1/ContentClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/ContentClient/TestIamPermissions/main.go b/internal/generated/snippets/dataplex/apiv1/ContentClient/TestIamPermissions/main.go index ab117f9e0e37..ff3d73076ffd 100644 --- a/internal/generated/snippets/dataplex/apiv1/ContentClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/dataplex/apiv1/ContentClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/ContentClient/UpdateContent/main.go b/internal/generated/snippets/dataplex/apiv1/ContentClient/UpdateContent/main.go index 4c5f5283edb6..5d4a8140605d 100644 --- a/internal/generated/snippets/dataplex/apiv1/ContentClient/UpdateContent/main.go +++ b/internal/generated/snippets/dataplex/apiv1/ContentClient/UpdateContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataScanClient/CancelOperation/main.go b/internal/generated/snippets/dataplex/apiv1/DataScanClient/CancelOperation/main.go index f4e61367af09..8525ffa7afb4 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataScanClient/CancelOperation/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataScanClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataScanClient/CreateDataScan/main.go b/internal/generated/snippets/dataplex/apiv1/DataScanClient/CreateDataScan/main.go index 1f202a87de03..c2335e793ef9 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataScanClient/CreateDataScan/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataScanClient/CreateDataScan/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataScanClient/DeleteDataScan/main.go b/internal/generated/snippets/dataplex/apiv1/DataScanClient/DeleteDataScan/main.go index 425ef5759e40..22f42ebb761f 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataScanClient/DeleteDataScan/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataScanClient/DeleteDataScan/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataScanClient/DeleteOperation/main.go b/internal/generated/snippets/dataplex/apiv1/DataScanClient/DeleteOperation/main.go index ce8373cf2ebe..5c67e0d5f517 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataScanClient/DeleteOperation/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataScanClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataScanClient/GenerateDataQualityRules/main.go b/internal/generated/snippets/dataplex/apiv1/DataScanClient/GenerateDataQualityRules/main.go index 9114fe378586..1357284c880b 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataScanClient/GenerateDataQualityRules/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataScanClient/GenerateDataQualityRules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataScanClient/GetDataScan/main.go b/internal/generated/snippets/dataplex/apiv1/DataScanClient/GetDataScan/main.go index fdf7d2fae148..c99ef8adc6df 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataScanClient/GetDataScan/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataScanClient/GetDataScan/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataScanClient/GetDataScanJob/main.go b/internal/generated/snippets/dataplex/apiv1/DataScanClient/GetDataScanJob/main.go index c10f65090ddc..abbd09300413 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataScanClient/GetDataScanJob/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataScanClient/GetDataScanJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataScanClient/GetLocation/main.go b/internal/generated/snippets/dataplex/apiv1/DataScanClient/GetLocation/main.go index c0393993b678..013c3d1247e6 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataScanClient/GetLocation/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataScanClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataScanClient/GetOperation/main.go b/internal/generated/snippets/dataplex/apiv1/DataScanClient/GetOperation/main.go index 87bc2ece2e42..2130a7eeeacf 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataScanClient/GetOperation/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataScanClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataScanClient/ListDataScanJobs/main.go b/internal/generated/snippets/dataplex/apiv1/DataScanClient/ListDataScanJobs/main.go index c3d438319076..c200c8a34170 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataScanClient/ListDataScanJobs/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataScanClient/ListDataScanJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataScanClient/ListDataScans/main.go b/internal/generated/snippets/dataplex/apiv1/DataScanClient/ListDataScans/main.go index 19fb64a537d1..edd59a6619ce 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataScanClient/ListDataScans/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataScanClient/ListDataScans/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataScanClient/ListLocations/main.go b/internal/generated/snippets/dataplex/apiv1/DataScanClient/ListLocations/main.go index 328ebca82929..179c47bdfcba 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataScanClient/ListLocations/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataScanClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataScanClient/ListOperations/main.go b/internal/generated/snippets/dataplex/apiv1/DataScanClient/ListOperations/main.go index 493d5182a8bf..a7e41961e076 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataScanClient/ListOperations/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataScanClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataScanClient/RunDataScan/main.go b/internal/generated/snippets/dataplex/apiv1/DataScanClient/RunDataScan/main.go index 353e448e8ee9..739824d2451a 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataScanClient/RunDataScan/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataScanClient/RunDataScan/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataScanClient/UpdateDataScan/main.go b/internal/generated/snippets/dataplex/apiv1/DataScanClient/UpdateDataScan/main.go index 64c83b29f606..001999865d2c 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataScanClient/UpdateDataScan/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataScanClient/UpdateDataScan/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/CancelOperation/main.go b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/CancelOperation/main.go index b23a308deaf3..ea8913d6fdad 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/CancelOperation/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/CreateDataAttribute/main.go b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/CreateDataAttribute/main.go index f1f4c1871aba..9c385bc59b7a 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/CreateDataAttribute/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/CreateDataAttribute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/CreateDataAttributeBinding/main.go b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/CreateDataAttributeBinding/main.go index 47fa2d86f4ee..6b58c9926081 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/CreateDataAttributeBinding/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/CreateDataAttributeBinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/CreateDataTaxonomy/main.go b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/CreateDataTaxonomy/main.go index 7212c24c8b65..2f10061dd50a 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/CreateDataTaxonomy/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/CreateDataTaxonomy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/DeleteDataAttribute/main.go b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/DeleteDataAttribute/main.go index 4d409e920f04..4dbcacfbcf98 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/DeleteDataAttribute/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/DeleteDataAttribute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/DeleteDataAttributeBinding/main.go b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/DeleteDataAttributeBinding/main.go index b409ca5ac771..d4d647d6bb01 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/DeleteDataAttributeBinding/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/DeleteDataAttributeBinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/DeleteDataTaxonomy/main.go b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/DeleteDataTaxonomy/main.go index 628233ebb06b..aed86d6c0ad5 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/DeleteDataTaxonomy/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/DeleteDataTaxonomy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/DeleteOperation/main.go b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/DeleteOperation/main.go index 4fa97f0c59ff..ca5b05e4c147 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/DeleteOperation/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/GetDataAttribute/main.go b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/GetDataAttribute/main.go index 0dedc48ff0e9..e62b6617091a 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/GetDataAttribute/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/GetDataAttribute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/GetDataAttributeBinding/main.go b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/GetDataAttributeBinding/main.go index f09d4f7cc227..3e5c50d3f755 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/GetDataAttributeBinding/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/GetDataAttributeBinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/GetDataTaxonomy/main.go b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/GetDataTaxonomy/main.go index c64674e246da..ea90c341f9de 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/GetDataTaxonomy/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/GetDataTaxonomy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/GetLocation/main.go b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/GetLocation/main.go index 0100bdcbf85f..370db6a5372a 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/GetLocation/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/GetOperation/main.go b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/GetOperation/main.go index d18d6fbc2dd4..5204b301eca7 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/GetOperation/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/ListDataAttributeBindings/main.go b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/ListDataAttributeBindings/main.go index 54a3b903dc14..52256d42fe3a 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/ListDataAttributeBindings/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/ListDataAttributeBindings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/ListDataAttributes/main.go b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/ListDataAttributes/main.go index e8508c26a8d6..9881fd800863 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/ListDataAttributes/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/ListDataAttributes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/ListDataTaxonomies/main.go b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/ListDataTaxonomies/main.go index b919ec986e5c..146320cfa91f 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/ListDataTaxonomies/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/ListDataTaxonomies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/ListLocations/main.go b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/ListLocations/main.go index 2a8bd9a4e3da..7ff0c1cc0a33 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/ListLocations/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/ListOperations/main.go b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/ListOperations/main.go index a45c3a788f6a..f37b99ddbbf5 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/ListOperations/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/UpdateDataAttribute/main.go b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/UpdateDataAttribute/main.go index 0e90ddd1e9c9..836447902146 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/UpdateDataAttribute/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/UpdateDataAttribute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/UpdateDataAttributeBinding/main.go b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/UpdateDataAttributeBinding/main.go index bf63b886a52a..8d22a4b2a29d 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/UpdateDataAttributeBinding/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/UpdateDataAttributeBinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/UpdateDataTaxonomy/main.go b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/UpdateDataTaxonomy/main.go index b44f88a531a6..4954673a7d5f 100644 --- a/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/UpdateDataTaxonomy/main.go +++ b/internal/generated/snippets/dataplex/apiv1/DataTaxonomyClient/UpdateDataTaxonomy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/MetadataClient/CancelOperation/main.go b/internal/generated/snippets/dataplex/apiv1/MetadataClient/CancelOperation/main.go index 5f40659feb4e..7c5fd1845e70 100644 --- a/internal/generated/snippets/dataplex/apiv1/MetadataClient/CancelOperation/main.go +++ b/internal/generated/snippets/dataplex/apiv1/MetadataClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/MetadataClient/CreateEntity/main.go b/internal/generated/snippets/dataplex/apiv1/MetadataClient/CreateEntity/main.go index 63d8f499245d..8ad813acd984 100644 --- a/internal/generated/snippets/dataplex/apiv1/MetadataClient/CreateEntity/main.go +++ b/internal/generated/snippets/dataplex/apiv1/MetadataClient/CreateEntity/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/MetadataClient/CreatePartition/main.go b/internal/generated/snippets/dataplex/apiv1/MetadataClient/CreatePartition/main.go index 2a7015ca1721..f5e77ff4a2f9 100644 --- a/internal/generated/snippets/dataplex/apiv1/MetadataClient/CreatePartition/main.go +++ b/internal/generated/snippets/dataplex/apiv1/MetadataClient/CreatePartition/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/MetadataClient/DeleteEntity/main.go b/internal/generated/snippets/dataplex/apiv1/MetadataClient/DeleteEntity/main.go index 7e094e3999c7..69c6f06b16d0 100644 --- a/internal/generated/snippets/dataplex/apiv1/MetadataClient/DeleteEntity/main.go +++ b/internal/generated/snippets/dataplex/apiv1/MetadataClient/DeleteEntity/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/MetadataClient/DeleteOperation/main.go b/internal/generated/snippets/dataplex/apiv1/MetadataClient/DeleteOperation/main.go index 9ba655affac0..cd780a439aad 100644 --- a/internal/generated/snippets/dataplex/apiv1/MetadataClient/DeleteOperation/main.go +++ b/internal/generated/snippets/dataplex/apiv1/MetadataClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/MetadataClient/DeletePartition/main.go b/internal/generated/snippets/dataplex/apiv1/MetadataClient/DeletePartition/main.go index ffdb343aecda..9ebf2be09e0c 100644 --- a/internal/generated/snippets/dataplex/apiv1/MetadataClient/DeletePartition/main.go +++ b/internal/generated/snippets/dataplex/apiv1/MetadataClient/DeletePartition/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/MetadataClient/GetEntity/main.go b/internal/generated/snippets/dataplex/apiv1/MetadataClient/GetEntity/main.go index 30bff832f4f6..ebddf7dbdad0 100644 --- a/internal/generated/snippets/dataplex/apiv1/MetadataClient/GetEntity/main.go +++ b/internal/generated/snippets/dataplex/apiv1/MetadataClient/GetEntity/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/MetadataClient/GetLocation/main.go b/internal/generated/snippets/dataplex/apiv1/MetadataClient/GetLocation/main.go index a07ea923d078..74f3c6b2859e 100644 --- a/internal/generated/snippets/dataplex/apiv1/MetadataClient/GetLocation/main.go +++ b/internal/generated/snippets/dataplex/apiv1/MetadataClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/MetadataClient/GetOperation/main.go b/internal/generated/snippets/dataplex/apiv1/MetadataClient/GetOperation/main.go index 89674510a334..5b17b805a5b1 100644 --- a/internal/generated/snippets/dataplex/apiv1/MetadataClient/GetOperation/main.go +++ b/internal/generated/snippets/dataplex/apiv1/MetadataClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/MetadataClient/GetPartition/main.go b/internal/generated/snippets/dataplex/apiv1/MetadataClient/GetPartition/main.go index 49d69fd66d17..250ea4208c59 100644 --- a/internal/generated/snippets/dataplex/apiv1/MetadataClient/GetPartition/main.go +++ b/internal/generated/snippets/dataplex/apiv1/MetadataClient/GetPartition/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/MetadataClient/ListEntities/main.go b/internal/generated/snippets/dataplex/apiv1/MetadataClient/ListEntities/main.go index 218268794e42..fbd561f31557 100644 --- a/internal/generated/snippets/dataplex/apiv1/MetadataClient/ListEntities/main.go +++ b/internal/generated/snippets/dataplex/apiv1/MetadataClient/ListEntities/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/MetadataClient/ListLocations/main.go b/internal/generated/snippets/dataplex/apiv1/MetadataClient/ListLocations/main.go index 67919039c028..4a2aa26b10d7 100644 --- a/internal/generated/snippets/dataplex/apiv1/MetadataClient/ListLocations/main.go +++ b/internal/generated/snippets/dataplex/apiv1/MetadataClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/MetadataClient/ListOperations/main.go b/internal/generated/snippets/dataplex/apiv1/MetadataClient/ListOperations/main.go index 33b8dac57ce4..a03546612852 100644 --- a/internal/generated/snippets/dataplex/apiv1/MetadataClient/ListOperations/main.go +++ b/internal/generated/snippets/dataplex/apiv1/MetadataClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/MetadataClient/ListPartitions/main.go b/internal/generated/snippets/dataplex/apiv1/MetadataClient/ListPartitions/main.go index 062f8a5b1020..3965a490e23a 100644 --- a/internal/generated/snippets/dataplex/apiv1/MetadataClient/ListPartitions/main.go +++ b/internal/generated/snippets/dataplex/apiv1/MetadataClient/ListPartitions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/MetadataClient/UpdateEntity/main.go b/internal/generated/snippets/dataplex/apiv1/MetadataClient/UpdateEntity/main.go index e7e53bec6d2e..84089829b5c9 100644 --- a/internal/generated/snippets/dataplex/apiv1/MetadataClient/UpdateEntity/main.go +++ b/internal/generated/snippets/dataplex/apiv1/MetadataClient/UpdateEntity/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataplex/apiv1/snippet_metadata.google.cloud.dataplex.v1.json b/internal/generated/snippets/dataplex/apiv1/snippet_metadata.google.cloud.dataplex.v1.json index 6e110acd7802..3b8e0f7d035d 100644 --- a/internal/generated/snippets/dataplex/apiv1/snippet_metadata.google.cloud.dataplex.v1.json +++ b/internal/generated/snippets/dataplex/apiv1/snippet_metadata.google.cloud.dataplex.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/dataplex/apiv1", - "version": "1.20.0", + "version": "1.21.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/CancelOperation/main.go b/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/CancelOperation/main.go index 53ac7317970c..485b27a9d20e 100644 --- a/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/CancelOperation/main.go +++ b/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/CreateAutoscalingPolicy/main.go b/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/CreateAutoscalingPolicy/main.go index a1f4c03bbafc..d8e568c5a893 100644 --- a/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/CreateAutoscalingPolicy/main.go +++ b/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/CreateAutoscalingPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/DeleteAutoscalingPolicy/main.go b/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/DeleteAutoscalingPolicy/main.go index 061b20a03986..3634e55b0a43 100644 --- a/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/DeleteAutoscalingPolicy/main.go +++ b/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/DeleteAutoscalingPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/DeleteOperation/main.go b/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/DeleteOperation/main.go index 3101cb4fc1f8..5f179ebc6ecb 100644 --- a/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/DeleteOperation/main.go +++ b/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/GetAutoscalingPolicy/main.go b/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/GetAutoscalingPolicy/main.go index ba914b857c66..414b40673289 100644 --- a/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/GetAutoscalingPolicy/main.go +++ b/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/GetAutoscalingPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/GetIamPolicy/main.go b/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/GetIamPolicy/main.go index 5f2aff869af0..99806e76d240 100644 --- a/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/GetOperation/main.go b/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/GetOperation/main.go index 21af46084c3a..a2abc92534b6 100644 --- a/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/GetOperation/main.go +++ b/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/ListAutoscalingPolicies/main.go b/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/ListAutoscalingPolicies/main.go index 28230279e73f..1c81b677aa94 100644 --- a/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/ListAutoscalingPolicies/main.go +++ b/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/ListAutoscalingPolicies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/ListOperations/main.go b/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/ListOperations/main.go index 6f131317d9d5..48ed20bcc47e 100644 --- a/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/ListOperations/main.go +++ b/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/SetIamPolicy/main.go b/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/SetIamPolicy/main.go index 0725ac1e328d..66b9dc13218e 100644 --- a/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/TestIamPermissions/main.go b/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/TestIamPermissions/main.go index aec90234a572..0716d0dd3dad 100644 --- a/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/UpdateAutoscalingPolicy/main.go b/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/UpdateAutoscalingPolicy/main.go index 8b9183607adf..28785a07dda6 100644 --- a/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/UpdateAutoscalingPolicy/main.go +++ b/internal/generated/snippets/dataproc/apiv1/AutoscalingPolicyClient/UpdateAutoscalingPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/CancelOperation/main.go b/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/CancelOperation/main.go index 44550fe8d018..07c2a295af18 100644 --- a/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/CancelOperation/main.go +++ b/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/CreateBatch/main.go b/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/CreateBatch/main.go index feb68d3422b1..3d72cd76c160 100644 --- a/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/CreateBatch/main.go +++ b/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/CreateBatch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/DeleteBatch/main.go b/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/DeleteBatch/main.go index a45eedf96dba..fd49f6a3a4fe 100644 --- a/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/DeleteBatch/main.go +++ b/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/DeleteBatch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/DeleteOperation/main.go b/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/DeleteOperation/main.go index 46e886e8ec05..1b518787d344 100644 --- a/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/DeleteOperation/main.go +++ b/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/GetBatch/main.go b/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/GetBatch/main.go index e18e97760391..5b6d07b450ae 100644 --- a/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/GetBatch/main.go +++ b/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/GetBatch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/GetIamPolicy/main.go b/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/GetIamPolicy/main.go index 395e146b975b..a1fa6acf50f3 100644 --- a/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/GetOperation/main.go b/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/GetOperation/main.go index 49bd09ab6297..709268c55fc4 100644 --- a/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/GetOperation/main.go +++ b/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/ListBatches/main.go b/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/ListBatches/main.go index 00c61cab5552..fe3ad4d60b9c 100644 --- a/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/ListBatches/main.go +++ b/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/ListBatches/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/ListOperations/main.go b/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/ListOperations/main.go index 9074d4cd7166..5c6ef638198a 100644 --- a/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/ListOperations/main.go +++ b/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/SetIamPolicy/main.go b/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/SetIamPolicy/main.go index 0a3343a09ac3..0f1dbae6d5ba 100644 --- a/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/TestIamPermissions/main.go b/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/TestIamPermissions/main.go index 46ea8ec2d369..db9f69e1170a 100644 --- a/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/dataproc/apiv1/BatchControllerClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/CancelOperation/main.go b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/CancelOperation/main.go index f1a3caab090a..310114ac0bf1 100644 --- a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/CancelOperation/main.go +++ b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/CreateCluster/main.go b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/CreateCluster/main.go index 6d125ff0bef4..8b2a99271448 100644 --- a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/CreateCluster/main.go +++ b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/CreateCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/DeleteCluster/main.go b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/DeleteCluster/main.go index 410dad27db80..69c4510b95e5 100644 --- a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/DeleteCluster/main.go +++ b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/DeleteCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/DeleteOperation/main.go b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/DeleteOperation/main.go index aded72b36499..2267a1a6c664 100644 --- a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/DeleteOperation/main.go +++ b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/DiagnoseCluster/main.go b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/DiagnoseCluster/main.go index 3008b0b9652c..97042a738858 100644 --- a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/DiagnoseCluster/main.go +++ b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/DiagnoseCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/GetCluster/main.go b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/GetCluster/main.go index 9f209a6dc26f..dd569583e30c 100644 --- a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/GetCluster/main.go +++ b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/GetCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/GetIamPolicy/main.go b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/GetIamPolicy/main.go index f4e5371d4edb..10c4fbb1611c 100644 --- a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/GetOperation/main.go b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/GetOperation/main.go index 5fb716e28d94..08c5a222c84b 100644 --- a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/GetOperation/main.go +++ b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/ListClusters/main.go b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/ListClusters/main.go index 590879371ad2..b3b967f79ffe 100644 --- a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/ListClusters/main.go +++ b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/ListClusters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/ListOperations/main.go b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/ListOperations/main.go index 1f4639dcf473..ee72d3efdcfe 100644 --- a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/ListOperations/main.go +++ b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/SetIamPolicy/main.go b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/SetIamPolicy/main.go index ee7e84844b36..5da994a25b7c 100644 --- a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/StartCluster/main.go b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/StartCluster/main.go index f9da075a48eb..10c9af6ba995 100644 --- a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/StartCluster/main.go +++ b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/StartCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/StopCluster/main.go b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/StopCluster/main.go index 4f4b0f0cab6a..0f3ae2e24a4a 100644 --- a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/StopCluster/main.go +++ b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/StopCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/TestIamPermissions/main.go b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/TestIamPermissions/main.go index bfac93fc52d3..d3b570079ecc 100644 --- a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/UpdateCluster/main.go b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/UpdateCluster/main.go index 52111a3b6f0e..e19531c2fb6a 100644 --- a/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/UpdateCluster/main.go +++ b/internal/generated/snippets/dataproc/apiv1/ClusterControllerClient/UpdateCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/JobControllerClient/CancelJob/main.go b/internal/generated/snippets/dataproc/apiv1/JobControllerClient/CancelJob/main.go index 4b2fe20d315b..85a8bfb98620 100644 --- a/internal/generated/snippets/dataproc/apiv1/JobControllerClient/CancelJob/main.go +++ b/internal/generated/snippets/dataproc/apiv1/JobControllerClient/CancelJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/JobControllerClient/CancelOperation/main.go b/internal/generated/snippets/dataproc/apiv1/JobControllerClient/CancelOperation/main.go index c549a51e68dd..11b4c0e3d181 100644 --- a/internal/generated/snippets/dataproc/apiv1/JobControllerClient/CancelOperation/main.go +++ b/internal/generated/snippets/dataproc/apiv1/JobControllerClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/JobControllerClient/DeleteJob/main.go b/internal/generated/snippets/dataproc/apiv1/JobControllerClient/DeleteJob/main.go index 674fd995b7a5..33a4c6b1ea46 100644 --- a/internal/generated/snippets/dataproc/apiv1/JobControllerClient/DeleteJob/main.go +++ b/internal/generated/snippets/dataproc/apiv1/JobControllerClient/DeleteJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/JobControllerClient/DeleteOperation/main.go b/internal/generated/snippets/dataproc/apiv1/JobControllerClient/DeleteOperation/main.go index 557de2a34524..6bec5d4dca96 100644 --- a/internal/generated/snippets/dataproc/apiv1/JobControllerClient/DeleteOperation/main.go +++ b/internal/generated/snippets/dataproc/apiv1/JobControllerClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/JobControllerClient/GetIamPolicy/main.go b/internal/generated/snippets/dataproc/apiv1/JobControllerClient/GetIamPolicy/main.go index 59ccfc7497d2..d0f50dbc49cc 100644 --- a/internal/generated/snippets/dataproc/apiv1/JobControllerClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/dataproc/apiv1/JobControllerClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/JobControllerClient/GetJob/main.go b/internal/generated/snippets/dataproc/apiv1/JobControllerClient/GetJob/main.go index 6ee5a6451f0f..840bd47d0568 100644 --- a/internal/generated/snippets/dataproc/apiv1/JobControllerClient/GetJob/main.go +++ b/internal/generated/snippets/dataproc/apiv1/JobControllerClient/GetJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/JobControllerClient/GetOperation/main.go b/internal/generated/snippets/dataproc/apiv1/JobControllerClient/GetOperation/main.go index 6a3ed20ebc43..3834847bbb67 100644 --- a/internal/generated/snippets/dataproc/apiv1/JobControllerClient/GetOperation/main.go +++ b/internal/generated/snippets/dataproc/apiv1/JobControllerClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/JobControllerClient/ListJobs/main.go b/internal/generated/snippets/dataproc/apiv1/JobControllerClient/ListJobs/main.go index 79dcae8a4e0c..f5619d1ef4af 100644 --- a/internal/generated/snippets/dataproc/apiv1/JobControllerClient/ListJobs/main.go +++ b/internal/generated/snippets/dataproc/apiv1/JobControllerClient/ListJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/JobControllerClient/ListOperations/main.go b/internal/generated/snippets/dataproc/apiv1/JobControllerClient/ListOperations/main.go index a8802e493a57..d00d41d1ea3f 100644 --- a/internal/generated/snippets/dataproc/apiv1/JobControllerClient/ListOperations/main.go +++ b/internal/generated/snippets/dataproc/apiv1/JobControllerClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/JobControllerClient/SetIamPolicy/main.go b/internal/generated/snippets/dataproc/apiv1/JobControllerClient/SetIamPolicy/main.go index 11a63a7de34a..8d30d1d25d66 100644 --- a/internal/generated/snippets/dataproc/apiv1/JobControllerClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/dataproc/apiv1/JobControllerClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/JobControllerClient/SubmitJob/main.go b/internal/generated/snippets/dataproc/apiv1/JobControllerClient/SubmitJob/main.go index 2890eda27c0b..de158a7e4d12 100644 --- a/internal/generated/snippets/dataproc/apiv1/JobControllerClient/SubmitJob/main.go +++ b/internal/generated/snippets/dataproc/apiv1/JobControllerClient/SubmitJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/JobControllerClient/SubmitJobAsOperation/main.go b/internal/generated/snippets/dataproc/apiv1/JobControllerClient/SubmitJobAsOperation/main.go index 4667b68ec390..a552dd308c99 100644 --- a/internal/generated/snippets/dataproc/apiv1/JobControllerClient/SubmitJobAsOperation/main.go +++ b/internal/generated/snippets/dataproc/apiv1/JobControllerClient/SubmitJobAsOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/JobControllerClient/TestIamPermissions/main.go b/internal/generated/snippets/dataproc/apiv1/JobControllerClient/TestIamPermissions/main.go index 13ee81d4675d..4ee9c33dcb02 100644 --- a/internal/generated/snippets/dataproc/apiv1/JobControllerClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/dataproc/apiv1/JobControllerClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/JobControllerClient/UpdateJob/main.go b/internal/generated/snippets/dataproc/apiv1/JobControllerClient/UpdateJob/main.go index 1c77ec653181..bee395844120 100644 --- a/internal/generated/snippets/dataproc/apiv1/JobControllerClient/UpdateJob/main.go +++ b/internal/generated/snippets/dataproc/apiv1/JobControllerClient/UpdateJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/CancelOperation/main.go b/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/CancelOperation/main.go index 02afd9d398b6..6ae2c2ff4e9c 100644 --- a/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/CancelOperation/main.go +++ b/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/CreateNodeGroup/main.go b/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/CreateNodeGroup/main.go index 96426117ba88..9f3d520ce6b0 100644 --- a/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/CreateNodeGroup/main.go +++ b/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/CreateNodeGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/DeleteOperation/main.go b/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/DeleteOperation/main.go index ac0a02b1f793..59c48f4d8e39 100644 --- a/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/DeleteOperation/main.go +++ b/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/GetIamPolicy/main.go b/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/GetIamPolicy/main.go index 827c58937360..1f4e93d75d31 100644 --- a/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/GetNodeGroup/main.go b/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/GetNodeGroup/main.go index 25e05f65e487..6d439329e73d 100644 --- a/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/GetNodeGroup/main.go +++ b/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/GetNodeGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/GetOperation/main.go b/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/GetOperation/main.go index 6de2884c2c6b..df9e765682bd 100644 --- a/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/GetOperation/main.go +++ b/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/ListOperations/main.go b/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/ListOperations/main.go index a48d3502eab5..12b93e39bf07 100644 --- a/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/ListOperations/main.go +++ b/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/ResizeNodeGroup/main.go b/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/ResizeNodeGroup/main.go index 39dfcf468300..e471940b1fae 100644 --- a/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/ResizeNodeGroup/main.go +++ b/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/ResizeNodeGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/SetIamPolicy/main.go b/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/SetIamPolicy/main.go index e0f2a184bcab..d820d7531951 100644 --- a/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/TestIamPermissions/main.go b/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/TestIamPermissions/main.go index e44f0fe0f413..2cce1af50e20 100644 --- a/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/dataproc/apiv1/NodeGroupControllerClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/CancelOperation/main.go b/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/CancelOperation/main.go index 5107d285cddf..4c55e5e6100d 100644 --- a/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/CancelOperation/main.go +++ b/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/CreateSession/main.go b/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/CreateSession/main.go index 9d51b1d2e45a..573ded093686 100644 --- a/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/CreateSession/main.go +++ b/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/CreateSession/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/DeleteOperation/main.go b/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/DeleteOperation/main.go index d0d86411e0ef..972422bf035a 100644 --- a/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/DeleteOperation/main.go +++ b/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/DeleteSession/main.go b/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/DeleteSession/main.go index b8e7ed9bf7b2..52f0caddb0ab 100644 --- a/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/DeleteSession/main.go +++ b/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/DeleteSession/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/GetIamPolicy/main.go b/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/GetIamPolicy/main.go index 3744e38b8635..b1b42e990484 100644 --- a/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/GetOperation/main.go b/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/GetOperation/main.go index 8740fefb45b5..7136370473d3 100644 --- a/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/GetOperation/main.go +++ b/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/GetSession/main.go b/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/GetSession/main.go index 4a1d3596c33b..5aae7efa93ea 100644 --- a/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/GetSession/main.go +++ b/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/GetSession/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/ListOperations/main.go b/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/ListOperations/main.go index b2c4c0e56461..56f3bc86b1e7 100644 --- a/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/ListOperations/main.go +++ b/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/ListSessions/main.go b/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/ListSessions/main.go index d0eb9305edc1..25bdd56023d9 100644 --- a/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/ListSessions/main.go +++ b/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/ListSessions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/SetIamPolicy/main.go b/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/SetIamPolicy/main.go index 2438e331f324..6afaede58bb9 100644 --- a/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/TerminateSession/main.go b/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/TerminateSession/main.go index ce2f9a340a9a..b8a9abebbd2e 100644 --- a/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/TerminateSession/main.go +++ b/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/TerminateSession/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/TestIamPermissions/main.go b/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/TestIamPermissions/main.go index 840c1ea6052e..f51a99921ee6 100644 --- a/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/dataproc/apiv1/SessionControllerClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/CancelOperation/main.go b/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/CancelOperation/main.go index e2eae76f3e13..eae3c6aa4d77 100644 --- a/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/CancelOperation/main.go +++ b/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/CreateSessionTemplate/main.go b/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/CreateSessionTemplate/main.go index 3ca42ff5d37d..bbe15793be34 100644 --- a/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/CreateSessionTemplate/main.go +++ b/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/CreateSessionTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/DeleteOperation/main.go b/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/DeleteOperation/main.go index ad4af8f806cc..bfab070a54d4 100644 --- a/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/DeleteOperation/main.go +++ b/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/DeleteSessionTemplate/main.go b/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/DeleteSessionTemplate/main.go index cc54d782a6ff..d67ef82c387f 100644 --- a/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/DeleteSessionTemplate/main.go +++ b/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/DeleteSessionTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/GetIamPolicy/main.go b/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/GetIamPolicy/main.go index e76f1c4a884b..26214b766c55 100644 --- a/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/GetOperation/main.go b/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/GetOperation/main.go index 8949bdeb451c..3e23a70c8579 100644 --- a/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/GetOperation/main.go +++ b/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/GetSessionTemplate/main.go b/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/GetSessionTemplate/main.go index 31221b612d95..0017c1b463de 100644 --- a/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/GetSessionTemplate/main.go +++ b/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/GetSessionTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/ListOperations/main.go b/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/ListOperations/main.go index d5da21cb932c..88a89fcb7326 100644 --- a/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/ListOperations/main.go +++ b/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/ListSessionTemplates/main.go b/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/ListSessionTemplates/main.go index a6ba5178f086..9d10ac0d6ba9 100644 --- a/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/ListSessionTemplates/main.go +++ b/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/ListSessionTemplates/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/SetIamPolicy/main.go b/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/SetIamPolicy/main.go index 98d3d1d96139..22da1e4c3251 100644 --- a/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/TestIamPermissions/main.go b/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/TestIamPermissions/main.go index 799b4b85a10c..5e19e6ece0c1 100644 --- a/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/UpdateSessionTemplate/main.go b/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/UpdateSessionTemplate/main.go index 12249ef20644..bd3a00a9b62a 100644 --- a/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/UpdateSessionTemplate/main.go +++ b/internal/generated/snippets/dataproc/apiv1/SessionTemplateControllerClient/UpdateSessionTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/CancelOperation/main.go b/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/CancelOperation/main.go index f58ac7bebf93..a8be61720df2 100644 --- a/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/CancelOperation/main.go +++ b/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/CreateWorkflowTemplate/main.go b/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/CreateWorkflowTemplate/main.go index e98b76a19dfe..04a195a208fa 100644 --- a/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/CreateWorkflowTemplate/main.go +++ b/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/CreateWorkflowTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/DeleteOperation/main.go b/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/DeleteOperation/main.go index 27c6b4c081f1..e836351c1b91 100644 --- a/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/DeleteOperation/main.go +++ b/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/DeleteWorkflowTemplate/main.go b/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/DeleteWorkflowTemplate/main.go index 68c9ed52953f..fc0226d6a3bc 100644 --- a/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/DeleteWorkflowTemplate/main.go +++ b/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/DeleteWorkflowTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/GetIamPolicy/main.go b/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/GetIamPolicy/main.go index 311303aeedaf..e961db91a1cf 100644 --- a/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/GetOperation/main.go b/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/GetOperation/main.go index 9253b3dfd0bf..74465114fab6 100644 --- a/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/GetOperation/main.go +++ b/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/GetWorkflowTemplate/main.go b/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/GetWorkflowTemplate/main.go index e66c8c19c40b..cb2b494e04ea 100644 --- a/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/GetWorkflowTemplate/main.go +++ b/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/GetWorkflowTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/InstantiateInlineWorkflowTemplate/main.go b/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/InstantiateInlineWorkflowTemplate/main.go index 0ac93aeae63f..fdec706d0177 100644 --- a/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/InstantiateInlineWorkflowTemplate/main.go +++ b/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/InstantiateInlineWorkflowTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/InstantiateWorkflowTemplate/main.go b/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/InstantiateWorkflowTemplate/main.go index edfd4bf6337e..25ecd3a6b051 100644 --- a/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/InstantiateWorkflowTemplate/main.go +++ b/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/InstantiateWorkflowTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/ListOperations/main.go b/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/ListOperations/main.go index 1d22947b1f30..2a1460658051 100644 --- a/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/ListOperations/main.go +++ b/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/ListWorkflowTemplates/main.go b/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/ListWorkflowTemplates/main.go index 3bcbcb5584b0..04c70145ed4d 100644 --- a/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/ListWorkflowTemplates/main.go +++ b/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/ListWorkflowTemplates/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/SetIamPolicy/main.go b/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/SetIamPolicy/main.go index 77a9d31a6129..e5cefc30c9a0 100644 --- a/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/TestIamPermissions/main.go b/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/TestIamPermissions/main.go index 17ff8c2aa18e..7ac25dc62fcd 100644 --- a/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/UpdateWorkflowTemplate/main.go b/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/UpdateWorkflowTemplate/main.go index e713d24b604d..8c2dce6fed0d 100644 --- a/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/UpdateWorkflowTemplate/main.go +++ b/internal/generated/snippets/dataproc/apiv1/WorkflowTemplateClient/UpdateWorkflowTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataproc/apiv1/snippet_metadata.google.cloud.dataproc.v1.json b/internal/generated/snippets/dataproc/apiv1/snippet_metadata.google.cloud.dataproc.v1.json index 74af7fceabdb..d96c1351b9e6 100644 --- a/internal/generated/snippets/dataproc/apiv1/snippet_metadata.google.cloud.dataproc.v1.json +++ b/internal/generated/snippets/dataproc/apiv1/snippet_metadata.google.cloud.dataproc.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/dataproc/v2/apiv1", - "version": "2.10.0", + "version": "2.10.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/dataqna/apiv1alpha/AutoSuggestionClient/SuggestQueries/main.go b/internal/generated/snippets/dataqna/apiv1alpha/AutoSuggestionClient/SuggestQueries/main.go index a6b8cc795aad..a1d706d6fde4 100644 --- a/internal/generated/snippets/dataqna/apiv1alpha/AutoSuggestionClient/SuggestQueries/main.go +++ b/internal/generated/snippets/dataqna/apiv1alpha/AutoSuggestionClient/SuggestQueries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataqna/apiv1alpha/QuestionClient/CreateQuestion/main.go b/internal/generated/snippets/dataqna/apiv1alpha/QuestionClient/CreateQuestion/main.go index fea6bc755bde..db5626aeb110 100644 --- a/internal/generated/snippets/dataqna/apiv1alpha/QuestionClient/CreateQuestion/main.go +++ b/internal/generated/snippets/dataqna/apiv1alpha/QuestionClient/CreateQuestion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataqna/apiv1alpha/QuestionClient/ExecuteQuestion/main.go b/internal/generated/snippets/dataqna/apiv1alpha/QuestionClient/ExecuteQuestion/main.go index 7a68d2b9464b..92c4ea7bfeb5 100644 --- a/internal/generated/snippets/dataqna/apiv1alpha/QuestionClient/ExecuteQuestion/main.go +++ b/internal/generated/snippets/dataqna/apiv1alpha/QuestionClient/ExecuteQuestion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataqna/apiv1alpha/QuestionClient/GetQuestion/main.go b/internal/generated/snippets/dataqna/apiv1alpha/QuestionClient/GetQuestion/main.go index e917c2c82900..61f492d10050 100644 --- a/internal/generated/snippets/dataqna/apiv1alpha/QuestionClient/GetQuestion/main.go +++ b/internal/generated/snippets/dataqna/apiv1alpha/QuestionClient/GetQuestion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataqna/apiv1alpha/QuestionClient/GetUserFeedback/main.go b/internal/generated/snippets/dataqna/apiv1alpha/QuestionClient/GetUserFeedback/main.go index 35a09e9b0df9..01d9b9b987de 100644 --- a/internal/generated/snippets/dataqna/apiv1alpha/QuestionClient/GetUserFeedback/main.go +++ b/internal/generated/snippets/dataqna/apiv1alpha/QuestionClient/GetUserFeedback/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dataqna/apiv1alpha/QuestionClient/UpdateUserFeedback/main.go b/internal/generated/snippets/dataqna/apiv1alpha/QuestionClient/UpdateUserFeedback/main.go index 39682315b341..8a08dfabf38b 100644 --- a/internal/generated/snippets/dataqna/apiv1alpha/QuestionClient/UpdateUserFeedback/main.go +++ b/internal/generated/snippets/dataqna/apiv1alpha/QuestionClient/UpdateUserFeedback/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/CancelOperation/main.go b/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/CancelOperation/main.go index b9c7a1cd879e..d8e3c55f9f42 100644 --- a/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/CancelOperation/main.go +++ b/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/CreateIndex/main.go b/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/CreateIndex/main.go index b30964aef902..0092586fe807 100644 --- a/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/CreateIndex/main.go +++ b/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/CreateIndex/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/DeleteIndex/main.go b/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/DeleteIndex/main.go index 6425a64d5d63..0844998d1242 100644 --- a/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/DeleteIndex/main.go +++ b/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/DeleteIndex/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/DeleteOperation/main.go b/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/DeleteOperation/main.go index 4f46a1ac73fb..df07b3d9f539 100644 --- a/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/DeleteOperation/main.go +++ b/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/ExportEntities/main.go b/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/ExportEntities/main.go index 04c1177c9b1d..726245445434 100644 --- a/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/ExportEntities/main.go +++ b/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/ExportEntities/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/GetIndex/main.go b/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/GetIndex/main.go index 66076608ee68..0409d4eac94c 100644 --- a/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/GetIndex/main.go +++ b/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/GetIndex/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/GetOperation/main.go b/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/GetOperation/main.go index fb8c96dddd87..a8398e982773 100644 --- a/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/GetOperation/main.go +++ b/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/ImportEntities/main.go b/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/ImportEntities/main.go index 50a3ba41736c..732c767edf69 100644 --- a/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/ImportEntities/main.go +++ b/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/ImportEntities/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/ListIndexes/main.go b/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/ListIndexes/main.go index ecc1a918723b..93091d58db6b 100644 --- a/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/ListIndexes/main.go +++ b/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/ListIndexes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/ListOperations/main.go b/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/ListOperations/main.go index ee76b9b3c984..5fa36b4450b7 100644 --- a/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/ListOperations/main.go +++ b/internal/generated/snippets/datastore/admin/apiv1/DatastoreAdminClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/datastream/apiv1/Client/CancelOperation/main.go index 8d144a3fcc2e..f43f6319f61d 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/CreateConnectionProfile/main.go b/internal/generated/snippets/datastream/apiv1/Client/CreateConnectionProfile/main.go index 520aa9392747..744b0ae64565 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/CreateConnectionProfile/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/CreateConnectionProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/CreatePrivateConnection/main.go b/internal/generated/snippets/datastream/apiv1/Client/CreatePrivateConnection/main.go index 194294b6dd7a..2edbb024d07c 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/CreatePrivateConnection/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/CreatePrivateConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/CreateRoute/main.go b/internal/generated/snippets/datastream/apiv1/Client/CreateRoute/main.go index 5041395956de..f2dd6fd86ec0 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/CreateRoute/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/CreateRoute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/CreateStream/main.go b/internal/generated/snippets/datastream/apiv1/Client/CreateStream/main.go index 932f33f60607..c9b7dd11c8e1 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/CreateStream/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/CreateStream/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/DeleteConnectionProfile/main.go b/internal/generated/snippets/datastream/apiv1/Client/DeleteConnectionProfile/main.go index e6f99fdc13c4..47e5d95bcf32 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/DeleteConnectionProfile/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/DeleteConnectionProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/datastream/apiv1/Client/DeleteOperation/main.go index 32bc88d11f08..b9adf25f8b54 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/DeletePrivateConnection/main.go b/internal/generated/snippets/datastream/apiv1/Client/DeletePrivateConnection/main.go index 59953b8d849a..aeff8e6a9eb5 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/DeletePrivateConnection/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/DeletePrivateConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/DeleteRoute/main.go b/internal/generated/snippets/datastream/apiv1/Client/DeleteRoute/main.go index 9258da4a6184..328e5a51ef1b 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/DeleteRoute/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/DeleteRoute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/DeleteStream/main.go b/internal/generated/snippets/datastream/apiv1/Client/DeleteStream/main.go index 221ee2128f34..975b68b88bb1 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/DeleteStream/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/DeleteStream/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/DiscoverConnectionProfile/main.go b/internal/generated/snippets/datastream/apiv1/Client/DiscoverConnectionProfile/main.go index 996585f093f8..c8d384d274ee 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/DiscoverConnectionProfile/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/DiscoverConnectionProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/FetchStaticIps/main.go b/internal/generated/snippets/datastream/apiv1/Client/FetchStaticIps/main.go index d7c0fee27d59..55c0d081f21c 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/FetchStaticIps/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/FetchStaticIps/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/GetConnectionProfile/main.go b/internal/generated/snippets/datastream/apiv1/Client/GetConnectionProfile/main.go index 3f3b9cc6fb6d..fa1575b60f06 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/GetConnectionProfile/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/GetConnectionProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/datastream/apiv1/Client/GetLocation/main.go index 589d67ccd1b1..d7c557ade392 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/datastream/apiv1/Client/GetOperation/main.go index 34c9a535fe4e..edfbbaf3ce4c 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/GetPrivateConnection/main.go b/internal/generated/snippets/datastream/apiv1/Client/GetPrivateConnection/main.go index 4242d6b18113..7d5851e9c478 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/GetPrivateConnection/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/GetPrivateConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/GetRoute/main.go b/internal/generated/snippets/datastream/apiv1/Client/GetRoute/main.go index c51b8815f756..c60e8755e3bc 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/GetRoute/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/GetRoute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/GetStream/main.go b/internal/generated/snippets/datastream/apiv1/Client/GetStream/main.go index 4e396f3325ed..97fe90f0b81b 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/GetStream/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/GetStream/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/GetStreamObject/main.go b/internal/generated/snippets/datastream/apiv1/Client/GetStreamObject/main.go index 72b5c1bcb20f..09f5fb972828 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/GetStreamObject/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/GetStreamObject/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/ListConnectionProfiles/main.go b/internal/generated/snippets/datastream/apiv1/Client/ListConnectionProfiles/main.go index 428d7fba3024..f6cc1a61dece 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/ListConnectionProfiles/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/ListConnectionProfiles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/datastream/apiv1/Client/ListLocations/main.go index fe06af320c14..b2988e3a7da2 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/datastream/apiv1/Client/ListOperations/main.go index 5f09a8a325b8..3ee4d9cef355 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/ListPrivateConnections/main.go b/internal/generated/snippets/datastream/apiv1/Client/ListPrivateConnections/main.go index 822ec62125e0..8b03bcf905dd 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/ListPrivateConnections/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/ListPrivateConnections/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/ListRoutes/main.go b/internal/generated/snippets/datastream/apiv1/Client/ListRoutes/main.go index 7177ca1a0d6a..7dae618cdf00 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/ListRoutes/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/ListRoutes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/ListStreamObjects/main.go b/internal/generated/snippets/datastream/apiv1/Client/ListStreamObjects/main.go index c53fa88ff3dd..2b8f2f876b86 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/ListStreamObjects/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/ListStreamObjects/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/ListStreams/main.go b/internal/generated/snippets/datastream/apiv1/Client/ListStreams/main.go index 31b5724e053e..31166fdae593 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/ListStreams/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/ListStreams/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/LookupStreamObject/main.go b/internal/generated/snippets/datastream/apiv1/Client/LookupStreamObject/main.go index ae047c159d98..7730adb45260 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/LookupStreamObject/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/LookupStreamObject/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/RunStream/main.go b/internal/generated/snippets/datastream/apiv1/Client/RunStream/main.go index 055ed1d88cb3..b6a0d9b76c22 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/RunStream/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/RunStream/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/StartBackfillJob/main.go b/internal/generated/snippets/datastream/apiv1/Client/StartBackfillJob/main.go index 06d1c45e9e2b..97571e561eca 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/StartBackfillJob/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/StartBackfillJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/StopBackfillJob/main.go b/internal/generated/snippets/datastream/apiv1/Client/StopBackfillJob/main.go index 5c95ff68465a..55ea5e49a037 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/StopBackfillJob/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/StopBackfillJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/UpdateConnectionProfile/main.go b/internal/generated/snippets/datastream/apiv1/Client/UpdateConnectionProfile/main.go index 88018d621215..39df70f24ca8 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/UpdateConnectionProfile/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/UpdateConnectionProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1/Client/UpdateStream/main.go b/internal/generated/snippets/datastream/apiv1/Client/UpdateStream/main.go index 7cc29170c8a3..a9f4e0055b37 100644 --- a/internal/generated/snippets/datastream/apiv1/Client/UpdateStream/main.go +++ b/internal/generated/snippets/datastream/apiv1/Client/UpdateStream/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1alpha1/Client/CreateConnectionProfile/main.go b/internal/generated/snippets/datastream/apiv1alpha1/Client/CreateConnectionProfile/main.go index 387bc4534599..559cc786c706 100644 --- a/internal/generated/snippets/datastream/apiv1alpha1/Client/CreateConnectionProfile/main.go +++ b/internal/generated/snippets/datastream/apiv1alpha1/Client/CreateConnectionProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1alpha1/Client/CreatePrivateConnection/main.go b/internal/generated/snippets/datastream/apiv1alpha1/Client/CreatePrivateConnection/main.go index 861e575ba306..1056b75de8cc 100644 --- a/internal/generated/snippets/datastream/apiv1alpha1/Client/CreatePrivateConnection/main.go +++ b/internal/generated/snippets/datastream/apiv1alpha1/Client/CreatePrivateConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1alpha1/Client/CreateRoute/main.go b/internal/generated/snippets/datastream/apiv1alpha1/Client/CreateRoute/main.go index 850388f5cee3..96bb04057f5f 100644 --- a/internal/generated/snippets/datastream/apiv1alpha1/Client/CreateRoute/main.go +++ b/internal/generated/snippets/datastream/apiv1alpha1/Client/CreateRoute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1alpha1/Client/CreateStream/main.go b/internal/generated/snippets/datastream/apiv1alpha1/Client/CreateStream/main.go index c4bd6f5b1113..19938a8ec0d3 100644 --- a/internal/generated/snippets/datastream/apiv1alpha1/Client/CreateStream/main.go +++ b/internal/generated/snippets/datastream/apiv1alpha1/Client/CreateStream/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1alpha1/Client/DeleteConnectionProfile/main.go b/internal/generated/snippets/datastream/apiv1alpha1/Client/DeleteConnectionProfile/main.go index d99dd2bf4a5a..0997c002ceaa 100644 --- a/internal/generated/snippets/datastream/apiv1alpha1/Client/DeleteConnectionProfile/main.go +++ b/internal/generated/snippets/datastream/apiv1alpha1/Client/DeleteConnectionProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1alpha1/Client/DeletePrivateConnection/main.go b/internal/generated/snippets/datastream/apiv1alpha1/Client/DeletePrivateConnection/main.go index 06540176133c..a6fd17580029 100644 --- a/internal/generated/snippets/datastream/apiv1alpha1/Client/DeletePrivateConnection/main.go +++ b/internal/generated/snippets/datastream/apiv1alpha1/Client/DeletePrivateConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1alpha1/Client/DeleteRoute/main.go b/internal/generated/snippets/datastream/apiv1alpha1/Client/DeleteRoute/main.go index 06463a93854f..d7606756f34a 100644 --- a/internal/generated/snippets/datastream/apiv1alpha1/Client/DeleteRoute/main.go +++ b/internal/generated/snippets/datastream/apiv1alpha1/Client/DeleteRoute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1alpha1/Client/DeleteStream/main.go b/internal/generated/snippets/datastream/apiv1alpha1/Client/DeleteStream/main.go index 2eccf267f20d..89e50ea52387 100644 --- a/internal/generated/snippets/datastream/apiv1alpha1/Client/DeleteStream/main.go +++ b/internal/generated/snippets/datastream/apiv1alpha1/Client/DeleteStream/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1alpha1/Client/DiscoverConnectionProfile/main.go b/internal/generated/snippets/datastream/apiv1alpha1/Client/DiscoverConnectionProfile/main.go index 7c2e9e04ca92..dd2024ada455 100644 --- a/internal/generated/snippets/datastream/apiv1alpha1/Client/DiscoverConnectionProfile/main.go +++ b/internal/generated/snippets/datastream/apiv1alpha1/Client/DiscoverConnectionProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1alpha1/Client/FetchErrors/main.go b/internal/generated/snippets/datastream/apiv1alpha1/Client/FetchErrors/main.go index 74530e3563b4..7b53008beabc 100644 --- a/internal/generated/snippets/datastream/apiv1alpha1/Client/FetchErrors/main.go +++ b/internal/generated/snippets/datastream/apiv1alpha1/Client/FetchErrors/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1alpha1/Client/FetchStaticIps/main.go b/internal/generated/snippets/datastream/apiv1alpha1/Client/FetchStaticIps/main.go index 582045c3ba7f..d0c8a499908a 100644 --- a/internal/generated/snippets/datastream/apiv1alpha1/Client/FetchStaticIps/main.go +++ b/internal/generated/snippets/datastream/apiv1alpha1/Client/FetchStaticIps/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1alpha1/Client/GetConnectionProfile/main.go b/internal/generated/snippets/datastream/apiv1alpha1/Client/GetConnectionProfile/main.go index 95b568e12b9f..9910919be635 100644 --- a/internal/generated/snippets/datastream/apiv1alpha1/Client/GetConnectionProfile/main.go +++ b/internal/generated/snippets/datastream/apiv1alpha1/Client/GetConnectionProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1alpha1/Client/GetPrivateConnection/main.go b/internal/generated/snippets/datastream/apiv1alpha1/Client/GetPrivateConnection/main.go index 3b842b9b964c..d7c5132ed6fd 100644 --- a/internal/generated/snippets/datastream/apiv1alpha1/Client/GetPrivateConnection/main.go +++ b/internal/generated/snippets/datastream/apiv1alpha1/Client/GetPrivateConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1alpha1/Client/GetRoute/main.go b/internal/generated/snippets/datastream/apiv1alpha1/Client/GetRoute/main.go index 70ae72b6d247..64b4222aeaed 100644 --- a/internal/generated/snippets/datastream/apiv1alpha1/Client/GetRoute/main.go +++ b/internal/generated/snippets/datastream/apiv1alpha1/Client/GetRoute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1alpha1/Client/GetStream/main.go b/internal/generated/snippets/datastream/apiv1alpha1/Client/GetStream/main.go index 0b081a8faa18..a58656765ae8 100644 --- a/internal/generated/snippets/datastream/apiv1alpha1/Client/GetStream/main.go +++ b/internal/generated/snippets/datastream/apiv1alpha1/Client/GetStream/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1alpha1/Client/ListConnectionProfiles/main.go b/internal/generated/snippets/datastream/apiv1alpha1/Client/ListConnectionProfiles/main.go index 39247ca0dfeb..874640b137ae 100644 --- a/internal/generated/snippets/datastream/apiv1alpha1/Client/ListConnectionProfiles/main.go +++ b/internal/generated/snippets/datastream/apiv1alpha1/Client/ListConnectionProfiles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1alpha1/Client/ListPrivateConnections/main.go b/internal/generated/snippets/datastream/apiv1alpha1/Client/ListPrivateConnections/main.go index 509d274b1cab..dd7ae705d5f5 100644 --- a/internal/generated/snippets/datastream/apiv1alpha1/Client/ListPrivateConnections/main.go +++ b/internal/generated/snippets/datastream/apiv1alpha1/Client/ListPrivateConnections/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1alpha1/Client/ListRoutes/main.go b/internal/generated/snippets/datastream/apiv1alpha1/Client/ListRoutes/main.go index 416ef01dcf30..1b45755aca27 100644 --- a/internal/generated/snippets/datastream/apiv1alpha1/Client/ListRoutes/main.go +++ b/internal/generated/snippets/datastream/apiv1alpha1/Client/ListRoutes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1alpha1/Client/ListStreams/main.go b/internal/generated/snippets/datastream/apiv1alpha1/Client/ListStreams/main.go index 566d6a030773..3bf003eb4ccf 100644 --- a/internal/generated/snippets/datastream/apiv1alpha1/Client/ListStreams/main.go +++ b/internal/generated/snippets/datastream/apiv1alpha1/Client/ListStreams/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1alpha1/Client/UpdateConnectionProfile/main.go b/internal/generated/snippets/datastream/apiv1alpha1/Client/UpdateConnectionProfile/main.go index 9232bad5678b..54e67cc0d6a2 100644 --- a/internal/generated/snippets/datastream/apiv1alpha1/Client/UpdateConnectionProfile/main.go +++ b/internal/generated/snippets/datastream/apiv1alpha1/Client/UpdateConnectionProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/datastream/apiv1alpha1/Client/UpdateStream/main.go b/internal/generated/snippets/datastream/apiv1alpha1/Client/UpdateStream/main.go index 793ee0e2906c..436fc157086c 100644 --- a/internal/generated/snippets/datastream/apiv1alpha1/Client/UpdateStream/main.go +++ b/internal/generated/snippets/datastream/apiv1alpha1/Client/UpdateStream/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/AbandonRelease/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/AbandonRelease/main.go index 96f2ac367fdd..a76304b3c914 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/AbandonRelease/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/AbandonRelease/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/AdvanceRollout/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/AdvanceRollout/main.go index f7118d2d9c0e..806caa91d5e8 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/AdvanceRollout/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/AdvanceRollout/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ApproveRollout/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ApproveRollout/main.go index 163b122a1459..312a97f9ce93 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ApproveRollout/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ApproveRollout/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CancelAutomationRun/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CancelAutomationRun/main.go index 8c5719710a7d..5a612cb5b9a1 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CancelAutomationRun/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CancelAutomationRun/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CancelOperation/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CancelOperation/main.go index f0335251ceb9..34e89e4e7556 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CancelOperation/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CancelRollout/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CancelRollout/main.go index 6d983966ca4f..3ec3cfd9fd1f 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CancelRollout/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CancelRollout/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CreateAutomation/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CreateAutomation/main.go index 9f1025d51fe7..4c7e7a68e52c 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CreateAutomation/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CreateAutomation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CreateCustomTargetType/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CreateCustomTargetType/main.go index b34ef36658b4..328690db2e12 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CreateCustomTargetType/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CreateCustomTargetType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CreateDeliveryPipeline/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CreateDeliveryPipeline/main.go index 8405d2ad9089..48adcfcfa0ce 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CreateDeliveryPipeline/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CreateDeliveryPipeline/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CreateDeployPolicy/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CreateDeployPolicy/main.go index dafc47ce5c90..9e46e0db4c78 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CreateDeployPolicy/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CreateDeployPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CreateRelease/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CreateRelease/main.go index 0e6c658f93fa..017c459af5b7 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CreateRelease/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CreateRelease/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CreateRollout/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CreateRollout/main.go index f51290325804..2391477cb3a0 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CreateRollout/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CreateRollout/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CreateTarget/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CreateTarget/main.go index fd055524717f..ecf9f69e8376 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CreateTarget/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/CreateTarget/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/DeleteAutomation/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/DeleteAutomation/main.go index 4e4883b2d7e7..ae614a772ebe 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/DeleteAutomation/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/DeleteAutomation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/DeleteCustomTargetType/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/DeleteCustomTargetType/main.go index e28ab3691598..7e2ff971148f 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/DeleteCustomTargetType/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/DeleteCustomTargetType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/DeleteDeliveryPipeline/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/DeleteDeliveryPipeline/main.go index 7e7c17d624b9..28a54898ef52 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/DeleteDeliveryPipeline/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/DeleteDeliveryPipeline/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/DeleteDeployPolicy/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/DeleteDeployPolicy/main.go index 013f36f0e4b9..41018e97d5aa 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/DeleteDeployPolicy/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/DeleteDeployPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/DeleteOperation/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/DeleteOperation/main.go index d37b22c33400..8e0b8bbe00fc 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/DeleteOperation/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/DeleteTarget/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/DeleteTarget/main.go index b0d82f8917d9..cee02ad7d9d0 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/DeleteTarget/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/DeleteTarget/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetAutomation/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetAutomation/main.go index fe936e9d7983..8b0681b25acf 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetAutomation/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetAutomation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetAutomationRun/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetAutomationRun/main.go index ec77422dc986..6e840e092b88 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetAutomationRun/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetAutomationRun/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetConfig/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetConfig/main.go index 1cee34354f43..db69ee90f4df 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetConfig/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetCustomTargetType/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetCustomTargetType/main.go index 458c3e884872..9900c5b5ed06 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetCustomTargetType/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetCustomTargetType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetDeliveryPipeline/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetDeliveryPipeline/main.go index 11b90f659390..3765865d8130 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetDeliveryPipeline/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetDeliveryPipeline/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetDeployPolicy/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetDeployPolicy/main.go index 60cf83aac016..e057c948edd8 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetDeployPolicy/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetDeployPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetIamPolicy/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetIamPolicy/main.go index e12058df6a78..0f6af1bbaf57 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetJobRun/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetJobRun/main.go index f895a18671b0..26b9c36cf96e 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetJobRun/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetJobRun/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetLocation/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetLocation/main.go index 476352e3ba70..ff0eb2ee2b3f 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetLocation/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetOperation/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetOperation/main.go index e42495b39b8d..2545d53ffd91 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetOperation/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetRelease/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetRelease/main.go index d53a011c14f7..4177d3b0daab 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetRelease/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetRelease/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetRollout/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetRollout/main.go index 7d55bc16ca9c..9c01d2b01d8a 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetRollout/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetRollout/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetTarget/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetTarget/main.go index d10ef5393aa1..8c6ca65e3043 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetTarget/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/GetTarget/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/IgnoreJob/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/IgnoreJob/main.go index 1b0be2124baa..51935552a23b 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/IgnoreJob/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/IgnoreJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListAutomationRuns/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListAutomationRuns/main.go index 6daf0e3097a6..c75e312b0909 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListAutomationRuns/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListAutomationRuns/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListAutomations/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListAutomations/main.go index 4ac87b997b87..f2c4e9b6348d 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListAutomations/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListAutomations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListCustomTargetTypes/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListCustomTargetTypes/main.go index 416d8df771e3..bd9ace757bc2 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListCustomTargetTypes/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListCustomTargetTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListDeliveryPipelines/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListDeliveryPipelines/main.go index dcc077435d60..25ce99f2564d 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListDeliveryPipelines/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListDeliveryPipelines/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListDeployPolicies/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListDeployPolicies/main.go index a4424e6283c8..f7f9478c67f3 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListDeployPolicies/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListDeployPolicies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListJobRuns/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListJobRuns/main.go index 24ac7e033229..77616ac17655 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListJobRuns/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListJobRuns/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListLocations/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListLocations/main.go index 95081cb3e4ec..986e784ffd74 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListLocations/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListOperations/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListOperations/main.go index 993f603969f6..f5433de67b45 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListOperations/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListReleases/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListReleases/main.go index ac284c0da585..0e6b582eb0b4 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListReleases/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListReleases/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListRollouts/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListRollouts/main.go index a35c7dd1350e..401b207ef07c 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListRollouts/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListRollouts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListTargets/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListTargets/main.go index 2b2d2c3cc50e..35c01e75bbd4 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListTargets/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/ListTargets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/RetryJob/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/RetryJob/main.go index 05c3ca6d3bfe..397a5423377d 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/RetryJob/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/RetryJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/RollbackTarget/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/RollbackTarget/main.go index feb0e7e9bcc2..84150b7d0e39 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/RollbackTarget/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/RollbackTarget/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/SetIamPolicy/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/SetIamPolicy/main.go index df9b08296a2d..bdaa451815b1 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/TerminateJobRun/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/TerminateJobRun/main.go index bd065f8f17fd..659c10b4650c 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/TerminateJobRun/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/TerminateJobRun/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/TestIamPermissions/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/TestIamPermissions/main.go index 2c572d91e7ea..6bf45a8d005d 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/UpdateAutomation/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/UpdateAutomation/main.go index 2df76fb291a7..d05b118882e9 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/UpdateAutomation/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/UpdateAutomation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/UpdateCustomTargetType/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/UpdateCustomTargetType/main.go index 790c798b358f..64452a9cd1e6 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/UpdateCustomTargetType/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/UpdateCustomTargetType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/UpdateDeliveryPipeline/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/UpdateDeliveryPipeline/main.go index 471bc8d5f3fd..a2c72cc0d2c5 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/UpdateDeliveryPipeline/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/UpdateDeliveryPipeline/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/UpdateDeployPolicy/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/UpdateDeployPolicy/main.go index 755487f56c67..87bfe0306de1 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/UpdateDeployPolicy/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/UpdateDeployPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/UpdateTarget/main.go b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/UpdateTarget/main.go index eab710509e59..d83b3fe9828a 100644 --- a/internal/generated/snippets/deploy/apiv1/CloudDeployClient/UpdateTarget/main.go +++ b/internal/generated/snippets/deploy/apiv1/CloudDeployClient/UpdateTarget/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/deploy/apiv1/snippet_metadata.google.cloud.deploy.v1.json b/internal/generated/snippets/deploy/apiv1/snippet_metadata.google.cloud.deploy.v1.json index 03072a7dd95b..d58498381826 100644 --- a/internal/generated/snippets/deploy/apiv1/snippet_metadata.google.cloud.deploy.v1.json +++ b/internal/generated/snippets/deploy/apiv1/snippet_metadata.google.cloud.deploy.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/deploy/apiv1", - "version": "1.26.0", + "version": "1.26.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/developerconnect/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/developerconnect/apiv1/Client/CancelOperation/main.go index c0f8fb05424c..3925dc153037 100644 --- a/internal/generated/snippets/developerconnect/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/developerconnect/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/developerconnect/apiv1/Client/CreateConnection/main.go b/internal/generated/snippets/developerconnect/apiv1/Client/CreateConnection/main.go index 76f203936cff..1d43ab643ce0 100644 --- a/internal/generated/snippets/developerconnect/apiv1/Client/CreateConnection/main.go +++ b/internal/generated/snippets/developerconnect/apiv1/Client/CreateConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/developerconnect/apiv1/Client/CreateGitRepositoryLink/main.go b/internal/generated/snippets/developerconnect/apiv1/Client/CreateGitRepositoryLink/main.go index 82d4f030c1af..3e46139a5047 100644 --- a/internal/generated/snippets/developerconnect/apiv1/Client/CreateGitRepositoryLink/main.go +++ b/internal/generated/snippets/developerconnect/apiv1/Client/CreateGitRepositoryLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/developerconnect/apiv1/Client/DeleteConnection/main.go b/internal/generated/snippets/developerconnect/apiv1/Client/DeleteConnection/main.go index 69429a1dd907..3244e4c15eed 100644 --- a/internal/generated/snippets/developerconnect/apiv1/Client/DeleteConnection/main.go +++ b/internal/generated/snippets/developerconnect/apiv1/Client/DeleteConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/developerconnect/apiv1/Client/DeleteGitRepositoryLink/main.go b/internal/generated/snippets/developerconnect/apiv1/Client/DeleteGitRepositoryLink/main.go index 1f54975d0286..6981f13d1290 100644 --- a/internal/generated/snippets/developerconnect/apiv1/Client/DeleteGitRepositoryLink/main.go +++ b/internal/generated/snippets/developerconnect/apiv1/Client/DeleteGitRepositoryLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/developerconnect/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/developerconnect/apiv1/Client/DeleteOperation/main.go index 60b900026f7f..d3dd2b040806 100644 --- a/internal/generated/snippets/developerconnect/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/developerconnect/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/developerconnect/apiv1/Client/FetchGitHubInstallations/main.go b/internal/generated/snippets/developerconnect/apiv1/Client/FetchGitHubInstallations/main.go index 22561553631a..0b6e613a74f6 100644 --- a/internal/generated/snippets/developerconnect/apiv1/Client/FetchGitHubInstallations/main.go +++ b/internal/generated/snippets/developerconnect/apiv1/Client/FetchGitHubInstallations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/developerconnect/apiv1/Client/FetchGitRefs/main.go b/internal/generated/snippets/developerconnect/apiv1/Client/FetchGitRefs/main.go index e4cf838d94ec..dc8a0a4a42d3 100644 --- a/internal/generated/snippets/developerconnect/apiv1/Client/FetchGitRefs/main.go +++ b/internal/generated/snippets/developerconnect/apiv1/Client/FetchGitRefs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/developerconnect/apiv1/Client/FetchLinkableGitRepositories/main.go b/internal/generated/snippets/developerconnect/apiv1/Client/FetchLinkableGitRepositories/main.go index 32ebb1808526..2397d3892feb 100644 --- a/internal/generated/snippets/developerconnect/apiv1/Client/FetchLinkableGitRepositories/main.go +++ b/internal/generated/snippets/developerconnect/apiv1/Client/FetchLinkableGitRepositories/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/developerconnect/apiv1/Client/FetchReadToken/main.go b/internal/generated/snippets/developerconnect/apiv1/Client/FetchReadToken/main.go index cd0f5862f057..15b6bdebdf1b 100644 --- a/internal/generated/snippets/developerconnect/apiv1/Client/FetchReadToken/main.go +++ b/internal/generated/snippets/developerconnect/apiv1/Client/FetchReadToken/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/developerconnect/apiv1/Client/FetchReadWriteToken/main.go b/internal/generated/snippets/developerconnect/apiv1/Client/FetchReadWriteToken/main.go index 1c840686f1e1..4e109ca6779f 100644 --- a/internal/generated/snippets/developerconnect/apiv1/Client/FetchReadWriteToken/main.go +++ b/internal/generated/snippets/developerconnect/apiv1/Client/FetchReadWriteToken/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/developerconnect/apiv1/Client/GetConnection/main.go b/internal/generated/snippets/developerconnect/apiv1/Client/GetConnection/main.go index 25a715cfd6a1..928b299c1a05 100644 --- a/internal/generated/snippets/developerconnect/apiv1/Client/GetConnection/main.go +++ b/internal/generated/snippets/developerconnect/apiv1/Client/GetConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/developerconnect/apiv1/Client/GetGitRepositoryLink/main.go b/internal/generated/snippets/developerconnect/apiv1/Client/GetGitRepositoryLink/main.go index 37dde3f6c739..274efda9c40d 100644 --- a/internal/generated/snippets/developerconnect/apiv1/Client/GetGitRepositoryLink/main.go +++ b/internal/generated/snippets/developerconnect/apiv1/Client/GetGitRepositoryLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/developerconnect/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/developerconnect/apiv1/Client/GetLocation/main.go index d44f1ed8cc64..0a534d5acd71 100644 --- a/internal/generated/snippets/developerconnect/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/developerconnect/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/developerconnect/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/developerconnect/apiv1/Client/GetOperation/main.go index 0daa6f8e5fb9..ca72586d6c46 100644 --- a/internal/generated/snippets/developerconnect/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/developerconnect/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/developerconnect/apiv1/Client/ListConnections/main.go b/internal/generated/snippets/developerconnect/apiv1/Client/ListConnections/main.go index ffdfd3844224..8a68aec02de8 100644 --- a/internal/generated/snippets/developerconnect/apiv1/Client/ListConnections/main.go +++ b/internal/generated/snippets/developerconnect/apiv1/Client/ListConnections/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/developerconnect/apiv1/Client/ListGitRepositoryLinks/main.go b/internal/generated/snippets/developerconnect/apiv1/Client/ListGitRepositoryLinks/main.go index 49bf80e89335..fe5bb9f84e11 100644 --- a/internal/generated/snippets/developerconnect/apiv1/Client/ListGitRepositoryLinks/main.go +++ b/internal/generated/snippets/developerconnect/apiv1/Client/ListGitRepositoryLinks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/developerconnect/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/developerconnect/apiv1/Client/ListLocations/main.go index 62917ca3f7a6..b1af949e8c19 100644 --- a/internal/generated/snippets/developerconnect/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/developerconnect/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/developerconnect/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/developerconnect/apiv1/Client/ListOperations/main.go index 0458fec88abc..405e7fc2248a 100644 --- a/internal/generated/snippets/developerconnect/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/developerconnect/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/developerconnect/apiv1/Client/UpdateConnection/main.go b/internal/generated/snippets/developerconnect/apiv1/Client/UpdateConnection/main.go index 0efa783392ff..2f7ed14e2606 100644 --- a/internal/generated/snippets/developerconnect/apiv1/Client/UpdateConnection/main.go +++ b/internal/generated/snippets/developerconnect/apiv1/Client/UpdateConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/developerconnect/apiv1/snippet_metadata.google.cloud.developerconnect.v1.json b/internal/generated/snippets/developerconnect/apiv1/snippet_metadata.google.cloud.developerconnect.v1.json index 9fbf8f9e94b0..891cb90e29f0 100644 --- a/internal/generated/snippets/developerconnect/apiv1/snippet_metadata.google.cloud.developerconnect.v1.json +++ b/internal/generated/snippets/developerconnect/apiv1/snippet_metadata.google.cloud.developerconnect.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/developerconnect/apiv1", - "version": "0.3.0", + "version": "0.3.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/dialogflow/apiv2/AgentsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/AgentsClient/CancelOperation/main.go index c8057e667e4a..99cfdf8a0e47 100644 --- a/internal/generated/snippets/dialogflow/apiv2/AgentsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/AgentsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/AgentsClient/DeleteAgent/main.go b/internal/generated/snippets/dialogflow/apiv2/AgentsClient/DeleteAgent/main.go index e9c04e70241e..772ca0eb4125 100644 --- a/internal/generated/snippets/dialogflow/apiv2/AgentsClient/DeleteAgent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/AgentsClient/DeleteAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/AgentsClient/ExportAgent/main.go b/internal/generated/snippets/dialogflow/apiv2/AgentsClient/ExportAgent/main.go index 1a13409b93c7..fa4547dee119 100644 --- a/internal/generated/snippets/dialogflow/apiv2/AgentsClient/ExportAgent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/AgentsClient/ExportAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/AgentsClient/GetAgent/main.go b/internal/generated/snippets/dialogflow/apiv2/AgentsClient/GetAgent/main.go index 31395b2fd491..e453b7871538 100644 --- a/internal/generated/snippets/dialogflow/apiv2/AgentsClient/GetAgent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/AgentsClient/GetAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/AgentsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2/AgentsClient/GetLocation/main.go index 1c88c7c2079e..469bc20e8295 100644 --- a/internal/generated/snippets/dialogflow/apiv2/AgentsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/AgentsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/AgentsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/AgentsClient/GetOperation/main.go index fe58d48ee980..2d84778be045 100644 --- a/internal/generated/snippets/dialogflow/apiv2/AgentsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/AgentsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/AgentsClient/GetValidationResult/main.go b/internal/generated/snippets/dialogflow/apiv2/AgentsClient/GetValidationResult/main.go index 278c89400a97..f9e4fe4a9a0b 100644 --- a/internal/generated/snippets/dialogflow/apiv2/AgentsClient/GetValidationResult/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/AgentsClient/GetValidationResult/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/AgentsClient/ImportAgent/main.go b/internal/generated/snippets/dialogflow/apiv2/AgentsClient/ImportAgent/main.go index 4b7878096827..aa998b194159 100644 --- a/internal/generated/snippets/dialogflow/apiv2/AgentsClient/ImportAgent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/AgentsClient/ImportAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/AgentsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2/AgentsClient/ListLocations/main.go index dd6f1f041a25..03a5510526fc 100644 --- a/internal/generated/snippets/dialogflow/apiv2/AgentsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/AgentsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/AgentsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2/AgentsClient/ListOperations/main.go index c9975093bb9e..4fdabf5116fb 100644 --- a/internal/generated/snippets/dialogflow/apiv2/AgentsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/AgentsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/AgentsClient/RestoreAgent/main.go b/internal/generated/snippets/dialogflow/apiv2/AgentsClient/RestoreAgent/main.go index c26d6afc6e17..b7d7790baee9 100644 --- a/internal/generated/snippets/dialogflow/apiv2/AgentsClient/RestoreAgent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/AgentsClient/RestoreAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/AgentsClient/SearchAgents/main.go b/internal/generated/snippets/dialogflow/apiv2/AgentsClient/SearchAgents/main.go index 49dabca13ee2..7dd24f3041db 100644 --- a/internal/generated/snippets/dialogflow/apiv2/AgentsClient/SearchAgents/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/AgentsClient/SearchAgents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/AgentsClient/SetAgent/main.go b/internal/generated/snippets/dialogflow/apiv2/AgentsClient/SetAgent/main.go index ce1f434a12d0..b627d32d48d9 100644 --- a/internal/generated/snippets/dialogflow/apiv2/AgentsClient/SetAgent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/AgentsClient/SetAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/AgentsClient/TrainAgent/main.go b/internal/generated/snippets/dialogflow/apiv2/AgentsClient/TrainAgent/main.go index c94a2df68c4a..a62bff53ca75 100644 --- a/internal/generated/snippets/dialogflow/apiv2/AgentsClient/TrainAgent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/AgentsClient/TrainAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/AnswerRecordsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/AnswerRecordsClient/CancelOperation/main.go index 7339d3958a44..6f75cf9de179 100644 --- a/internal/generated/snippets/dialogflow/apiv2/AnswerRecordsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/AnswerRecordsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/AnswerRecordsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2/AnswerRecordsClient/GetLocation/main.go index 83052c4afaf2..3e8f4bee69e1 100644 --- a/internal/generated/snippets/dialogflow/apiv2/AnswerRecordsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/AnswerRecordsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/AnswerRecordsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/AnswerRecordsClient/GetOperation/main.go index cb960e50668b..486b6cb7d825 100644 --- a/internal/generated/snippets/dialogflow/apiv2/AnswerRecordsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/AnswerRecordsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/AnswerRecordsClient/ListAnswerRecords/main.go b/internal/generated/snippets/dialogflow/apiv2/AnswerRecordsClient/ListAnswerRecords/main.go index 00ab658a8ef1..656cc51a4948 100644 --- a/internal/generated/snippets/dialogflow/apiv2/AnswerRecordsClient/ListAnswerRecords/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/AnswerRecordsClient/ListAnswerRecords/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/AnswerRecordsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2/AnswerRecordsClient/ListLocations/main.go index d032153bc5b1..8035570705c8 100644 --- a/internal/generated/snippets/dialogflow/apiv2/AnswerRecordsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/AnswerRecordsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/AnswerRecordsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2/AnswerRecordsClient/ListOperations/main.go index e528c411320f..998fc8f853ea 100644 --- a/internal/generated/snippets/dialogflow/apiv2/AnswerRecordsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/AnswerRecordsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/AnswerRecordsClient/UpdateAnswerRecord/main.go b/internal/generated/snippets/dialogflow/apiv2/AnswerRecordsClient/UpdateAnswerRecord/main.go index 13797aadf696..a21d04de416f 100644 --- a/internal/generated/snippets/dialogflow/apiv2/AnswerRecordsClient/UpdateAnswerRecord/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/AnswerRecordsClient/UpdateAnswerRecord/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ContextsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/ContextsClient/CancelOperation/main.go index 2fd6e2494954..5decf7902ad5 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ContextsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ContextsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ContextsClient/CreateContext/main.go b/internal/generated/snippets/dialogflow/apiv2/ContextsClient/CreateContext/main.go index a02ef6e386a8..e83ebbea6345 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ContextsClient/CreateContext/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ContextsClient/CreateContext/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ContextsClient/DeleteAllContexts/main.go b/internal/generated/snippets/dialogflow/apiv2/ContextsClient/DeleteAllContexts/main.go index ab13507ca0af..fa7f3c49e9b7 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ContextsClient/DeleteAllContexts/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ContextsClient/DeleteAllContexts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ContextsClient/DeleteContext/main.go b/internal/generated/snippets/dialogflow/apiv2/ContextsClient/DeleteContext/main.go index 50fbc3eec6c3..34cbead0e14e 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ContextsClient/DeleteContext/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ContextsClient/DeleteContext/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ContextsClient/GetContext/main.go b/internal/generated/snippets/dialogflow/apiv2/ContextsClient/GetContext/main.go index 4be6c4b2ed23..f3d3dc8181e9 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ContextsClient/GetContext/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ContextsClient/GetContext/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ContextsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2/ContextsClient/GetLocation/main.go index 280a80dbae30..28c4f72010d6 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ContextsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ContextsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ContextsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/ContextsClient/GetOperation/main.go index 125ec5c3c455..ba97cd2a4914 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ContextsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ContextsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ContextsClient/ListContexts/main.go b/internal/generated/snippets/dialogflow/apiv2/ContextsClient/ListContexts/main.go index 3b42b1071887..dd87f27ecd0f 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ContextsClient/ListContexts/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ContextsClient/ListContexts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ContextsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2/ContextsClient/ListLocations/main.go index 368b2235d094..8f8519909064 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ContextsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ContextsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ContextsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2/ContextsClient/ListOperations/main.go index 52521baaa329..3142cfe7af29 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ContextsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ContextsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ContextsClient/UpdateContext/main.go b/internal/generated/snippets/dialogflow/apiv2/ContextsClient/UpdateContext/main.go index 7c9a8fc199b8..b801244190c3 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ContextsClient/UpdateContext/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ContextsClient/UpdateContext/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/CancelOperation/main.go index e4c8d62d339b..b7c53448630d 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/CreateConversationDataset/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/CreateConversationDataset/main.go index 5f7cce604746..f5f9858d4c08 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/CreateConversationDataset/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/CreateConversationDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/DeleteConversationDataset/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/DeleteConversationDataset/main.go index 5fbf12e0fa16..4e0d49adffca 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/DeleteConversationDataset/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/DeleteConversationDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/GetConversationDataset/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/GetConversationDataset/main.go index dd00bee134ad..bd4e50109e2c 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/GetConversationDataset/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/GetConversationDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/GetLocation/main.go index e63b859495c8..e2a0f85c70db 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/GetOperation/main.go index 6ece2cf2fa7d..481c02463c5a 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/ImportConversationData/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/ImportConversationData/main.go index ec5372e42925..8be7921ecb64 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/ImportConversationData/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/ImportConversationData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/ListConversationDatasets/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/ListConversationDatasets/main.go index c104fa799b3e..abf400e4a01d 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/ListConversationDatasets/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/ListConversationDatasets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/ListLocations/main.go index 7debbcc7bdb0..26cc124182f9 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/ListOperations/main.go index 7fe4659640f6..e0292088000d 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationDatasetsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/CancelOperation/main.go index d9db270259cc..a956ed6a448a 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/CreateConversationModel/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/CreateConversationModel/main.go index 1fb1b9e4dfb3..bedee8df435f 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/CreateConversationModel/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/CreateConversationModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/CreateConversationModelEvaluation/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/CreateConversationModelEvaluation/main.go index e7044a4b3796..f93ccf408c9f 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/CreateConversationModelEvaluation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/CreateConversationModelEvaluation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/DeleteConversationModel/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/DeleteConversationModel/main.go index 9cc856cc5600..a7b8e82c8449 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/DeleteConversationModel/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/DeleteConversationModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/DeployConversationModel/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/DeployConversationModel/main.go index b047cf67c996..fe0b4988e0e0 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/DeployConversationModel/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/DeployConversationModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/GetConversationModel/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/GetConversationModel/main.go index dd6338be972f..aeb01f504fda 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/GetConversationModel/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/GetConversationModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/GetConversationModelEvaluation/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/GetConversationModelEvaluation/main.go index 896cbbf27211..066ee0eddb02 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/GetConversationModelEvaluation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/GetConversationModelEvaluation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/GetLocation/main.go index 044d6c6887ca..47fbbb19d7c7 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/GetOperation/main.go index 75cd83918ef0..9055c1e97207 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/ListConversationModelEvaluations/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/ListConversationModelEvaluations/main.go index bb0af3602de2..62e93780f890 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/ListConversationModelEvaluations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/ListConversationModelEvaluations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/ListConversationModels/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/ListConversationModels/main.go index 49a13adeccc3..db743b97cc2b 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/ListConversationModels/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/ListConversationModels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/ListLocations/main.go index a954b44d696e..df70575d0427 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/ListOperations/main.go index 046ef1dabdbe..297b40b54f50 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/UndeployConversationModel/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/UndeployConversationModel/main.go index c4eb8ddc69c0..6854454d5a7b 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/UndeployConversationModel/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationModelsClient/UndeployConversationModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/CancelOperation/main.go index 7fa13b9c4e29..c0897c23aded 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/ClearSuggestionFeatureConfig/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/ClearSuggestionFeatureConfig/main.go index 9d6feb8a2a90..ecfd90754464 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/ClearSuggestionFeatureConfig/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/ClearSuggestionFeatureConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/CreateConversationProfile/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/CreateConversationProfile/main.go index 38e98823de80..b479eaae72d0 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/CreateConversationProfile/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/CreateConversationProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/DeleteConversationProfile/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/DeleteConversationProfile/main.go index 33a7d56b948a..8b6b7d663bd7 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/DeleteConversationProfile/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/DeleteConversationProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/GetConversationProfile/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/GetConversationProfile/main.go index 29f2e18f15e4..6a28fcc83da0 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/GetConversationProfile/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/GetConversationProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/GetLocation/main.go index 1c783e50db9c..f0e76300fc9b 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/GetOperation/main.go index 9c0d74eff5ef..35b6c022049c 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/ListConversationProfiles/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/ListConversationProfiles/main.go index a71caa2c11ca..9ab057eab46e 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/ListConversationProfiles/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/ListConversationProfiles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/ListLocations/main.go index b803f9a8a0bf..fe7681a72615 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/ListOperations/main.go index d8a83c778df3..4b08825eaf67 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/SetSuggestionFeatureConfig/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/SetSuggestionFeatureConfig/main.go index 5f8929b1b32d..f088bd5449f9 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/SetSuggestionFeatureConfig/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/SetSuggestionFeatureConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/UpdateConversationProfile/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/UpdateConversationProfile/main.go index 0c6902df8c06..85d68c59284c 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/UpdateConversationProfile/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationProfilesClient/UpdateConversationProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/CancelOperation/main.go index fbf5758716e0..bdd2164eb3f9 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/CompleteConversation/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/CompleteConversation/main.go index cbfc1bf1a106..598a2c56535a 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/CompleteConversation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/CompleteConversation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/CreateConversation/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/CreateConversation/main.go index 07e4610137a1..8db7703a5be8 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/CreateConversation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/CreateConversation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/GenerateStatelessSuggestion/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/GenerateStatelessSuggestion/main.go index f2a61d8d1e78..3223fbf60a43 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/GenerateStatelessSuggestion/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/GenerateStatelessSuggestion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/GenerateStatelessSummary/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/GenerateStatelessSummary/main.go index 85b1b815af94..e6f18d630752 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/GenerateStatelessSummary/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/GenerateStatelessSummary/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/GetConversation/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/GetConversation/main.go index ffe1c7ce58fa..94011a8cafab 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/GetConversation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/GetConversation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/GetLocation/main.go index f9e7db7e11b9..a73f87023963 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/GetOperation/main.go index be475ca6d64a..2c6020140eff 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/ListConversations/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/ListConversations/main.go index 75bc9bec9845..1d3cd06bbef4 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/ListConversations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/ListConversations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/ListLocations/main.go index f7b1e4362a40..f139b5f86ff9 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/ListMessages/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/ListMessages/main.go index 4e7589a7e48d..ac5806da7d07 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/ListMessages/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/ListMessages/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/ListOperations/main.go index 6aaaa4a2f47d..762bbc38978b 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/SearchKnowledge/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/SearchKnowledge/main.go index 1063cc57a82a..46f2fda2287d 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/SearchKnowledge/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/SearchKnowledge/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/SuggestConversationSummary/main.go b/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/SuggestConversationSummary/main.go index a4bab87a4757..fd7b05057b90 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/SuggestConversationSummary/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ConversationsClient/SuggestConversationSummary/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/CancelOperation/main.go index 6ac48cae4bc6..d40167dfad8e 100644 --- a/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/CreateDocument/main.go b/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/CreateDocument/main.go index 1d6ebbf0b22d..cc2486ac9af7 100644 --- a/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/CreateDocument/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/CreateDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/DeleteDocument/main.go b/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/DeleteDocument/main.go index 470cd9d2af1c..4ef454595e6b 100644 --- a/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/DeleteDocument/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/DeleteDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/ExportDocument/main.go b/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/ExportDocument/main.go index 7828ab6b0413..e5ab5deba3f4 100644 --- a/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/ExportDocument/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/ExportDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/GetDocument/main.go b/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/GetDocument/main.go index af1a0f152869..d89d1f30447f 100644 --- a/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/GetDocument/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/GetDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/GetLocation/main.go index 1757cec72a67..abb3be4b45ec 100644 --- a/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/GetOperation/main.go index dc4de5390556..5ac4d009ca31 100644 --- a/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/ImportDocuments/main.go b/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/ImportDocuments/main.go index 8e074b1dbb46..cfca800f7c18 100644 --- a/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/ImportDocuments/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/ImportDocuments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/ListDocuments/main.go b/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/ListDocuments/main.go index 15bb2c3e3812..2fb50acaa135 100644 --- a/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/ListDocuments/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/ListDocuments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/ListLocations/main.go index 159450e7a72f..1e44352654d1 100644 --- a/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/ListOperations/main.go index c7d188a95ede..46f90627fe3b 100644 --- a/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/ReloadDocument/main.go b/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/ReloadDocument/main.go index 16d9acbd714f..c1b9c64aed81 100644 --- a/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/ReloadDocument/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/ReloadDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/UpdateDocument/main.go b/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/UpdateDocument/main.go index 151a09409e98..57faf967c6f4 100644 --- a/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/UpdateDocument/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/DocumentsClient/UpdateDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EncryptionSpecClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/EncryptionSpecClient/CancelOperation/main.go index 3b12749546fa..8f913f9d68ef 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EncryptionSpecClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EncryptionSpecClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EncryptionSpecClient/GetEncryptionSpec/main.go b/internal/generated/snippets/dialogflow/apiv2/EncryptionSpecClient/GetEncryptionSpec/main.go index 1dd751fe938d..9612c76f7baf 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EncryptionSpecClient/GetEncryptionSpec/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EncryptionSpecClient/GetEncryptionSpec/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EncryptionSpecClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2/EncryptionSpecClient/GetLocation/main.go index ea6dda56d7ec..13a4cd1a04ae 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EncryptionSpecClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EncryptionSpecClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EncryptionSpecClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/EncryptionSpecClient/GetOperation/main.go index ad0c08f081f5..50589bfcb93b 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EncryptionSpecClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EncryptionSpecClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EncryptionSpecClient/InitializeEncryptionSpec/main.go b/internal/generated/snippets/dialogflow/apiv2/EncryptionSpecClient/InitializeEncryptionSpec/main.go index 9a183cbeca81..9b1259e5c57d 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EncryptionSpecClient/InitializeEncryptionSpec/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EncryptionSpecClient/InitializeEncryptionSpec/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EncryptionSpecClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2/EncryptionSpecClient/ListLocations/main.go index 827b1b538c91..e6c26a066144 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EncryptionSpecClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EncryptionSpecClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EncryptionSpecClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2/EncryptionSpecClient/ListOperations/main.go index cd1c8e59724a..d12da1409380 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EncryptionSpecClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EncryptionSpecClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/BatchCreateEntities/main.go b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/BatchCreateEntities/main.go index d1b5a645192f..12811dbe9863 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/BatchCreateEntities/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/BatchCreateEntities/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/BatchDeleteEntities/main.go b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/BatchDeleteEntities/main.go index 0b0cd610836f..0ee575792ea6 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/BatchDeleteEntities/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/BatchDeleteEntities/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/BatchDeleteEntityTypes/main.go b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/BatchDeleteEntityTypes/main.go index 19886ccfa9cc..a5e65658bff8 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/BatchDeleteEntityTypes/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/BatchDeleteEntityTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/BatchUpdateEntities/main.go b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/BatchUpdateEntities/main.go index 98b161e87831..3d3733beca22 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/BatchUpdateEntities/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/BatchUpdateEntities/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/BatchUpdateEntityTypes/main.go b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/BatchUpdateEntityTypes/main.go index 580aeb7da57c..217fbca3429c 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/BatchUpdateEntityTypes/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/BatchUpdateEntityTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/CancelOperation/main.go index f191e74ebec1..a5ae469a18f5 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/CreateEntityType/main.go b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/CreateEntityType/main.go index 1d598c92133e..df2464807085 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/CreateEntityType/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/CreateEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/DeleteEntityType/main.go b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/DeleteEntityType/main.go index 0267127bb74c..42f7a8bbfcc6 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/DeleteEntityType/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/DeleteEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/GetEntityType/main.go b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/GetEntityType/main.go index eb9f84f55050..665d56af7cfd 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/GetEntityType/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/GetEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/GetLocation/main.go index be6700c9ce58..eccff3436885 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/GetOperation/main.go index 0c3f73b9f8fb..443a28300f8b 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/ListEntityTypes/main.go b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/ListEntityTypes/main.go index 10aec512d1c4..12171be6695a 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/ListEntityTypes/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/ListEntityTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/ListLocations/main.go index 82e3a9d16837..6376bf210793 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/ListOperations/main.go index da7df0b22475..8cfe55f10665 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/UpdateEntityType/main.go b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/UpdateEntityType/main.go index 659db4947d6d..829d2738dfa3 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/UpdateEntityType/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EntityTypesClient/UpdateEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/CancelOperation/main.go index 2ee584290ffc..07b02783c9d1 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/CreateEnvironment/main.go b/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/CreateEnvironment/main.go index 30b103741524..f68c34e7041c 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/CreateEnvironment/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/CreateEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/DeleteEnvironment/main.go b/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/DeleteEnvironment/main.go index c98b8b6d7ec1..9d56a70c5fd2 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/DeleteEnvironment/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/DeleteEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/GetEnvironment/main.go b/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/GetEnvironment/main.go index d7a94090ea92..e702b5560f38 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/GetEnvironment/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/GetEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/GetEnvironmentHistory/main.go b/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/GetEnvironmentHistory/main.go index 6b8cfd3cfcca..c3848c0170d2 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/GetEnvironmentHistory/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/GetEnvironmentHistory/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/GetLocation/main.go index afb755d86588..e2df7c91d460 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/GetOperation/main.go index 158cee05be67..c0659f90a6a9 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/ListEnvironments/main.go b/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/ListEnvironments/main.go index 73a2cd056d53..4fd46596f169 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/ListEnvironments/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/ListEnvironments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/ListLocations/main.go index b3a5cd9fc629..8d664dcc198c 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/ListOperations/main.go index 2b81d0385c16..9868b2070ed6 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/UpdateEnvironment/main.go b/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/UpdateEnvironment/main.go index c8292cf02c2c..b26aab568ec7 100644 --- a/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/UpdateEnvironment/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/EnvironmentsClient/UpdateEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/FulfillmentsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/FulfillmentsClient/CancelOperation/main.go index 1227fd80f8aa..24cfe4aa920a 100644 --- a/internal/generated/snippets/dialogflow/apiv2/FulfillmentsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/FulfillmentsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/FulfillmentsClient/GetFulfillment/main.go b/internal/generated/snippets/dialogflow/apiv2/FulfillmentsClient/GetFulfillment/main.go index 9797004ecdd7..d22a8980917d 100644 --- a/internal/generated/snippets/dialogflow/apiv2/FulfillmentsClient/GetFulfillment/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/FulfillmentsClient/GetFulfillment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/FulfillmentsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2/FulfillmentsClient/GetLocation/main.go index 9aedd4e48222..8eede5f256b6 100644 --- a/internal/generated/snippets/dialogflow/apiv2/FulfillmentsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/FulfillmentsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/FulfillmentsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/FulfillmentsClient/GetOperation/main.go index 6ae5b448cee3..f5964fdef3d2 100644 --- a/internal/generated/snippets/dialogflow/apiv2/FulfillmentsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/FulfillmentsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/FulfillmentsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2/FulfillmentsClient/ListLocations/main.go index 70c204cf27c2..fcd567635d0d 100644 --- a/internal/generated/snippets/dialogflow/apiv2/FulfillmentsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/FulfillmentsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/FulfillmentsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2/FulfillmentsClient/ListOperations/main.go index 70497a2743b9..b37add892b1c 100644 --- a/internal/generated/snippets/dialogflow/apiv2/FulfillmentsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/FulfillmentsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/FulfillmentsClient/UpdateFulfillment/main.go b/internal/generated/snippets/dialogflow/apiv2/FulfillmentsClient/UpdateFulfillment/main.go index e48a7d6adb7c..82ab90fb3f71 100644 --- a/internal/generated/snippets/dialogflow/apiv2/FulfillmentsClient/UpdateFulfillment/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/FulfillmentsClient/UpdateFulfillment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/CancelOperation/main.go index ef7448ecf3a0..821912952834 100644 --- a/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/CreateGenerator/main.go b/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/CreateGenerator/main.go index a2e7aef3ef61..d8871b3b7bf1 100644 --- a/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/CreateGenerator/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/CreateGenerator/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/DeleteGenerator/main.go b/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/DeleteGenerator/main.go index 88aa6c6ef950..822fea611c70 100644 --- a/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/DeleteGenerator/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/DeleteGenerator/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/GetGenerator/main.go b/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/GetGenerator/main.go index 3bf0bcb5b031..a801f881948f 100644 --- a/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/GetGenerator/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/GetGenerator/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/GetLocation/main.go index 77dde7004e8f..a70804beb153 100644 --- a/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/GetOperation/main.go index 1bc1311b1144..8117c5a89aee 100644 --- a/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/ListGenerators/main.go b/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/ListGenerators/main.go index a9e330e9ee31..636d39da8622 100644 --- a/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/ListGenerators/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/ListGenerators/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/ListLocations/main.go index c8c7953d2c69..bd6ab26d86fd 100644 --- a/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/ListOperations/main.go index 1f5d31e2fbb4..d5ec945b2426 100644 --- a/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/UpdateGenerator/main.go b/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/UpdateGenerator/main.go index 0801f43dcd5f..4519a673dcfe 100644 --- a/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/UpdateGenerator/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/GeneratorsClient/UpdateGenerator/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/IntentsClient/BatchDeleteIntents/main.go b/internal/generated/snippets/dialogflow/apiv2/IntentsClient/BatchDeleteIntents/main.go index da6b504fed18..11385a4c5c22 100644 --- a/internal/generated/snippets/dialogflow/apiv2/IntentsClient/BatchDeleteIntents/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/IntentsClient/BatchDeleteIntents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/IntentsClient/BatchUpdateIntents/main.go b/internal/generated/snippets/dialogflow/apiv2/IntentsClient/BatchUpdateIntents/main.go index cef1f0fb1da7..bc2e61d15d03 100644 --- a/internal/generated/snippets/dialogflow/apiv2/IntentsClient/BatchUpdateIntents/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/IntentsClient/BatchUpdateIntents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/IntentsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/IntentsClient/CancelOperation/main.go index adb91f11cf3c..e2601ed4c10d 100644 --- a/internal/generated/snippets/dialogflow/apiv2/IntentsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/IntentsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/IntentsClient/CreateIntent/main.go b/internal/generated/snippets/dialogflow/apiv2/IntentsClient/CreateIntent/main.go index 39a974fb9736..c529c9ae4a5d 100644 --- a/internal/generated/snippets/dialogflow/apiv2/IntentsClient/CreateIntent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/IntentsClient/CreateIntent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/IntentsClient/DeleteIntent/main.go b/internal/generated/snippets/dialogflow/apiv2/IntentsClient/DeleteIntent/main.go index edd8179642f7..726bc73ffafd 100644 --- a/internal/generated/snippets/dialogflow/apiv2/IntentsClient/DeleteIntent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/IntentsClient/DeleteIntent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/IntentsClient/GetIntent/main.go b/internal/generated/snippets/dialogflow/apiv2/IntentsClient/GetIntent/main.go index 8183a7b6c643..3c879acbb533 100644 --- a/internal/generated/snippets/dialogflow/apiv2/IntentsClient/GetIntent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/IntentsClient/GetIntent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/IntentsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2/IntentsClient/GetLocation/main.go index 7cd329792129..04ccd44311c1 100644 --- a/internal/generated/snippets/dialogflow/apiv2/IntentsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/IntentsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/IntentsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/IntentsClient/GetOperation/main.go index 6229b6e78f30..f67a52b831ed 100644 --- a/internal/generated/snippets/dialogflow/apiv2/IntentsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/IntentsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/IntentsClient/ListIntents/main.go b/internal/generated/snippets/dialogflow/apiv2/IntentsClient/ListIntents/main.go index 74a4f570393c..da5dfee60e79 100644 --- a/internal/generated/snippets/dialogflow/apiv2/IntentsClient/ListIntents/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/IntentsClient/ListIntents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/IntentsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2/IntentsClient/ListLocations/main.go index 4673a5b5b089..4424469a1732 100644 --- a/internal/generated/snippets/dialogflow/apiv2/IntentsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/IntentsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/IntentsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2/IntentsClient/ListOperations/main.go index 5ef8989a9ed8..171dea6f8c1e 100644 --- a/internal/generated/snippets/dialogflow/apiv2/IntentsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/IntentsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/IntentsClient/UpdateIntent/main.go b/internal/generated/snippets/dialogflow/apiv2/IntentsClient/UpdateIntent/main.go index 51693137f3f2..5f1f3c0483e5 100644 --- a/internal/generated/snippets/dialogflow/apiv2/IntentsClient/UpdateIntent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/IntentsClient/UpdateIntent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/CancelOperation/main.go index a4f30c76cbbb..11ae63254afe 100644 --- a/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/CreateKnowledgeBase/main.go b/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/CreateKnowledgeBase/main.go index 2165ab22c511..d02d5f182bc3 100644 --- a/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/CreateKnowledgeBase/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/CreateKnowledgeBase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/DeleteKnowledgeBase/main.go b/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/DeleteKnowledgeBase/main.go index 7dd8a58f7318..b3f0d84b5d91 100644 --- a/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/DeleteKnowledgeBase/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/DeleteKnowledgeBase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/GetKnowledgeBase/main.go b/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/GetKnowledgeBase/main.go index 626de6bd0078..586f1a8f5e28 100644 --- a/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/GetKnowledgeBase/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/GetKnowledgeBase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/GetLocation/main.go index d5abbb4dcf5c..418d9e35311c 100644 --- a/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/GetOperation/main.go index 0728e1c28e38..d61f5c883283 100644 --- a/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/ListKnowledgeBases/main.go b/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/ListKnowledgeBases/main.go index 0207a5290ed7..d5629817ea38 100644 --- a/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/ListKnowledgeBases/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/ListKnowledgeBases/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/ListLocations/main.go index cf22cb2ba7ba..116c6bb0d6de 100644 --- a/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/ListOperations/main.go index 510e80a25a50..3f69f09b3a44 100644 --- a/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/UpdateKnowledgeBase/main.go b/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/UpdateKnowledgeBase/main.go index e997ebe4ffa9..81045d2d5030 100644 --- a/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/UpdateKnowledgeBase/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/KnowledgeBasesClient/UpdateKnowledgeBase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/AnalyzeContent/main.go b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/AnalyzeContent/main.go index f38397b57095..205c5aa49b57 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/AnalyzeContent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/AnalyzeContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/CancelOperation/main.go index 7da122456cf8..c247b5e918f2 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/CreateParticipant/main.go b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/CreateParticipant/main.go index 288e7cc1d8e2..b527735d837e 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/CreateParticipant/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/CreateParticipant/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/GetLocation/main.go index 00eed0ac2cc9..6c00373fa197 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/GetOperation/main.go index 9c110c10edb0..a10128608433 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/GetParticipant/main.go b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/GetParticipant/main.go index be3add31f02b..dc6b86d8a227 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/GetParticipant/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/GetParticipant/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/ListLocations/main.go index c2410b5d57ff..92b289ea0f1e 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/ListOperations/main.go index 35d0295a3640..4e9ea07b0e52 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/ListParticipants/main.go b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/ListParticipants/main.go index abb25399a419..bc3c47475acf 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/ListParticipants/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/ListParticipants/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/StreamingAnalyzeContent/main.go b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/StreamingAnalyzeContent/main.go index 57c9871a9377..d0411249a6a6 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/StreamingAnalyzeContent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/StreamingAnalyzeContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/SuggestArticles/main.go b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/SuggestArticles/main.go index 8c37203f8b6c..b2f078d2c6ea 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/SuggestArticles/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/SuggestArticles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/SuggestFaqAnswers/main.go b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/SuggestFaqAnswers/main.go index 9e279e79bd9e..f0ca87989dfd 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/SuggestFaqAnswers/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/SuggestFaqAnswers/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/SuggestKnowledgeAssist/main.go b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/SuggestKnowledgeAssist/main.go index 314e7db8f7fd..280e4893bd8d 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/SuggestKnowledgeAssist/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/SuggestKnowledgeAssist/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/SuggestSmartReplies/main.go b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/SuggestSmartReplies/main.go index e6e9613c5b54..8d30af6b9ab8 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/SuggestSmartReplies/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/SuggestSmartReplies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/UpdateParticipant/main.go b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/UpdateParticipant/main.go index de7d30e38825..f38b41baf3ff 100644 --- a/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/UpdateParticipant/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/ParticipantsClient/UpdateParticipant/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/CancelOperation/main.go index c453f7949811..90be96a32c90 100644 --- a/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/CreateSessionEntityType/main.go b/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/CreateSessionEntityType/main.go index 46a799959010..7f4dae5f6f23 100644 --- a/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/CreateSessionEntityType/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/CreateSessionEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/DeleteSessionEntityType/main.go b/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/DeleteSessionEntityType/main.go index 12fbdefe9664..3b23db245557 100644 --- a/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/DeleteSessionEntityType/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/DeleteSessionEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/GetLocation/main.go index c4e933435763..a3a307bdc40f 100644 --- a/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/GetOperation/main.go index 61325f846b5e..28be0d3ae578 100644 --- a/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/GetSessionEntityType/main.go b/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/GetSessionEntityType/main.go index 16f49d8e5f52..f3384b4d6d25 100644 --- a/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/GetSessionEntityType/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/GetSessionEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/ListLocations/main.go index cbd3530ff83e..7d222d7e9abd 100644 --- a/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/ListOperations/main.go index d38c93abfec7..c7ad5d29f855 100644 --- a/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/ListSessionEntityTypes/main.go b/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/ListSessionEntityTypes/main.go index fe9d120f5cc7..284080a283b7 100644 --- a/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/ListSessionEntityTypes/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/ListSessionEntityTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/UpdateSessionEntityType/main.go b/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/UpdateSessionEntityType/main.go index 8f46440622c6..f36c3e243769 100644 --- a/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/UpdateSessionEntityType/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/SessionEntityTypesClient/UpdateSessionEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/SessionsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/SessionsClient/CancelOperation/main.go index 402262cee860..ef38e29b13e4 100644 --- a/internal/generated/snippets/dialogflow/apiv2/SessionsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/SessionsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/SessionsClient/DetectIntent/main.go b/internal/generated/snippets/dialogflow/apiv2/SessionsClient/DetectIntent/main.go index acf347ab18a6..6ffb3d995144 100644 --- a/internal/generated/snippets/dialogflow/apiv2/SessionsClient/DetectIntent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/SessionsClient/DetectIntent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/SessionsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2/SessionsClient/GetLocation/main.go index 227154632474..5dd637717c29 100644 --- a/internal/generated/snippets/dialogflow/apiv2/SessionsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/SessionsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/SessionsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/SessionsClient/GetOperation/main.go index 68f4a6a4f1fb..ca2031d74c38 100644 --- a/internal/generated/snippets/dialogflow/apiv2/SessionsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/SessionsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/SessionsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2/SessionsClient/ListLocations/main.go index 040eedcc9908..854e1a7da7df 100644 --- a/internal/generated/snippets/dialogflow/apiv2/SessionsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/SessionsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/SessionsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2/SessionsClient/ListOperations/main.go index 672a628edf8a..ed5192816787 100644 --- a/internal/generated/snippets/dialogflow/apiv2/SessionsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/SessionsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/SessionsClient/StreamingDetectIntent/main.go b/internal/generated/snippets/dialogflow/apiv2/SessionsClient/StreamingDetectIntent/main.go index 1b179891d894..d45dff197631 100644 --- a/internal/generated/snippets/dialogflow/apiv2/SessionsClient/StreamingDetectIntent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/SessionsClient/StreamingDetectIntent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/VersionsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/VersionsClient/CancelOperation/main.go index 7ce90975582b..0ca4968ff1e8 100644 --- a/internal/generated/snippets/dialogflow/apiv2/VersionsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/VersionsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/VersionsClient/CreateVersion/main.go b/internal/generated/snippets/dialogflow/apiv2/VersionsClient/CreateVersion/main.go index d1afea3f6ded..0345dc5d6b9b 100644 --- a/internal/generated/snippets/dialogflow/apiv2/VersionsClient/CreateVersion/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/VersionsClient/CreateVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/VersionsClient/DeleteVersion/main.go b/internal/generated/snippets/dialogflow/apiv2/VersionsClient/DeleteVersion/main.go index c2e2db4e406a..1f7e232780ad 100644 --- a/internal/generated/snippets/dialogflow/apiv2/VersionsClient/DeleteVersion/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/VersionsClient/DeleteVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/VersionsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2/VersionsClient/GetLocation/main.go index 526c45abae58..ab7b77b2f9d7 100644 --- a/internal/generated/snippets/dialogflow/apiv2/VersionsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/VersionsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/VersionsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2/VersionsClient/GetOperation/main.go index c1311e3c47d1..cdc47a5d2fd3 100644 --- a/internal/generated/snippets/dialogflow/apiv2/VersionsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/VersionsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/VersionsClient/GetVersion/main.go b/internal/generated/snippets/dialogflow/apiv2/VersionsClient/GetVersion/main.go index 848d14d387c0..6020ed523e05 100644 --- a/internal/generated/snippets/dialogflow/apiv2/VersionsClient/GetVersion/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/VersionsClient/GetVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/VersionsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2/VersionsClient/ListLocations/main.go index 6742be6795db..849b3ebbbe69 100644 --- a/internal/generated/snippets/dialogflow/apiv2/VersionsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/VersionsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/VersionsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2/VersionsClient/ListOperations/main.go index 1d19d684eb55..2c8d00999aec 100644 --- a/internal/generated/snippets/dialogflow/apiv2/VersionsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/VersionsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/VersionsClient/ListVersions/main.go b/internal/generated/snippets/dialogflow/apiv2/VersionsClient/ListVersions/main.go index 5fdea40afbe2..321b325a7f54 100644 --- a/internal/generated/snippets/dialogflow/apiv2/VersionsClient/ListVersions/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/VersionsClient/ListVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/VersionsClient/UpdateVersion/main.go b/internal/generated/snippets/dialogflow/apiv2/VersionsClient/UpdateVersion/main.go index a9574629d75e..fbf49d284642 100644 --- a/internal/generated/snippets/dialogflow/apiv2/VersionsClient/UpdateVersion/main.go +++ b/internal/generated/snippets/dialogflow/apiv2/VersionsClient/UpdateVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2/snippet_metadata.google.cloud.dialogflow.v2.json b/internal/generated/snippets/dialogflow/apiv2/snippet_metadata.google.cloud.dialogflow.v2.json index fea81c00c880..52fd14fc3dab 100644 --- a/internal/generated/snippets/dialogflow/apiv2/snippet_metadata.google.cloud.dialogflow.v2.json +++ b/internal/generated/snippets/dialogflow/apiv2/snippet_metadata.google.cloud.dialogflow.v2.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/dialogflow/apiv2", - "version": "1.64.0", + "version": "1.64.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/CancelOperation/main.go index 0a21cc9c6dd0..8d6838b23b05 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/DeleteAgent/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/DeleteAgent/main.go index 1bab7802a7b2..e85c9d5fa344 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/DeleteAgent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/DeleteAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/ExportAgent/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/ExportAgent/main.go index 3c3061748273..5db366ad5fb6 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/ExportAgent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/ExportAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/GetAgent/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/GetAgent/main.go index e74172a83335..d8da5f85f5d7 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/GetAgent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/GetAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/GetLocation/main.go index 84d8dfbf95e3..78feda10060e 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/GetOperation/main.go index 1d8cb032f973..2857ef8a2167 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/GetValidationResult/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/GetValidationResult/main.go index c1cad8e60ff9..8d820d006db0 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/GetValidationResult/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/GetValidationResult/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/ImportAgent/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/ImportAgent/main.go index 4de2835806eb..08c28361c9e8 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/ImportAgent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/ImportAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/ListLocations/main.go index 50db5302a23f..8adf8f7c5928 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/ListOperations/main.go index 477558e6f007..d055cca7c2e8 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/RestoreAgent/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/RestoreAgent/main.go index 7d150bf31a9d..9c24fb8dcbcd 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/RestoreAgent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/RestoreAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/SearchAgents/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/SearchAgents/main.go index 6c6c047e4770..0b1da3fe24d7 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/SearchAgents/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/SearchAgents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/SetAgent/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/SetAgent/main.go index 17b8e7d2d7d8..be62a8231df9 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/SetAgent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/SetAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/TrainAgent/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/TrainAgent/main.go index 3f8911de716e..e07f147abc51 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/TrainAgent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/AgentsClient/TrainAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/CancelOperation/main.go index 74de1d7fd0d9..1fea77e93fa3 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/GetAnswerRecord/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/GetAnswerRecord/main.go index 33b5868eeee3..892c7b2b82b8 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/GetAnswerRecord/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/GetAnswerRecord/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/GetLocation/main.go index 94c56fc41749..c1b47318334e 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/GetOperation/main.go index 04c63d8ea144..e64fce943c6d 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/ListAnswerRecords/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/ListAnswerRecords/main.go index b34d1e52ab3f..4c4d206a8412 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/ListAnswerRecords/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/ListAnswerRecords/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/ListLocations/main.go index e3e855c03d37..aada450453ec 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/ListOperations/main.go index 2cbe99f68748..29922a5ae8be 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/UpdateAnswerRecord/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/UpdateAnswerRecord/main.go index e483fe426209..3d278504e50b 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/UpdateAnswerRecord/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/AnswerRecordsClient/UpdateAnswerRecord/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/CancelOperation/main.go index 33e839d4a7c0..ec72d86a877e 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/CreateContext/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/CreateContext/main.go index b9df2ee4653d..552a232c462f 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/CreateContext/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/CreateContext/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/DeleteAllContexts/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/DeleteAllContexts/main.go index 3346384a8163..0344b94132cb 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/DeleteAllContexts/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/DeleteAllContexts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/DeleteContext/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/DeleteContext/main.go index 81d2ec6b75b3..77c05262c2f6 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/DeleteContext/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/DeleteContext/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/GetContext/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/GetContext/main.go index 5dd7765f602f..6da3a21e95cd 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/GetContext/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/GetContext/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/GetLocation/main.go index d849bd805324..0b7c6bacd9e6 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/GetOperation/main.go index 6d4df004c5d7..f88d14cff7d4 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/ListContexts/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/ListContexts/main.go index 28ba03d0ea43..f92ddd37a68b 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/ListContexts/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/ListContexts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/ListLocations/main.go index de353009bb8f..baedd913b2dc 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/ListOperations/main.go index e1cdcf5be340..2e2aa141e858 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/UpdateContext/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/UpdateContext/main.go index de68d1b29816..a13432c3ca83 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/UpdateContext/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ContextsClient/UpdateContext/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/CancelOperation/main.go index c976a25cabb7..34ad4623b978 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/ClearSuggestionFeatureConfig/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/ClearSuggestionFeatureConfig/main.go index 9bbb56879e6b..2fc46f5e9e1c 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/ClearSuggestionFeatureConfig/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/ClearSuggestionFeatureConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/CreateConversationProfile/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/CreateConversationProfile/main.go index 65a78700463f..57c931133995 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/CreateConversationProfile/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/CreateConversationProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/DeleteConversationProfile/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/DeleteConversationProfile/main.go index b576b1e4c4ac..323a2cd9ba77 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/DeleteConversationProfile/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/DeleteConversationProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/GetConversationProfile/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/GetConversationProfile/main.go index 2485c7b649f4..e6c25827ae0e 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/GetConversationProfile/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/GetConversationProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/GetLocation/main.go index d8559c313638..2d2014d024ec 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/GetOperation/main.go index 964f03ddfd11..bbf8f56891ee 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/ListConversationProfiles/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/ListConversationProfiles/main.go index 4df47e5de506..4ff63968b6fe 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/ListConversationProfiles/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/ListConversationProfiles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/ListLocations/main.go index df1e8f1c7396..6f3d12c7bd7c 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/ListOperations/main.go index c1b933a8a0c0..807b9b2a3015 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/SetSuggestionFeatureConfig/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/SetSuggestionFeatureConfig/main.go index a5010815bab7..e7a250883ab3 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/SetSuggestionFeatureConfig/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/SetSuggestionFeatureConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/UpdateConversationProfile/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/UpdateConversationProfile/main.go index b12f5ac8de3f..565f55d10a88 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/UpdateConversationProfile/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationProfilesClient/UpdateConversationProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/BatchCreateMessages/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/BatchCreateMessages/main.go index 0d49b4fdb889..4599ead1756c 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/BatchCreateMessages/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/BatchCreateMessages/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/CancelOperation/main.go index fb549d73b4f3..1650f62872aa 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/CompleteConversation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/CompleteConversation/main.go index 0c9c9e3f578a..959aa9955825 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/CompleteConversation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/CompleteConversation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/CreateConversation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/CreateConversation/main.go index 6cf9724e66c4..9be877284ea9 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/CreateConversation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/CreateConversation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/GenerateStatelessSuggestion/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/GenerateStatelessSuggestion/main.go index 5c3ad21035ff..bbcd584e3f8e 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/GenerateStatelessSuggestion/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/GenerateStatelessSuggestion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/GenerateStatelessSummary/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/GenerateStatelessSummary/main.go index d002ffd53834..24866ec7c26b 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/GenerateStatelessSummary/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/GenerateStatelessSummary/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/GetConversation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/GetConversation/main.go index 17736af3e7ec..9e7c22faa177 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/GetConversation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/GetConversation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/GetLocation/main.go index e60e98a4e3d9..61939e11138a 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/GetOperation/main.go index b4ed7ef1fa92..80182eaac45e 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/ListConversations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/ListConversations/main.go index 66758834fdf4..23ca3a29c51f 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/ListConversations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/ListConversations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/ListLocations/main.go index 627bc5e0c26f..25e88f958eb6 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/ListMessages/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/ListMessages/main.go index 8bd24424774b..4ffdec604957 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/ListMessages/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/ListMessages/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/ListOperations/main.go index 49375181032f..51aaafa382db 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/SearchKnowledge/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/SearchKnowledge/main.go index d6d3321ba057..f46daadcb2cd 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/SearchKnowledge/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/SearchKnowledge/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/SuggestConversationSummary/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/SuggestConversationSummary/main.go index d3567f528746..3aabcf667291 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/SuggestConversationSummary/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ConversationsClient/SuggestConversationSummary/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/CancelOperation/main.go index eef4c7d53480..005d8dd14879 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/CreateDocument/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/CreateDocument/main.go index a9a8f72fe68f..e13ee979e689 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/CreateDocument/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/CreateDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/DeleteDocument/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/DeleteDocument/main.go index 6002ecf48c55..669acff6cffa 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/DeleteDocument/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/DeleteDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/GetDocument/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/GetDocument/main.go index 8c5b80b12491..4f44f30bcfba 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/GetDocument/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/GetDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/GetLocation/main.go index 579652623df0..a5ee504d845a 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/GetOperation/main.go index 2408a339f632..4a8887c4496a 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/ImportDocuments/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/ImportDocuments/main.go index 5817a4cd238a..7783eb04acd2 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/ImportDocuments/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/ImportDocuments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/ListDocuments/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/ListDocuments/main.go index d3ea59b22660..5df13f8facf8 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/ListDocuments/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/ListDocuments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/ListLocations/main.go index 1bcbade7af48..72e49aa8020f 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/ListOperations/main.go index 9a0f94cabcdc..95fae30ed2d4 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/ReloadDocument/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/ReloadDocument/main.go index cba4e74c2158..124b11ec02de 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/ReloadDocument/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/ReloadDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/UpdateDocument/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/UpdateDocument/main.go index a4158c869943..e68f5d616257 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/UpdateDocument/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/DocumentsClient/UpdateDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EncryptionSpecClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EncryptionSpecClient/CancelOperation/main.go index c6b17d27d7d5..71d1748ce1cc 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EncryptionSpecClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EncryptionSpecClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EncryptionSpecClient/GetEncryptionSpec/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EncryptionSpecClient/GetEncryptionSpec/main.go index 842fb5a0875b..b3102ab97379 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EncryptionSpecClient/GetEncryptionSpec/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EncryptionSpecClient/GetEncryptionSpec/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EncryptionSpecClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EncryptionSpecClient/GetLocation/main.go index bbc7172a2b74..0c2f5548ea30 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EncryptionSpecClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EncryptionSpecClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EncryptionSpecClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EncryptionSpecClient/GetOperation/main.go index 5ff3f2358dc1..7a48a2d171bd 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EncryptionSpecClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EncryptionSpecClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EncryptionSpecClient/InitializeEncryptionSpec/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EncryptionSpecClient/InitializeEncryptionSpec/main.go index 10152c7913b0..173f25d0f708 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EncryptionSpecClient/InitializeEncryptionSpec/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EncryptionSpecClient/InitializeEncryptionSpec/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EncryptionSpecClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EncryptionSpecClient/ListLocations/main.go index 47b72909d1d4..7e59f93cc4b9 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EncryptionSpecClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EncryptionSpecClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EncryptionSpecClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EncryptionSpecClient/ListOperations/main.go index e59529642aa9..f54264c932f6 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EncryptionSpecClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EncryptionSpecClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/BatchCreateEntities/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/BatchCreateEntities/main.go index 8f21a8a6e6fc..8f601e1aead0 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/BatchCreateEntities/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/BatchCreateEntities/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/BatchDeleteEntities/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/BatchDeleteEntities/main.go index 921d5955666b..2c129104281b 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/BatchDeleteEntities/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/BatchDeleteEntities/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/BatchDeleteEntityTypes/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/BatchDeleteEntityTypes/main.go index 73aae11562fa..c9905bc087ff 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/BatchDeleteEntityTypes/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/BatchDeleteEntityTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/BatchUpdateEntities/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/BatchUpdateEntities/main.go index 3add0ab8a692..29b355ec1909 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/BatchUpdateEntities/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/BatchUpdateEntities/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/BatchUpdateEntityTypes/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/BatchUpdateEntityTypes/main.go index 7c7fd86d9ea9..13a409cd118d 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/BatchUpdateEntityTypes/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/BatchUpdateEntityTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/CancelOperation/main.go index d24b60f324a6..a244719d0941 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/CreateEntityType/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/CreateEntityType/main.go index 9bad912d7288..88b3a4622093 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/CreateEntityType/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/CreateEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/DeleteEntityType/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/DeleteEntityType/main.go index 8814a09d641e..b5a5d95a2947 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/DeleteEntityType/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/DeleteEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/GetEntityType/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/GetEntityType/main.go index 7124edda3402..a67cf39f18f8 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/GetEntityType/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/GetEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/GetLocation/main.go index 7a8e6cb9bbcb..4aad292c8369 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/GetOperation/main.go index 0cfdf1db258d..5863d2e84175 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/ListEntityTypes/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/ListEntityTypes/main.go index df6fa5c20f37..97b4cc202bd0 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/ListEntityTypes/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/ListEntityTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/ListLocations/main.go index 697c2b1be487..9a29e6109e8a 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/ListOperations/main.go index 51547d4f4ec6..6d55d4e029d9 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/UpdateEntityType/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/UpdateEntityType/main.go index 1f332297f8f4..4b30048272d0 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/UpdateEntityType/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EntityTypesClient/UpdateEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/CancelOperation/main.go index a4da838ea587..604feb12095b 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/CreateEnvironment/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/CreateEnvironment/main.go index 25394785fe1f..853ccc8d6e92 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/CreateEnvironment/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/CreateEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/DeleteEnvironment/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/DeleteEnvironment/main.go index 28e5834549ee..05d5505961dd 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/DeleteEnvironment/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/DeleteEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/GetEnvironment/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/GetEnvironment/main.go index f3e7d65fe72b..c8f2a691b25d 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/GetEnvironment/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/GetEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/GetEnvironmentHistory/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/GetEnvironmentHistory/main.go index c32eb5db4c25..3333da86c99a 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/GetEnvironmentHistory/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/GetEnvironmentHistory/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/GetLocation/main.go index 69ef97fb4e9b..88cd7ff1dae7 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/GetOperation/main.go index 6817cac856e2..5ef7fb6a8ea0 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/ListEnvironments/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/ListEnvironments/main.go index 1b75b7f4618d..e7520da5941f 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/ListEnvironments/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/ListEnvironments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/ListLocations/main.go index ce15fcb54bb7..4c28591aa871 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/ListOperations/main.go index d6a403e9e6a4..f3276553e8dc 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/UpdateEnvironment/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/UpdateEnvironment/main.go index 14a8c8f3a3d5..dd1f145241e8 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/UpdateEnvironment/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/EnvironmentsClient/UpdateEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/FulfillmentsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/FulfillmentsClient/CancelOperation/main.go index 811351b14c5d..dd0cf20b2e63 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/FulfillmentsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/FulfillmentsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/FulfillmentsClient/GetFulfillment/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/FulfillmentsClient/GetFulfillment/main.go index edd587df2599..33d2f7df83ce 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/FulfillmentsClient/GetFulfillment/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/FulfillmentsClient/GetFulfillment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/FulfillmentsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/FulfillmentsClient/GetLocation/main.go index c1954f980981..bd8cd8120580 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/FulfillmentsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/FulfillmentsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/FulfillmentsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/FulfillmentsClient/GetOperation/main.go index b4db00f3c591..48ac2a86f3b9 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/FulfillmentsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/FulfillmentsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/FulfillmentsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/FulfillmentsClient/ListLocations/main.go index d373f697ba6d..44bfc42eb9bd 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/FulfillmentsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/FulfillmentsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/FulfillmentsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/FulfillmentsClient/ListOperations/main.go index 07b9709884fb..1a6797d131c6 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/FulfillmentsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/FulfillmentsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/FulfillmentsClient/UpdateFulfillment/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/FulfillmentsClient/UpdateFulfillment/main.go index 4ef9f947f9bb..5a71a12ab7a8 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/FulfillmentsClient/UpdateFulfillment/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/FulfillmentsClient/UpdateFulfillment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/CancelOperation/main.go index 27e52750a8a8..396294f1a388 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/CreateGenerator/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/CreateGenerator/main.go index 2825527c16df..c6bbc87e167f 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/CreateGenerator/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/CreateGenerator/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/DeleteGenerator/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/DeleteGenerator/main.go index e6bbf8bbd54e..1193bc5488c0 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/DeleteGenerator/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/DeleteGenerator/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/GetGenerator/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/GetGenerator/main.go index 0dc84a95b1f0..fe5008625ecc 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/GetGenerator/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/GetGenerator/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/GetLocation/main.go index 3aab0efe1f27..d6fdaf1f0135 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/GetOperation/main.go index b030318b5e70..b94c5323671d 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/ListGenerators/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/ListGenerators/main.go index 05638641e4e3..bb3a2fc8e6bf 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/ListGenerators/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/ListGenerators/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/ListLocations/main.go index 757c35159a81..8bc8fc69f0b0 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/ListOperations/main.go index 1549417bcd95..1ccf4de51bcb 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/UpdateGenerator/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/UpdateGenerator/main.go index d4a904b0d1f2..07b7ecc8b5d7 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/UpdateGenerator/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/GeneratorsClient/UpdateGenerator/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/BatchDeleteIntents/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/BatchDeleteIntents/main.go index ec8cfb2c72a7..a09510eb04aa 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/BatchDeleteIntents/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/BatchDeleteIntents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/BatchUpdateIntents/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/BatchUpdateIntents/main.go index bb6a8d397d04..510e0d0f29d9 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/BatchUpdateIntents/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/BatchUpdateIntents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/CancelOperation/main.go index 15fd65b0cb44..0c3063eac70d 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/CreateIntent/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/CreateIntent/main.go index fc6cf6eee01d..083bc2d54241 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/CreateIntent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/CreateIntent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/DeleteIntent/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/DeleteIntent/main.go index 0113a5acfa93..be49b6b08014 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/DeleteIntent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/DeleteIntent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/GetIntent/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/GetIntent/main.go index 63fbaacd6ce2..b2ce0560cc3e 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/GetIntent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/GetIntent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/GetLocation/main.go index c8c11322e13e..e4046d4e0686 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/GetOperation/main.go index 74fa7d3e7d1c..241d83aaf6e7 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/ListIntents/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/ListIntents/main.go index 58c663cf15cb..f292c7a78330 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/ListIntents/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/ListIntents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/ListLocations/main.go index 99912e513c97..3122e1c9d45b 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/ListOperations/main.go index 6365bcbe3a70..fd4ef2b858ec 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/UpdateIntent/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/UpdateIntent/main.go index 3e9e852d1513..7fbece76dc5c 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/UpdateIntent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/IntentsClient/UpdateIntent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/CancelOperation/main.go index df106866ef5d..9d41763977fa 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/CreateKnowledgeBase/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/CreateKnowledgeBase/main.go index 7e28f9461ce8..bffec5ea33a7 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/CreateKnowledgeBase/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/CreateKnowledgeBase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/DeleteKnowledgeBase/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/DeleteKnowledgeBase/main.go index 8698df237510..d776648402e0 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/DeleteKnowledgeBase/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/DeleteKnowledgeBase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/GetKnowledgeBase/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/GetKnowledgeBase/main.go index e75200223256..84735b8aca3c 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/GetKnowledgeBase/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/GetKnowledgeBase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/GetLocation/main.go index 175e105158ab..b5cf88ef85e9 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/GetOperation/main.go index f1985c72bcfe..2a3aa2abc188 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/ListKnowledgeBases/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/ListKnowledgeBases/main.go index 15fe97e5c67f..92a1105b2ab9 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/ListKnowledgeBases/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/ListKnowledgeBases/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/ListLocations/main.go index 06222ce1f58d..16800cc6b93c 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/ListOperations/main.go index 5638792f6f36..2cff303bfc75 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/UpdateKnowledgeBase/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/UpdateKnowledgeBase/main.go index 8935be1eb873..7988ebeffa21 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/UpdateKnowledgeBase/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/KnowledgeBasesClient/UpdateKnowledgeBase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/AnalyzeContent/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/AnalyzeContent/main.go index 5a51fcfcadd6..b404a6f2d510 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/AnalyzeContent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/AnalyzeContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/CancelOperation/main.go index dd2215f1bad7..b926cc1c04e8 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/CompileSuggestion/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/CompileSuggestion/main.go index 6c64586377a9..8105a86aa449 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/CompileSuggestion/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/CompileSuggestion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/CreateParticipant/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/CreateParticipant/main.go index 8673c025820e..b7ec25ae3884 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/CreateParticipant/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/CreateParticipant/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/GetLocation/main.go index 6517a4f6c632..4f57e067ecec 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/GetOperation/main.go index a9689a0a24fc..5a3b3e891f29 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/GetParticipant/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/GetParticipant/main.go index 3cee8a463c38..72172665b13a 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/GetParticipant/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/GetParticipant/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/ListLocations/main.go index defabc139faf..870cbeaf2f20 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/ListOperations/main.go index c0ec96c7d980..239390a2725e 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/ListParticipants/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/ListParticipants/main.go index f4c36f069ac8..932ba047a7a2 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/ListParticipants/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/ListParticipants/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/ListSuggestions/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/ListSuggestions/main.go index 9d98d693d880..fd9f011489a9 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/ListSuggestions/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/ListSuggestions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/StreamingAnalyzeContent/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/StreamingAnalyzeContent/main.go index 77e688f71760..5c64102b57fe 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/StreamingAnalyzeContent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/StreamingAnalyzeContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/SuggestArticles/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/SuggestArticles/main.go index 330c5e2520ff..19e527e88846 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/SuggestArticles/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/SuggestArticles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/SuggestFaqAnswers/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/SuggestFaqAnswers/main.go index 5df794f46b56..1895f1e4f725 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/SuggestFaqAnswers/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/SuggestFaqAnswers/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/SuggestKnowledgeAssist/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/SuggestKnowledgeAssist/main.go index 776120f968e3..41e43d1870cf 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/SuggestKnowledgeAssist/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/SuggestKnowledgeAssist/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/SuggestSmartReplies/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/SuggestSmartReplies/main.go index d161d7739760..fda8c67927d4 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/SuggestSmartReplies/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/SuggestSmartReplies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/UpdateParticipant/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/UpdateParticipant/main.go index 09db9fa7c544..7c6980a71c1e 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/UpdateParticipant/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/ParticipantsClient/UpdateParticipant/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/CancelOperation/main.go index 5dd7a87d8025..f1823492b54f 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/CreateSessionEntityType/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/CreateSessionEntityType/main.go index d97e3a503522..4d7e920b85b5 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/CreateSessionEntityType/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/CreateSessionEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/DeleteSessionEntityType/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/DeleteSessionEntityType/main.go index 408e2ae4ed9c..055a2db431b2 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/DeleteSessionEntityType/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/DeleteSessionEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/GetLocation/main.go index 80bfada8368f..dd91eb2237db 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/GetOperation/main.go index b877fe6b5208..751446f800be 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/GetSessionEntityType/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/GetSessionEntityType/main.go index 00be9b9b9a8a..ad457d16cb2e 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/GetSessionEntityType/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/GetSessionEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/ListLocations/main.go index e3dee3c485b2..76e95237fc5a 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/ListOperations/main.go index acbaa642f868..146d52d2bbc5 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/ListSessionEntityTypes/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/ListSessionEntityTypes/main.go index 162b23e84ec8..97c151e161dd 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/ListSessionEntityTypes/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/ListSessionEntityTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/UpdateSessionEntityType/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/UpdateSessionEntityType/main.go index 0591ebada95e..305b39415993 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/UpdateSessionEntityType/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/SessionEntityTypesClient/UpdateSessionEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/SessionsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/SessionsClient/CancelOperation/main.go index 525e73a235a6..57a82dd4e569 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/SessionsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/SessionsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/SessionsClient/DetectIntent/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/SessionsClient/DetectIntent/main.go index 793781523c20..f3f9a48636da 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/SessionsClient/DetectIntent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/SessionsClient/DetectIntent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/SessionsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/SessionsClient/GetLocation/main.go index fd091f3ddc4c..5d0e1571fb61 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/SessionsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/SessionsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/SessionsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/SessionsClient/GetOperation/main.go index 74dc0e1a9331..aff005022f7d 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/SessionsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/SessionsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/SessionsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/SessionsClient/ListLocations/main.go index 73b0abcb508d..b86df260bda7 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/SessionsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/SessionsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/SessionsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/SessionsClient/ListOperations/main.go index cb9b9baba550..ca7c1f75de24 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/SessionsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/SessionsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/SessionsClient/StreamingDetectIntent/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/SessionsClient/StreamingDetectIntent/main.go index 2f9a478901df..ace4e4abe4e7 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/SessionsClient/StreamingDetectIntent/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/SessionsClient/StreamingDetectIntent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/CancelOperation/main.go index f8bfbda227d8..ff5d1aa7ace2 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/CreateSipTrunk/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/CreateSipTrunk/main.go index b0d641d9e04a..57556115b7d0 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/CreateSipTrunk/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/CreateSipTrunk/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/DeleteSipTrunk/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/DeleteSipTrunk/main.go index 685179254820..24e653754b51 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/DeleteSipTrunk/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/DeleteSipTrunk/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/GetLocation/main.go index 005d1efa49f5..bfe8061692d3 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/GetOperation/main.go index d1f03658a1b5..7d3a9eee7777 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/GetSipTrunk/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/GetSipTrunk/main.go index 5bc8db10a035..e4b6c29c1ede 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/GetSipTrunk/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/GetSipTrunk/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/ListLocations/main.go index 6864f250ace4..505129d3aa82 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/ListOperations/main.go index 1da8f9d40eaa..3ddc017f6e1c 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/ListSipTrunks/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/ListSipTrunks/main.go index 230ef135b780..dffd85bb13f0 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/ListSipTrunks/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/ListSipTrunks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/UpdateSipTrunk/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/UpdateSipTrunk/main.go index 7c1f3d5736bd..9bc9c79ed7bf 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/UpdateSipTrunk/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/SipTrunksClient/UpdateSipTrunk/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/CancelOperation/main.go index c28ede6f3f48..8ec793125a37 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/CreateVersion/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/CreateVersion/main.go index e73258a9df4f..f22a6bf91551 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/CreateVersion/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/CreateVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/DeleteVersion/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/DeleteVersion/main.go index c19632b4ca16..5c642a3486d0 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/DeleteVersion/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/DeleteVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/GetLocation/main.go index 0856461d0f0d..1461caa375ca 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/GetOperation/main.go index e6db4792ad42..e56607b10faa 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/GetVersion/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/GetVersion/main.go index d0ee434a3bbd..1df657e98c7b 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/GetVersion/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/GetVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/ListLocations/main.go index b02fd9d3a18a..74fb745341b8 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/ListOperations/main.go index 9ea1d1491af6..f093914468ec 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/ListVersions/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/ListVersions/main.go index e18b33362ff6..50507d477c30 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/ListVersions/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/ListVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/UpdateVersion/main.go b/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/UpdateVersion/main.go index 02d2f0e85954..2d881ef4fcc7 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/UpdateVersion/main.go +++ b/internal/generated/snippets/dialogflow/apiv2beta1/VersionsClient/UpdateVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/apiv2beta1/snippet_metadata.google.cloud.dialogflow.v2beta1.json b/internal/generated/snippets/dialogflow/apiv2beta1/snippet_metadata.google.cloud.dialogflow.v2beta1.json index d1a67d738926..7247c59c2b9a 100644 --- a/internal/generated/snippets/dialogflow/apiv2beta1/snippet_metadata.google.cloud.dialogflow.v2beta1.json +++ b/internal/generated/snippets/dialogflow/apiv2beta1/snippet_metadata.google.cloud.dialogflow.v2beta1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/dialogflow/apiv2beta1", - "version": "1.64.0", + "version": "1.64.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/CancelOperation/main.go index a3296289751e..0fcb463f284d 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/CreateAgent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/CreateAgent/main.go index 9cc2231da220..be546178b76c 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/CreateAgent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/CreateAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/DeleteAgent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/DeleteAgent/main.go index b6076439d210..f28cc9260612 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/DeleteAgent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/DeleteAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/ExportAgent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/ExportAgent/main.go index 702d6407ac34..9511ad09d0c8 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/ExportAgent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/ExportAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/GetAgent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/GetAgent/main.go index 19b89e17ab5a..57c35af46d1a 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/GetAgent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/GetAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/GetAgentValidationResult/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/GetAgentValidationResult/main.go index 6c822926225a..72d8ab5f9b74 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/GetAgentValidationResult/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/GetAgentValidationResult/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/GetGenerativeSettings/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/GetGenerativeSettings/main.go index 60c697fda510..732c9bb1034e 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/GetGenerativeSettings/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/GetGenerativeSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/GetLocation/main.go index 16349885a764..7b7232fb97ff 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/GetOperation/main.go index 7361b2f31730..5a4d305f8e8a 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/ListAgents/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/ListAgents/main.go index f745123ab9d6..85b26f981318 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/ListAgents/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/ListAgents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/ListLocations/main.go index b992f93e3ac8..eabb5c831f6e 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/ListOperations/main.go index d44b6bf7b8f9..43c314ea60a3 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/RestoreAgent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/RestoreAgent/main.go index 7bf9387f6f4a..96f501db991c 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/RestoreAgent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/RestoreAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/UpdateAgent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/UpdateAgent/main.go index b5b938806169..80f8f6a991cf 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/UpdateAgent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/UpdateAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/UpdateGenerativeSettings/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/UpdateGenerativeSettings/main.go index 6ee533ae2beb..d0bdae336179 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/UpdateGenerativeSettings/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/UpdateGenerativeSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/ValidateAgent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/ValidateAgent/main.go index 7b34961ede0f..731f39ac0da2 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/ValidateAgent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/AgentsClient/ValidateAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/ChangelogsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/ChangelogsClient/CancelOperation/main.go index 9987ee9e0cef..605dc214fef1 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/ChangelogsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/ChangelogsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/ChangelogsClient/GetChangelog/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/ChangelogsClient/GetChangelog/main.go index 843790c4862a..15976ee21e86 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/ChangelogsClient/GetChangelog/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/ChangelogsClient/GetChangelog/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/ChangelogsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/ChangelogsClient/GetLocation/main.go index ec4208ffe75a..7b273307fdfc 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/ChangelogsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/ChangelogsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/ChangelogsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/ChangelogsClient/GetOperation/main.go index 0b7db89d6e67..4fa8224d73fe 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/ChangelogsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/ChangelogsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/ChangelogsClient/ListChangelogs/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/ChangelogsClient/ListChangelogs/main.go index 8c6853c873cd..281f30eee85a 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/ChangelogsClient/ListChangelogs/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/ChangelogsClient/ListChangelogs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/ChangelogsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/ChangelogsClient/ListLocations/main.go index 0e014124ba19..20bbe82fb694 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/ChangelogsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/ChangelogsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/ChangelogsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/ChangelogsClient/ListOperations/main.go index e9565f60b1ab..eb0963d9eb0a 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/ChangelogsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/ChangelogsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/DeploymentsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/DeploymentsClient/CancelOperation/main.go index bde35f8ddd9d..21a31041a1b6 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/DeploymentsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/DeploymentsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/DeploymentsClient/GetDeployment/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/DeploymentsClient/GetDeployment/main.go index d39e2c604926..b089bb7514c1 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/DeploymentsClient/GetDeployment/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/DeploymentsClient/GetDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/DeploymentsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/DeploymentsClient/GetLocation/main.go index c769b26a8edf..8095d1aa0130 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/DeploymentsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/DeploymentsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/DeploymentsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/DeploymentsClient/GetOperation/main.go index d52adf949a22..9d14570aa281 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/DeploymentsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/DeploymentsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/DeploymentsClient/ListDeployments/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/DeploymentsClient/ListDeployments/main.go index 5dafed6bfd33..64798dedcd10 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/DeploymentsClient/ListDeployments/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/DeploymentsClient/ListDeployments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/DeploymentsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/DeploymentsClient/ListLocations/main.go index 49a06b3e1182..f1dbf7dec7b3 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/DeploymentsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/DeploymentsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/DeploymentsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/DeploymentsClient/ListOperations/main.go index 15d59c671dfc..97c53d8aeef9 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/DeploymentsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/DeploymentsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/CancelOperation/main.go index 192d17b62997..f4fca11c394d 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/CreateEntityType/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/CreateEntityType/main.go index bb295acb23c4..2c892140b15a 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/CreateEntityType/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/CreateEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/DeleteEntityType/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/DeleteEntityType/main.go index ef4fc1ed8cb9..688f98240700 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/DeleteEntityType/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/DeleteEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/ExportEntityTypes/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/ExportEntityTypes/main.go index 302d0c27989d..7c0e20d95d06 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/ExportEntityTypes/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/ExportEntityTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/GetEntityType/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/GetEntityType/main.go index 89411a7b6f69..cff3283cb7f4 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/GetEntityType/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/GetEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/GetLocation/main.go index 1c3b9e1adc16..94bacd95bdbc 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/GetOperation/main.go index 0c042985ab21..e2266a2557ee 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/ImportEntityTypes/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/ImportEntityTypes/main.go index 2b53779b1fa7..4fd4ae7f4928 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/ImportEntityTypes/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/ImportEntityTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/ListEntityTypes/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/ListEntityTypes/main.go index 5a8e55942028..ba67e13a066f 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/ListEntityTypes/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/ListEntityTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/ListLocations/main.go index c69442bb1ce6..19bfb88c6f6c 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/ListOperations/main.go index 2b9509eacfdb..883143c4f0e9 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/UpdateEntityType/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/UpdateEntityType/main.go index 50fb1c2cacaf..b5a716992780 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/UpdateEntityType/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/EntityTypesClient/UpdateEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/CancelOperation/main.go index c2b4eda55ccf..61da5e8808d0 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/CreateEnvironment/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/CreateEnvironment/main.go index 6d87a5876e0d..12ad70ecb5f0 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/CreateEnvironment/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/CreateEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/DeleteEnvironment/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/DeleteEnvironment/main.go index df6d5b7fc493..5fec2397d4b8 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/DeleteEnvironment/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/DeleteEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/DeployFlow/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/DeployFlow/main.go index 0bc13462016e..92a717deb33a 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/DeployFlow/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/DeployFlow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/GetEnvironment/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/GetEnvironment/main.go index 80cdc0f7ef70..6ca6e49f5d97 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/GetEnvironment/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/GetEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/GetLocation/main.go index ed16ea910a79..874310b8eb18 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/GetOperation/main.go index 8590ddd1868f..aef5fc1b03ba 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/ListContinuousTestResults/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/ListContinuousTestResults/main.go index 86edf7e78549..4146d5301cf7 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/ListContinuousTestResults/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/ListContinuousTestResults/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/ListEnvironments/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/ListEnvironments/main.go index e890e1f103c2..1acbb78713f9 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/ListEnvironments/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/ListEnvironments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/ListLocations/main.go index 1ca5799ee824..2ca7a1be1c81 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/ListOperations/main.go index 6f499c1a536e..b1396957d637 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/LookupEnvironmentHistory/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/LookupEnvironmentHistory/main.go index 80c58317a964..cdd3931d3b51 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/LookupEnvironmentHistory/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/LookupEnvironmentHistory/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/RunContinuousTest/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/RunContinuousTest/main.go index 1bc28d20224f..227e944249b3 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/RunContinuousTest/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/RunContinuousTest/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/UpdateEnvironment/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/UpdateEnvironment/main.go index 7056f5d3fb37..51c3bfe9bc33 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/UpdateEnvironment/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/EnvironmentsClient/UpdateEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/CancelOperation/main.go index 76b75923d5d1..51935a3b8417 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/CreateExperiment/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/CreateExperiment/main.go index 086e86b93fdc..c472307ae722 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/CreateExperiment/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/CreateExperiment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/DeleteExperiment/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/DeleteExperiment/main.go index 1527f2d0723a..35c69675ebc8 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/DeleteExperiment/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/DeleteExperiment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/GetExperiment/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/GetExperiment/main.go index 639b06ac4a6f..44a41a4bf20b 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/GetExperiment/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/GetExperiment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/GetLocation/main.go index fd3ac12b828c..bc84c1a38b90 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/GetOperation/main.go index 9a711ebd3c09..bc73fb0eae16 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/ListExperiments/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/ListExperiments/main.go index 398598978135..273a20386a75 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/ListExperiments/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/ListExperiments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/ListLocations/main.go index e85f59ec142e..bd31f104a58c 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/ListOperations/main.go index 5dcfa44cbf54..d20b5c9ee8b6 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/StartExperiment/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/StartExperiment/main.go index 9e64500eb953..cfcc8bb2217a 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/StartExperiment/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/StartExperiment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/StopExperiment/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/StopExperiment/main.go index 47a45eceae74..6f112e188196 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/StopExperiment/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/StopExperiment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/UpdateExperiment/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/UpdateExperiment/main.go index 3616377c55e0..21ef57ae3f2f 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/UpdateExperiment/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/ExperimentsClient/UpdateExperiment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/CancelOperation/main.go index b062c979babc..87a3e720a5a6 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/CreateFlow/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/CreateFlow/main.go index 1756426ab15c..b57d514a6c45 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/CreateFlow/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/CreateFlow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/DeleteFlow/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/DeleteFlow/main.go index 196e274e8d50..e003dd36ae68 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/DeleteFlow/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/DeleteFlow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/ExportFlow/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/ExportFlow/main.go index a1aa983eb788..ea5552ef39bf 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/ExportFlow/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/ExportFlow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/GetFlow/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/GetFlow/main.go index 607facd327b1..2903c7566a0e 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/GetFlow/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/GetFlow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/GetFlowValidationResult/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/GetFlowValidationResult/main.go index 5b026f07f53b..f68db1573811 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/GetFlowValidationResult/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/GetFlowValidationResult/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/GetLocation/main.go index d409497da785..86dacdca0442 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/GetOperation/main.go index f37bd8d29b2a..0b08a54d8c8f 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/ImportFlow/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/ImportFlow/main.go index d1af210ef2ab..5480029a0717 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/ImportFlow/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/ImportFlow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/ListFlows/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/ListFlows/main.go index a384cb349d2d..5bfa50246940 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/ListFlows/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/ListFlows/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/ListLocations/main.go index acc04a7d4dc1..d8b043637271 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/ListOperations/main.go index 1b648909d4d7..4bbf9763160d 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/TrainFlow/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/TrainFlow/main.go index a5dc515ef7bd..be7ef7dc0280 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/TrainFlow/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/TrainFlow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/UpdateFlow/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/UpdateFlow/main.go index 628a3e854626..2900cd036467 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/UpdateFlow/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/UpdateFlow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/ValidateFlow/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/ValidateFlow/main.go index a4e7f64969ab..400b0d5cba72 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/ValidateFlow/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/FlowsClient/ValidateFlow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/CancelOperation/main.go index 35f153328b50..11ee8d52fd26 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/CreateGenerator/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/CreateGenerator/main.go index 9d48456ad54e..a46414d4b87a 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/CreateGenerator/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/CreateGenerator/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/DeleteGenerator/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/DeleteGenerator/main.go index b6cb1cfc0ba4..b3d9c7896859 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/DeleteGenerator/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/DeleteGenerator/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/GetGenerator/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/GetGenerator/main.go index 75b928468bf5..7dc3c3c0ef16 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/GetGenerator/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/GetGenerator/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/GetLocation/main.go index 2eeed8e8a958..05c680bc19d1 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/GetOperation/main.go index 57c0b6e18d05..50dd97fc7819 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/ListGenerators/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/ListGenerators/main.go index 4a7fcbdac1cb..16fd0707c0c0 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/ListGenerators/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/ListGenerators/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/ListLocations/main.go index 8aefa44e536d..3a06d5c6b676 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/ListOperations/main.go index f4f25608d9ac..726d4f63bb4a 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/UpdateGenerator/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/UpdateGenerator/main.go index 27a54e9f7b99..2f3a0a749fdd 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/UpdateGenerator/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/GeneratorsClient/UpdateGenerator/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/CancelOperation/main.go index 8ec5adbb4b1c..f5711ea274da 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/CreateIntent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/CreateIntent/main.go index d079f75e255f..0b4a942d0fa6 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/CreateIntent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/CreateIntent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/DeleteIntent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/DeleteIntent/main.go index 758d1b3d3bb1..441bfa627a5e 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/DeleteIntent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/DeleteIntent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/ExportIntents/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/ExportIntents/main.go index cdce970d3a0d..8e55d8b2c321 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/ExportIntents/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/ExportIntents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/GetIntent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/GetIntent/main.go index 3e20bebd5d27..70dbcb367491 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/GetIntent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/GetIntent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/GetLocation/main.go index d360e040fb21..f9c7a1fe8033 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/GetOperation/main.go index 74e9b1972cc9..ec306efd6060 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/ImportIntents/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/ImportIntents/main.go index 5371ef01021f..68d6f96c4eb5 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/ImportIntents/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/ImportIntents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/ListIntents/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/ListIntents/main.go index 5c354d07a702..38bc5e4b8853 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/ListIntents/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/ListIntents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/ListLocations/main.go index 0454c56d4cd6..061da81fbeb8 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/ListOperations/main.go index dfa5a062d16d..27d00c21c2d6 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/UpdateIntent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/UpdateIntent/main.go index 94b73fea287d..08b873851b8c 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/UpdateIntent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/IntentsClient/UpdateIntent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/CancelOperation/main.go index 1462b6009157..5b52bc1412cc 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/CreatePage/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/CreatePage/main.go index 9081a0aec535..1b5c50bc59ee 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/CreatePage/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/CreatePage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/DeletePage/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/DeletePage/main.go index f9ca35a24e83..9f2b8901702c 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/DeletePage/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/DeletePage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/GetLocation/main.go index 5353bec7a31a..8a09589e787e 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/GetOperation/main.go index 32b67fe4e612..069021970923 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/GetPage/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/GetPage/main.go index ced8bc5b67b7..d19b1126474b 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/GetPage/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/GetPage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/ListLocations/main.go index fc79e33b9996..aeabc9721cf6 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/ListOperations/main.go index b861627d9307..c9daef4dbdc7 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/ListPages/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/ListPages/main.go index 61c9de735e2a..b174da5a0498 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/ListPages/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/ListPages/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/UpdatePage/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/UpdatePage/main.go index 3a522398e4f2..bde1b8e0f882 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/UpdatePage/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/PagesClient/UpdatePage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/CancelOperation/main.go index 3cce6fcee2ab..25fd10850aa1 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/CreateSecuritySettings/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/CreateSecuritySettings/main.go index a38df427d24d..6ef2e7cbc303 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/CreateSecuritySettings/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/CreateSecuritySettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/DeleteSecuritySettings/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/DeleteSecuritySettings/main.go index f5efab353e1b..f3328b34b0ba 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/DeleteSecuritySettings/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/DeleteSecuritySettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/GetLocation/main.go index b583555b100b..67c141b40779 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/GetOperation/main.go index 4129c3f2a588..c736e68699fb 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/GetSecuritySettings/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/GetSecuritySettings/main.go index 094549380f55..e2ccfbdba47e 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/GetSecuritySettings/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/GetSecuritySettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/ListLocations/main.go index 10aa6611eaad..9820e46867c0 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/ListOperations/main.go index 1127ee48e58e..a1f691dedbf9 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/ListSecuritySettings/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/ListSecuritySettings/main.go index 7335e23f14a4..5a6bf6b29ce3 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/ListSecuritySettings/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/ListSecuritySettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/UpdateSecuritySettings/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/UpdateSecuritySettings/main.go index 505adc694d7f..61b65d7ed21f 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/UpdateSecuritySettings/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SecuritySettingsClient/UpdateSecuritySettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/CancelOperation/main.go index c12d2094df4d..fc7db3966fc8 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/CreateSessionEntityType/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/CreateSessionEntityType/main.go index 96352d50e9fd..12931a1268ef 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/CreateSessionEntityType/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/CreateSessionEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/DeleteSessionEntityType/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/DeleteSessionEntityType/main.go index 5c19eb3bf36e..9b240d57cfa2 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/DeleteSessionEntityType/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/DeleteSessionEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/GetLocation/main.go index 0ce42c456ca0..e1748a936ec1 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/GetOperation/main.go index 59ffb082c2c9..ea764aa0ee9c 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/GetSessionEntityType/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/GetSessionEntityType/main.go index 02ce6a9cb05b..129a1cbaa097 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/GetSessionEntityType/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/GetSessionEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/ListLocations/main.go index 25e22fa7ca39..e243f2b2ad8e 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/ListOperations/main.go index 3f473008ce15..8aa2aa409885 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/ListSessionEntityTypes/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/ListSessionEntityTypes/main.go index 91795f61f26a..c4cf12436aef 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/ListSessionEntityTypes/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/ListSessionEntityTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/UpdateSessionEntityType/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/UpdateSessionEntityType/main.go index 5cfc5048c07c..2120e4f092f5 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/UpdateSessionEntityType/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SessionEntityTypesClient/UpdateSessionEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/CancelOperation/main.go index fac410ba597b..03b60f3b4ca0 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/DetectIntent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/DetectIntent/main.go index 56fbe14b9a62..7ad34014b97f 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/DetectIntent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/DetectIntent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/FulfillIntent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/FulfillIntent/main.go index da6c027b8c72..98f9c948591b 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/FulfillIntent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/FulfillIntent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/GetLocation/main.go index c98604a682ab..4879e9093995 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/GetOperation/main.go index 49b1e6b13bd0..8a0ccfa048b2 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/ListLocations/main.go index 72bf04514233..5b4de68f4816 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/ListOperations/main.go index 798c7c629aec..7423ffab80fb 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/MatchIntent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/MatchIntent/main.go index f0144b512844..5da6a4b58bce 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/MatchIntent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/MatchIntent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/StreamingDetectIntent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/StreamingDetectIntent/main.go index ba63afed0443..686485123519 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/StreamingDetectIntent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/StreamingDetectIntent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/SubmitAnswerFeedback/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/SubmitAnswerFeedback/main.go index 6e12765fe3bd..dddfd94e53fa 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/SubmitAnswerFeedback/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/SessionsClient/SubmitAnswerFeedback/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/BatchDeleteTestCases/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/BatchDeleteTestCases/main.go index 074bdc54ca28..69303f97ee24 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/BatchDeleteTestCases/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/BatchDeleteTestCases/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/BatchRunTestCases/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/BatchRunTestCases/main.go index 3baa3eab401e..236d6877886c 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/BatchRunTestCases/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/BatchRunTestCases/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/CalculateCoverage/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/CalculateCoverage/main.go index e4fbb3437ac9..065906aab39b 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/CalculateCoverage/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/CalculateCoverage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/CancelOperation/main.go index 062f69ff6fca..443e223b472a 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/CreateTestCase/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/CreateTestCase/main.go index bd60c7d8e964..058abb451ec5 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/CreateTestCase/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/CreateTestCase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/ExportTestCases/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/ExportTestCases/main.go index 9cdc2060b26b..f8f6b099dd0b 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/ExportTestCases/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/ExportTestCases/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/GetLocation/main.go index b0e741b9f26c..1c1505d1ee30 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/GetOperation/main.go index a6a15470a1f0..07b7ac150fd3 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/GetTestCase/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/GetTestCase/main.go index 64f6109c3ece..a7fe3a3d208c 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/GetTestCase/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/GetTestCase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/GetTestCaseResult/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/GetTestCaseResult/main.go index 699b1af49a29..5871b39edb8c 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/GetTestCaseResult/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/GetTestCaseResult/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/ImportTestCases/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/ImportTestCases/main.go index 643fa6a16732..859087c2f77e 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/ImportTestCases/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/ImportTestCases/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/ListLocations/main.go index 23b404bcdfa6..6711bd9b170e 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/ListOperations/main.go index 96b8ce8e1226..3cb1047eab8d 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/ListTestCaseResults/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/ListTestCaseResults/main.go index 275f8496f7cb..553f9387d552 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/ListTestCaseResults/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/ListTestCaseResults/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/ListTestCases/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/ListTestCases/main.go index dd9001c2dad9..c9fff3001b14 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/ListTestCases/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/ListTestCases/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/RunTestCase/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/RunTestCase/main.go index ed6b43d85847..10e268f86061 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/RunTestCase/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/RunTestCase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/UpdateTestCase/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/UpdateTestCase/main.go index 9c3e12172653..16b80205401c 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/UpdateTestCase/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/TestCasesClient/UpdateTestCase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/CancelOperation/main.go index 56504c571a5a..ae8416f0a149 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/CreateTransitionRouteGroup/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/CreateTransitionRouteGroup/main.go index b3de5e5f4d26..4f5b3932f964 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/CreateTransitionRouteGroup/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/CreateTransitionRouteGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/DeleteTransitionRouteGroup/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/DeleteTransitionRouteGroup/main.go index 61a4f804edce..4f5de415c2a9 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/DeleteTransitionRouteGroup/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/DeleteTransitionRouteGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/GetLocation/main.go index dbdb6916564f..9e6c50927214 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/GetOperation/main.go index 66f8298463f5..e035a901ab17 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/GetTransitionRouteGroup/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/GetTransitionRouteGroup/main.go index e68f1bab5779..90a6db951c23 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/GetTransitionRouteGroup/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/GetTransitionRouteGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/ListLocations/main.go index ec3d1e89cfb2..e7806b43756f 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/ListOperations/main.go index 6cecfae06111..b418f560601c 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/ListTransitionRouteGroups/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/ListTransitionRouteGroups/main.go index c39b6fed53ff..5132273f56b7 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/ListTransitionRouteGroups/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/ListTransitionRouteGroups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/UpdateTransitionRouteGroup/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/UpdateTransitionRouteGroup/main.go index 311ae181c327..5bc59ee18dd5 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/UpdateTransitionRouteGroup/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/TransitionRouteGroupsClient/UpdateTransitionRouteGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/CancelOperation/main.go index 601c3aff0402..8609eb2b9e6c 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/CompareVersions/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/CompareVersions/main.go index 130dcfbc84ba..ba9e8905ebd4 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/CompareVersions/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/CompareVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/CreateVersion/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/CreateVersion/main.go index 19c8096eb25e..8bca96c7eb85 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/CreateVersion/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/CreateVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/DeleteVersion/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/DeleteVersion/main.go index 5f3ed5a52bfe..d9d6c4b1bd2b 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/DeleteVersion/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/DeleteVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/GetLocation/main.go index ecf0cabd9c25..4527ccc03dda 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/GetOperation/main.go index 73bcc11fdb62..b3d52a99ad5c 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/GetVersion/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/GetVersion/main.go index 72524023eee6..d398e25a6b32 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/GetVersion/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/GetVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/ListLocations/main.go index 012f8b49b147..ad751d07fb5c 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/ListOperations/main.go index 228c1c3d15bd..94db4ca031bd 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/ListVersions/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/ListVersions/main.go index aa91a874e344..69816a6210f6 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/ListVersions/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/ListVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/LoadVersion/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/LoadVersion/main.go index b719dae2ee18..771cdf821b4a 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/LoadVersion/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/LoadVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/UpdateVersion/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/UpdateVersion/main.go index f1bb364d5e92..f6cbdd42f0a9 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/UpdateVersion/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/VersionsClient/UpdateVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/CancelOperation/main.go index 02fa20c1885b..b6d21121e075 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/CreateWebhook/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/CreateWebhook/main.go index 222cc02c41d0..98bd580b7f4b 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/CreateWebhook/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/CreateWebhook/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/DeleteWebhook/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/DeleteWebhook/main.go index d0febd4868b5..ab8ae6fd7bbb 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/DeleteWebhook/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/DeleteWebhook/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/GetLocation/main.go index 022ea213639a..013cb0882fe0 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/GetOperation/main.go index 322ad964d18f..61c23ef877c1 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/GetWebhook/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/GetWebhook/main.go index 627e2d4a6df4..63f2a49fafc9 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/GetWebhook/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/GetWebhook/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/ListLocations/main.go index 55c00b89686b..c6ca6514c6e6 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/ListOperations/main.go index 0047cff7bc56..4341c781fdfa 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/ListWebhooks/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/ListWebhooks/main.go index 56945269300d..ab080da79b5b 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/ListWebhooks/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/ListWebhooks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/UpdateWebhook/main.go b/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/UpdateWebhook/main.go index 077e50bc51ca..4735d074e03b 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/UpdateWebhook/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3/WebhooksClient/UpdateWebhook/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3/snippet_metadata.google.cloud.dialogflow.cx.v3.json b/internal/generated/snippets/dialogflow/cx/apiv3/snippet_metadata.google.cloud.dialogflow.cx.v3.json index 1aa22a1106f0..fde91aab3b8e 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3/snippet_metadata.google.cloud.dialogflow.cx.v3.json +++ b/internal/generated/snippets/dialogflow/cx/apiv3/snippet_metadata.google.cloud.dialogflow.cx.v3.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/dialogflow/cx/apiv3", - "version": "1.64.0", + "version": "1.64.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/CancelOperation/main.go index d09a9b4066e9..0aec6160f393 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/CreateAgent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/CreateAgent/main.go index 7517813916ad..4073def32257 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/CreateAgent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/CreateAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/DeleteAgent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/DeleteAgent/main.go index 67572ff6b942..c483769549bb 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/DeleteAgent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/DeleteAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/ExportAgent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/ExportAgent/main.go index 578a8d9d1849..ab853879c4e4 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/ExportAgent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/ExportAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/GetAgent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/GetAgent/main.go index f8086355bd4f..da4d9d80f767 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/GetAgent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/GetAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/GetAgentValidationResult/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/GetAgentValidationResult/main.go index c6b6e20d5572..81238725a7fc 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/GetAgentValidationResult/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/GetAgentValidationResult/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/GetGenerativeSettings/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/GetGenerativeSettings/main.go index 058bed4575bb..b6575bb28d2f 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/GetGenerativeSettings/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/GetGenerativeSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/GetLocation/main.go index 9e053104c333..73a3803fffd1 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/GetOperation/main.go index 7c657b8bd890..a3260ac91e13 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/ListAgents/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/ListAgents/main.go index 1b27f181d65d..8168f4be9ff7 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/ListAgents/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/ListAgents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/ListLocations/main.go index ceceeb9abc34..2085d867b7a1 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/ListOperations/main.go index 6abbfe0298f5..70dab0a94305 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/RestoreAgent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/RestoreAgent/main.go index 6e9c059a35d3..26ebe43eebab 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/RestoreAgent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/RestoreAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/UpdateAgent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/UpdateAgent/main.go index 09497a959202..60cdde7f3f41 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/UpdateAgent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/UpdateAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/UpdateGenerativeSettings/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/UpdateGenerativeSettings/main.go index a9a65e668e30..395d7534dceb 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/UpdateGenerativeSettings/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/UpdateGenerativeSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/ValidateAgent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/ValidateAgent/main.go index fc72609cc7bc..7bbaa9c454ec 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/ValidateAgent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/AgentsClient/ValidateAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ChangelogsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ChangelogsClient/CancelOperation/main.go index a2291b20ff59..9764b5570a89 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ChangelogsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ChangelogsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ChangelogsClient/GetChangelog/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ChangelogsClient/GetChangelog/main.go index 0890a07692c8..f661d099ecf5 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ChangelogsClient/GetChangelog/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ChangelogsClient/GetChangelog/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ChangelogsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ChangelogsClient/GetLocation/main.go index 6622807e3fcb..458c8e75db78 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ChangelogsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ChangelogsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ChangelogsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ChangelogsClient/GetOperation/main.go index 923a1b0ba0cd..72d806b55a35 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ChangelogsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ChangelogsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ChangelogsClient/ListChangelogs/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ChangelogsClient/ListChangelogs/main.go index dd3d1d1c83d6..790ca8ddd897 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ChangelogsClient/ListChangelogs/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ChangelogsClient/ListChangelogs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ChangelogsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ChangelogsClient/ListLocations/main.go index 3f68f71bc597..e995aa555774 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ChangelogsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ChangelogsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ChangelogsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ChangelogsClient/ListOperations/main.go index d7a8a163325f..fa1aa1e59441 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ChangelogsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ChangelogsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/CancelOperation/main.go index ef85b0684dbd..5aa54b908d0c 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/DeleteConversation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/DeleteConversation/main.go index bb5cd9b811ac..d2407b0ad1cc 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/DeleteConversation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/DeleteConversation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/GetConversation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/GetConversation/main.go index c18619830b8a..ef1d8e0f8271 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/GetConversation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/GetConversation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/GetLocation/main.go index f857294a4a94..696ec6c6df5c 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/GetOperation/main.go index 4b2d20457f52..f09f78e69390 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/ListConversations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/ListConversations/main.go index f3c23854d13a..93fe205cd32e 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/ListConversations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/ListConversations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/ListLocations/main.go index 5bca2b9be0b0..f3685f8bed17 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/ListOperations/main.go index 81cceafe55a8..40195c5802d0 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ConversationHistoryClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/DeploymentsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/DeploymentsClient/CancelOperation/main.go index 1a282387a259..d1747dc71fdf 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/DeploymentsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/DeploymentsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/DeploymentsClient/GetDeployment/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/DeploymentsClient/GetDeployment/main.go index ccfc21b0add8..5f675ddc5e37 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/DeploymentsClient/GetDeployment/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/DeploymentsClient/GetDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/DeploymentsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/DeploymentsClient/GetLocation/main.go index 365c9e0bd037..251642b89d37 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/DeploymentsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/DeploymentsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/DeploymentsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/DeploymentsClient/GetOperation/main.go index 6177c43b553a..1a70c60a4b18 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/DeploymentsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/DeploymentsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/DeploymentsClient/ListDeployments/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/DeploymentsClient/ListDeployments/main.go index ea34aac138ba..5957b2170287 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/DeploymentsClient/ListDeployments/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/DeploymentsClient/ListDeployments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/DeploymentsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/DeploymentsClient/ListLocations/main.go index b639f04d976d..da16e023d6b1 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/DeploymentsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/DeploymentsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/DeploymentsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/DeploymentsClient/ListOperations/main.go index e8356ee22099..f3a6321de7b0 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/DeploymentsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/DeploymentsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/CancelOperation/main.go index 90f44009bd07..2c2c7ec538f9 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/CreateEntityType/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/CreateEntityType/main.go index f76d4809bc73..5873d59e24eb 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/CreateEntityType/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/CreateEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/DeleteEntityType/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/DeleteEntityType/main.go index 6d6392addc48..a6ef60b89f76 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/DeleteEntityType/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/DeleteEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/ExportEntityTypes/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/ExportEntityTypes/main.go index beda935b55a8..31e443bef679 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/ExportEntityTypes/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/ExportEntityTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/GetEntityType/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/GetEntityType/main.go index 0c3b98f1a1b6..40b287a67c35 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/GetEntityType/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/GetEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/GetLocation/main.go index edd351110fb6..6386549bf688 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/GetOperation/main.go index 1d27455b0421..d4bc75ce5f1f 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/ImportEntityTypes/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/ImportEntityTypes/main.go index 508c93e5f81b..1182f6320b73 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/ImportEntityTypes/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/ImportEntityTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/ListEntityTypes/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/ListEntityTypes/main.go index 114b2d85956a..9c5ecb4ce1af 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/ListEntityTypes/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/ListEntityTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/ListLocations/main.go index 40940691a9f0..85830eb8ef23 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/ListOperations/main.go index 91aff1787a52..aff1c077ce0c 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/UpdateEntityType/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/UpdateEntityType/main.go index 94dcadaa9de6..87791804b3fd 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/UpdateEntityType/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EntityTypesClient/UpdateEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/CancelOperation/main.go index ecca8fe94137..f3834cc2625f 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/CreateEnvironment/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/CreateEnvironment/main.go index 76a64d5d2889..c71fc6b29ea4 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/CreateEnvironment/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/CreateEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/DeleteEnvironment/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/DeleteEnvironment/main.go index c6bb3ebc2169..5e0e0698c6d4 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/DeleteEnvironment/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/DeleteEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/DeployFlow/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/DeployFlow/main.go index d57e2389bb85..3de772f0aaa8 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/DeployFlow/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/DeployFlow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/GetEnvironment/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/GetEnvironment/main.go index 1300bffa7c7c..13633fc0d216 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/GetEnvironment/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/GetEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/GetLocation/main.go index 9e8b5337f8dc..be5f544c68cd 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/GetOperation/main.go index 3c68b899151b..842be3c3f634 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/ListContinuousTestResults/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/ListContinuousTestResults/main.go index 4eee7944fc2d..888e1dd81f68 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/ListContinuousTestResults/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/ListContinuousTestResults/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/ListEnvironments/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/ListEnvironments/main.go index 24f64add196a..f6194b9adca7 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/ListEnvironments/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/ListEnvironments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/ListLocations/main.go index 6a9a3714bfc7..5f4cf3b13cde 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/ListOperations/main.go index 83315c554c7f..1e536299e62a 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/LookupEnvironmentHistory/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/LookupEnvironmentHistory/main.go index f96b61c5fcdd..746ac667fc98 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/LookupEnvironmentHistory/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/LookupEnvironmentHistory/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/RunContinuousTest/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/RunContinuousTest/main.go index 3f90c7c96e5b..e775bfdb8582 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/RunContinuousTest/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/RunContinuousTest/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/UpdateEnvironment/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/UpdateEnvironment/main.go index e635c5cf550e..8975eb776463 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/UpdateEnvironment/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/EnvironmentsClient/UpdateEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/CancelOperation/main.go index 18557322e89e..5d2ac9cca7cf 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/CreateExample/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/CreateExample/main.go index 47a799c67010..b5a5ea49d7ff 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/CreateExample/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/CreateExample/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/DeleteExample/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/DeleteExample/main.go index f5e0b28d9eb9..4c55f815e0a6 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/DeleteExample/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/DeleteExample/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/GetExample/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/GetExample/main.go index 22f88c868f5a..d60ae3294852 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/GetExample/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/GetExample/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/GetLocation/main.go index fa45e16da66a..2001003f2815 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/GetOperation/main.go index e580a77ecbbe..604df3070672 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/ListExamples/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/ListExamples/main.go index 152aa5b4b614..3440d1c6f92c 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/ListExamples/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/ListExamples/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/ListLocations/main.go index 78abb6aba6bb..0f3e2c80a2e3 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/ListOperations/main.go index 446dd9167391..b962fa4d8b43 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/UpdateExample/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/UpdateExample/main.go index 8d11232fe73a..c8693c870028 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/UpdateExample/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExamplesClient/UpdateExample/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/CancelOperation/main.go index 10c0e5e01140..c58b49ed4bb7 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/CreateExperiment/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/CreateExperiment/main.go index 219a434aef4c..e4521c5ab5e6 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/CreateExperiment/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/CreateExperiment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/DeleteExperiment/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/DeleteExperiment/main.go index d780c7f524c2..ac820a91ffca 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/DeleteExperiment/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/DeleteExperiment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/GetExperiment/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/GetExperiment/main.go index 31278220c607..0733613a70bd 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/GetExperiment/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/GetExperiment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/GetLocation/main.go index 659ec92837fa..24611582f245 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/GetOperation/main.go index 079a1f86439d..0454f2e5177c 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/ListExperiments/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/ListExperiments/main.go index e21235667492..9ae86082cb8a 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/ListExperiments/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/ListExperiments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/ListLocations/main.go index a87aaa6e811b..264b28919bb9 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/ListOperations/main.go index fc5f64da1413..661a694783fa 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/StartExperiment/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/StartExperiment/main.go index f56ef4abb22d..e34140a07da5 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/StartExperiment/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/StartExperiment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/StopExperiment/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/StopExperiment/main.go index f96fd44ebd3e..874385f4640c 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/StopExperiment/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/StopExperiment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/UpdateExperiment/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/UpdateExperiment/main.go index 2d7e91a37dd7..c9152616dc37 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/UpdateExperiment/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ExperimentsClient/UpdateExperiment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/CancelOperation/main.go index 82f3a6ab261d..f5ecac4c33d7 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/CreateFlow/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/CreateFlow/main.go index a0ce5af5aeb9..922ad222fe1a 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/CreateFlow/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/CreateFlow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/DeleteFlow/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/DeleteFlow/main.go index 9508c5b3cb99..b5e4406434c5 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/DeleteFlow/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/DeleteFlow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/ExportFlow/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/ExportFlow/main.go index 369e60cf7290..f127c4c6adf0 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/ExportFlow/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/ExportFlow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/GetFlow/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/GetFlow/main.go index f9d3d24ab4e7..257cbc749685 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/GetFlow/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/GetFlow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/GetFlowValidationResult/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/GetFlowValidationResult/main.go index 5e41640d07d1..6ba69978a2e0 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/GetFlowValidationResult/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/GetFlowValidationResult/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/GetLocation/main.go index c248d10b98f1..8211810cf4cd 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/GetOperation/main.go index 274664be5d8b..f78715c4789f 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/ImportFlow/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/ImportFlow/main.go index 552bfa262b50..0f004b2a5e8f 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/ImportFlow/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/ImportFlow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/ListFlows/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/ListFlows/main.go index e03df7a8ae7b..c581fb3a4e17 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/ListFlows/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/ListFlows/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/ListLocations/main.go index 1764b4361e16..d0a20f9b3c5a 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/ListOperations/main.go index 6d2b3c8bc37a..f67deeef857d 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/TrainFlow/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/TrainFlow/main.go index 1670800f24df..2191be5b5423 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/TrainFlow/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/TrainFlow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/UpdateFlow/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/UpdateFlow/main.go index e564f00037b3..bd4025e3a30a 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/UpdateFlow/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/UpdateFlow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/ValidateFlow/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/ValidateFlow/main.go index d77e285e404e..678d6ee12a0b 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/ValidateFlow/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/FlowsClient/ValidateFlow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/CancelOperation/main.go index 85d495adb38e..d98adf525785 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/CreateGenerator/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/CreateGenerator/main.go index 2db9b1cdbd6e..c7b0dab7423d 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/CreateGenerator/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/CreateGenerator/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/DeleteGenerator/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/DeleteGenerator/main.go index 0b4f6c5ee436..f5fe6a422005 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/DeleteGenerator/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/DeleteGenerator/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/GetGenerator/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/GetGenerator/main.go index 9508fec0bf68..a3743411a2f4 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/GetGenerator/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/GetGenerator/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/GetLocation/main.go index b7a84f8619ea..4e57cc823272 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/GetOperation/main.go index 3116d490efa7..a4e2ff8b0786 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/ListGenerators/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/ListGenerators/main.go index 7ec517b39e12..daaf1d5a3221 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/ListGenerators/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/ListGenerators/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/ListLocations/main.go index 9d97813659f0..91728fd46cdb 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/ListOperations/main.go index d6328dce2336..b3a8cacc77f0 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/UpdateGenerator/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/UpdateGenerator/main.go index 9a113d3e4e20..d4ac31ed79d0 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/UpdateGenerator/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/GeneratorsClient/UpdateGenerator/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/CancelOperation/main.go index 506b03d2bcc0..347838acbef7 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/CreateIntent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/CreateIntent/main.go index b24df36c5517..cb7da7e14434 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/CreateIntent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/CreateIntent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/DeleteIntent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/DeleteIntent/main.go index 2c72b211ab28..cee745a9c997 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/DeleteIntent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/DeleteIntent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/ExportIntents/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/ExportIntents/main.go index b84d1e6342a4..b551dc385e57 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/ExportIntents/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/ExportIntents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/GetIntent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/GetIntent/main.go index 2cc6cf4532df..17b70318be40 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/GetIntent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/GetIntent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/GetLocation/main.go index 6172629376e7..0cc9ac19ecf8 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/GetOperation/main.go index 30b43423ee87..1cfdc5617528 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/ImportIntents/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/ImportIntents/main.go index 8a1dd4e2b4f0..d3e3a5e70d28 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/ImportIntents/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/ImportIntents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/ListIntents/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/ListIntents/main.go index 922f58b13f84..d0536632bfa8 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/ListIntents/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/ListIntents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/ListLocations/main.go index 96810314e1cc..fe8e9b076f92 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/ListOperations/main.go index 3e36411aa85d..61992b106885 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/UpdateIntent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/UpdateIntent/main.go index ee05a4e727d1..c02edbc72196 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/UpdateIntent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/IntentsClient/UpdateIntent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/CancelOperation/main.go index ba8c1954108c..2d246138185d 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/CreatePage/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/CreatePage/main.go index 63222ee4515c..49414031ada1 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/CreatePage/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/CreatePage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/DeletePage/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/DeletePage/main.go index 0302b481b984..8b2e80a9a270 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/DeletePage/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/DeletePage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/GetLocation/main.go index 422c7372dc31..6442b306cc5e 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/GetOperation/main.go index 32dd09ee3179..8543a5d1479c 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/GetPage/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/GetPage/main.go index eaf92fe82f93..a796fc90e3b0 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/GetPage/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/GetPage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/ListLocations/main.go index 51e67b7e3031..63d54549f5c4 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/ListOperations/main.go index 33435712b8e1..721d556c9192 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/ListPages/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/ListPages/main.go index e3a36d8b3d2a..84f6db608657 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/ListPages/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/ListPages/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/UpdatePage/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/UpdatePage/main.go index f4c4c0b64bf3..ecd8b026c8a5 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/UpdatePage/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PagesClient/UpdatePage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/CancelOperation/main.go index a66516ccbc25..2af1adca2954 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/CreatePlaybook/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/CreatePlaybook/main.go index 36292e1043e6..b25f47be4218 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/CreatePlaybook/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/CreatePlaybook/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/CreatePlaybookVersion/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/CreatePlaybookVersion/main.go index ce0a041690da..84c0fda38e63 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/CreatePlaybookVersion/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/CreatePlaybookVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/DeletePlaybook/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/DeletePlaybook/main.go index e9b26eb185d6..ef9f58b7e7d4 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/DeletePlaybook/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/DeletePlaybook/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/DeletePlaybookVersion/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/DeletePlaybookVersion/main.go index 42e2cf476d00..6099af12790a 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/DeletePlaybookVersion/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/DeletePlaybookVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/GetLocation/main.go index 3bf162b37e45..a33ed49cdd7c 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/GetOperation/main.go index 0607eefdbd17..680dac2b5773 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/GetPlaybook/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/GetPlaybook/main.go index 604c6294c60b..1a1951782056 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/GetPlaybook/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/GetPlaybook/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/GetPlaybookVersion/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/GetPlaybookVersion/main.go index 093816c825ba..a6a26bc8cb9b 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/GetPlaybookVersion/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/GetPlaybookVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/ListLocations/main.go index 31054d7d8a3c..55fb038bc9ab 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/ListOperations/main.go index 86fa74f0316b..01cf5c888527 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/ListPlaybookVersions/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/ListPlaybookVersions/main.go index 57b23990aaf9..cc6b0325f93b 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/ListPlaybookVersions/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/ListPlaybookVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/ListPlaybooks/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/ListPlaybooks/main.go index ad8322bb0a28..83c2ec0d2669 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/ListPlaybooks/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/ListPlaybooks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/UpdatePlaybook/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/UpdatePlaybook/main.go index 9bb73045421f..dc0dd81c8b9e 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/UpdatePlaybook/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/PlaybooksClient/UpdatePlaybook/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/CancelOperation/main.go index b4d8ab24fcd4..6fb2fd4aaccf 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/CreateSecuritySettings/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/CreateSecuritySettings/main.go index 691769daa6ce..e8e5c1bd5f85 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/CreateSecuritySettings/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/CreateSecuritySettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/DeleteSecuritySettings/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/DeleteSecuritySettings/main.go index a78f392fc441..e76bd3ab299c 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/DeleteSecuritySettings/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/DeleteSecuritySettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/GetLocation/main.go index 9da506f412bb..27432ece227a 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/GetOperation/main.go index 9b48384a4c5d..b6db71e3152e 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/GetSecuritySettings/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/GetSecuritySettings/main.go index f79633f414ad..b5c93012a1da 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/GetSecuritySettings/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/GetSecuritySettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/ListLocations/main.go index 309760a897be..fc0b378ed6bb 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/ListOperations/main.go index 307e26043fef..f6d406610ba9 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/ListSecuritySettings/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/ListSecuritySettings/main.go index 5fa47a4961db..7ec5b5b23a88 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/ListSecuritySettings/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/ListSecuritySettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/UpdateSecuritySettings/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/UpdateSecuritySettings/main.go index 01fb1460a07a..bf24085b25c5 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/UpdateSecuritySettings/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SecuritySettingsClient/UpdateSecuritySettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/CancelOperation/main.go index 4de223e17911..e089d37000f3 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/CreateSessionEntityType/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/CreateSessionEntityType/main.go index d153ef3b94e5..6bce6a5cb112 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/CreateSessionEntityType/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/CreateSessionEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/DeleteSessionEntityType/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/DeleteSessionEntityType/main.go index 12efb55613af..a7fd0330df79 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/DeleteSessionEntityType/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/DeleteSessionEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/GetLocation/main.go index f7e900c035f7..987c13030bc1 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/GetOperation/main.go index d144f32b30c4..4101a672eb49 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/GetSessionEntityType/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/GetSessionEntityType/main.go index f96fafda936f..d4343afeb056 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/GetSessionEntityType/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/GetSessionEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/ListLocations/main.go index 98359ca42f39..bf1498fee61e 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/ListOperations/main.go index ed65bab8edd2..2c8d8bbe0286 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/ListSessionEntityTypes/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/ListSessionEntityTypes/main.go index 72882f5e5206..3ff9f7303ca1 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/ListSessionEntityTypes/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/ListSessionEntityTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/UpdateSessionEntityType/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/UpdateSessionEntityType/main.go index 97ad53d48a23..dca8ef22a73a 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/UpdateSessionEntityType/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionEntityTypesClient/UpdateSessionEntityType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/CancelOperation/main.go index 926bd7f4a2b4..b4baefba3899 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/DetectIntent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/DetectIntent/main.go index 3fde067a7b07..5ca57a2045f5 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/DetectIntent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/DetectIntent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/FulfillIntent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/FulfillIntent/main.go index 6a2f10070390..a36bf390a2a7 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/FulfillIntent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/FulfillIntent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/GetLocation/main.go index 86240d931afa..9e51c05a95b8 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/GetOperation/main.go index 9e8c9ac2fad7..26e8a5a9dbc0 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/ListLocations/main.go index 1a10606b9cee..4bab9a4349f2 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/ListOperations/main.go index 0f850e94895d..80eae9f574c8 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/MatchIntent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/MatchIntent/main.go index a132ed129e63..b9426292fe66 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/MatchIntent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/MatchIntent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/StreamingDetectIntent/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/StreamingDetectIntent/main.go index 0d85e8ec3085..20f827b38115 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/StreamingDetectIntent/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/StreamingDetectIntent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/SubmitAnswerFeedback/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/SubmitAnswerFeedback/main.go index 3094b26c6449..b0b03d1dd7b8 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/SubmitAnswerFeedback/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/SessionsClient/SubmitAnswerFeedback/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/BatchDeleteTestCases/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/BatchDeleteTestCases/main.go index 4532ba77a134..bdeaa8d1172e 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/BatchDeleteTestCases/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/BatchDeleteTestCases/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/BatchRunTestCases/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/BatchRunTestCases/main.go index e8ef5fa41523..e39f4bf24215 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/BatchRunTestCases/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/BatchRunTestCases/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/CalculateCoverage/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/CalculateCoverage/main.go index 466feb7091e5..c674feaddc22 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/CalculateCoverage/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/CalculateCoverage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/CancelOperation/main.go index 012ba34cbdd5..c911e7bf3ca0 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/CreateTestCase/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/CreateTestCase/main.go index 995709dd495f..07b5d545b9b7 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/CreateTestCase/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/CreateTestCase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/ExportTestCases/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/ExportTestCases/main.go index 9887e47aefb0..86efc03f9e2e 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/ExportTestCases/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/ExportTestCases/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/GetLocation/main.go index 1a17002f0f0f..1c3af38d7493 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/GetOperation/main.go index bce6ef006f57..42cc729384e3 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/GetTestCase/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/GetTestCase/main.go index e9841fc2e8bd..9cf27fb70d27 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/GetTestCase/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/GetTestCase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/GetTestCaseResult/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/GetTestCaseResult/main.go index 694c93306e2f..376e00fa4edc 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/GetTestCaseResult/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/GetTestCaseResult/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/ImportTestCases/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/ImportTestCases/main.go index 288b5b8cc27a..c947bdb939d4 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/ImportTestCases/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/ImportTestCases/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/ListLocations/main.go index e2040de36ce9..ca9487481f13 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/ListOperations/main.go index b12c4ecf298d..ef9d02caf4d8 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/ListTestCaseResults/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/ListTestCaseResults/main.go index 0246070d1322..b9cefa9ad9a2 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/ListTestCaseResults/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/ListTestCaseResults/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/ListTestCases/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/ListTestCases/main.go index 7e89824e62ca..615f58ed2ab3 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/ListTestCases/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/ListTestCases/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/RunTestCase/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/RunTestCase/main.go index 3e912bbf67b4..16e8e7e1513c 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/RunTestCase/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/RunTestCase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/UpdateTestCase/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/UpdateTestCase/main.go index 71471ce1f039..f8a1883909b4 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/UpdateTestCase/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TestCasesClient/UpdateTestCase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/CancelOperation/main.go index c3b52756cbda..b06d83ba6cff 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/CreateTool/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/CreateTool/main.go index 0549af2de73b..3e9050f011b8 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/CreateTool/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/CreateTool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/DeleteTool/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/DeleteTool/main.go index 84c32d2b50e2..1717f2d3ea9f 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/DeleteTool/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/DeleteTool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/ExportTools/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/ExportTools/main.go index 084e6e76c012..4d1108376de0 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/ExportTools/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/ExportTools/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/GetLocation/main.go index 290940252003..230b9291c11b 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/GetOperation/main.go index c32d0743edc6..1c4e5a5e3aee 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/GetTool/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/GetTool/main.go index a90b633d0b0b..01286ccb73c6 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/GetTool/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/GetTool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/ListLocations/main.go index d82251df7a23..e9075980fbc7 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/ListOperations/main.go index a1c857a9a4cd..c0155c4d5b5d 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/ListTools/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/ListTools/main.go index 980a29132c4d..bd537843a01d 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/ListTools/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/ListTools/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/UpdateTool/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/UpdateTool/main.go index e6ce053efbae..92c53b4a960b 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/UpdateTool/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/ToolsClient/UpdateTool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/CancelOperation/main.go index 12a2610ff8a0..3ed7b885af13 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/CreateTransitionRouteGroup/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/CreateTransitionRouteGroup/main.go index 623ea94bef9f..01e580a1b936 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/CreateTransitionRouteGroup/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/CreateTransitionRouteGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/DeleteTransitionRouteGroup/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/DeleteTransitionRouteGroup/main.go index 29345a0f789a..66c1cec131db 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/DeleteTransitionRouteGroup/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/DeleteTransitionRouteGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/GetLocation/main.go index 18e028437a55..0f3238535304 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/GetOperation/main.go index de5323087a1e..43937487b4bf 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/GetTransitionRouteGroup/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/GetTransitionRouteGroup/main.go index 34164afdd705..4f14a5791549 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/GetTransitionRouteGroup/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/GetTransitionRouteGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/ListLocations/main.go index f121e640f46f..d102bebeb75f 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/ListOperations/main.go index 78b8a59b1a9f..709bd38513fc 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/ListTransitionRouteGroups/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/ListTransitionRouteGroups/main.go index beeed588e072..05ca74604c7f 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/ListTransitionRouteGroups/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/ListTransitionRouteGroups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/UpdateTransitionRouteGroup/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/UpdateTransitionRouteGroup/main.go index 6b0467c21758..89dad40c6d1b 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/UpdateTransitionRouteGroup/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/TransitionRouteGroupsClient/UpdateTransitionRouteGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/CancelOperation/main.go index 47d299dcbf1c..9bc012efaa8f 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/CompareVersions/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/CompareVersions/main.go index c6717a62f81a..35fa5398a657 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/CompareVersions/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/CompareVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/CreateVersion/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/CreateVersion/main.go index 032c53b63593..1eb25f2c5251 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/CreateVersion/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/CreateVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/DeleteVersion/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/DeleteVersion/main.go index cccbb9e91655..26586ba75077 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/DeleteVersion/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/DeleteVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/GetLocation/main.go index 8f05a8e4d5da..22c0908eb7b4 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/GetOperation/main.go index 430cc734981c..9f208f027207 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/GetVersion/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/GetVersion/main.go index c01e295e29d3..ca69bc5aa909 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/GetVersion/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/GetVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/ListLocations/main.go index 25d35140e08c..330d8bf57ca8 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/ListOperations/main.go index 8131f348b8c7..86a033d902a7 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/ListVersions/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/ListVersions/main.go index 95a5d1b3797d..575ae63b1b56 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/ListVersions/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/ListVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/LoadVersion/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/LoadVersion/main.go index 39171897f5ce..833dc176f840 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/LoadVersion/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/LoadVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/UpdateVersion/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/UpdateVersion/main.go index ca44dae9d64a..9157eabdb425 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/UpdateVersion/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/VersionsClient/UpdateVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/CancelOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/CancelOperation/main.go index 01f042a5e401..f1dfe1152721 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/CancelOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/CreateWebhook/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/CreateWebhook/main.go index 7248e0e7e803..84ea548f95ad 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/CreateWebhook/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/CreateWebhook/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/DeleteWebhook/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/DeleteWebhook/main.go index 39019cbab3d4..645a5aea0906 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/DeleteWebhook/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/DeleteWebhook/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/GetLocation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/GetLocation/main.go index c3240b7d6acc..c8cd3fe3ec54 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/GetLocation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/GetOperation/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/GetOperation/main.go index ff592209999a..36a072a6cfeb 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/GetOperation/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/GetWebhook/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/GetWebhook/main.go index 15accaa48b1e..52a12bbf73f1 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/GetWebhook/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/GetWebhook/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/ListLocations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/ListLocations/main.go index a79a1363a4ef..65644dc3b317 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/ListLocations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/ListOperations/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/ListOperations/main.go index 4fa8f8b025e4..9c47e93fb4e7 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/ListOperations/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/ListWebhooks/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/ListWebhooks/main.go index d775f1e13227..0481be25fa00 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/ListWebhooks/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/ListWebhooks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/UpdateWebhook/main.go b/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/UpdateWebhook/main.go index 1659b46f30a9..e54e18d09639 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/UpdateWebhook/main.go +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/WebhooksClient/UpdateWebhook/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dialogflow/cx/apiv3beta1/snippet_metadata.google.cloud.dialogflow.cx.v3beta1.json b/internal/generated/snippets/dialogflow/cx/apiv3beta1/snippet_metadata.google.cloud.dialogflow.cx.v3beta1.json index e855836fd71f..3e48ef7c85e5 100644 --- a/internal/generated/snippets/dialogflow/cx/apiv3beta1/snippet_metadata.google.cloud.dialogflow.cx.v3beta1.json +++ b/internal/generated/snippets/dialogflow/cx/apiv3beta1/snippet_metadata.google.cloud.dialogflow.cx.v3beta1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/dialogflow/cx/apiv3beta1", - "version": "1.64.0", + "version": "1.64.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/CancelOperation/main.go index 40ababb2fa57..478bcf703e2b 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/CompleteQuery/main.go b/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/CompleteQuery/main.go index 3d8467cebb1c..b43c2a0a2b6e 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/CompleteQuery/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/CompleteQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/GetOperation/main.go index 091eedf50736..6426cc8aa690 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/ImportCompletionSuggestions/main.go b/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/ImportCompletionSuggestions/main.go index f911794827c1..8493c33257c0 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/ImportCompletionSuggestions/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/ImportCompletionSuggestions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/ImportSuggestionDenyListEntries/main.go b/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/ImportSuggestionDenyListEntries/main.go index 5717f2de4734..09fae59aaba4 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/ImportSuggestionDenyListEntries/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/ImportSuggestionDenyListEntries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/ListOperations/main.go index 053e77bf0d78..0119c435bd3e 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/PurgeCompletionSuggestions/main.go b/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/PurgeCompletionSuggestions/main.go index 0da3ea6c8dfb..356fba7b1021 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/PurgeCompletionSuggestions/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/PurgeCompletionSuggestions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/PurgeSuggestionDenyListEntries/main.go b/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/PurgeSuggestionDenyListEntries/main.go index 6f00212f1e7a..bfa35d5559d0 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/PurgeSuggestionDenyListEntries/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/CompletionClient/PurgeSuggestionDenyListEntries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/ControlClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/ControlClient/CancelOperation/main.go index 24b61697534f..a9c01b3e20fe 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/ControlClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/ControlClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/ControlClient/CreateControl/main.go b/internal/generated/snippets/discoveryengine/apiv1/ControlClient/CreateControl/main.go index e1dbfa3b7e27..fcc9611ee21d 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/ControlClient/CreateControl/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/ControlClient/CreateControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/ControlClient/DeleteControl/main.go b/internal/generated/snippets/discoveryengine/apiv1/ControlClient/DeleteControl/main.go index 11d75e063d07..6da338ef0d6b 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/ControlClient/DeleteControl/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/ControlClient/DeleteControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/ControlClient/GetControl/main.go b/internal/generated/snippets/discoveryengine/apiv1/ControlClient/GetControl/main.go index 106b67450259..f72112b29e88 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/ControlClient/GetControl/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/ControlClient/GetControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/ControlClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/ControlClient/GetOperation/main.go index 94550ccc93bf..93e48b8de93a 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/ControlClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/ControlClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/ControlClient/ListControls/main.go b/internal/generated/snippets/discoveryengine/apiv1/ControlClient/ListControls/main.go index ca1578820b33..2f632221ffde 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/ControlClient/ListControls/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/ControlClient/ListControls/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/ControlClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1/ControlClient/ListOperations/main.go index b3118be7ca81..b6c7fc7e65ca 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/ControlClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/ControlClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/ControlClient/UpdateControl/main.go b/internal/generated/snippets/discoveryengine/apiv1/ControlClient/UpdateControl/main.go index d6c5ee0dc856..37b1c9137675 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/ControlClient/UpdateControl/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/ControlClient/UpdateControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/AnswerQuery/main.go b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/AnswerQuery/main.go index 0d03d3721562..8b1c032d856c 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/AnswerQuery/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/AnswerQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/CancelOperation/main.go index 39ccfc60a2dd..8ce179927c01 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/ConverseConversation/main.go b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/ConverseConversation/main.go index 9f76e1045bab..1fa8ac6c464d 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/ConverseConversation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/ConverseConversation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/CreateConversation/main.go b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/CreateConversation/main.go index d48e709bbf89..dfe00dec75d8 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/CreateConversation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/CreateConversation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/CreateSession/main.go b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/CreateSession/main.go index d127696460b7..fc2a9382e7b1 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/CreateSession/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/CreateSession/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/DeleteConversation/main.go b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/DeleteConversation/main.go index e95df7325b97..dbf350b78854 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/DeleteConversation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/DeleteConversation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/DeleteSession/main.go b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/DeleteSession/main.go index 7187a123d131..0a88e74a1c68 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/DeleteSession/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/DeleteSession/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/GetAnswer/main.go b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/GetAnswer/main.go index e0d30b69960c..b2e90ab0ebca 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/GetAnswer/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/GetAnswer/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/GetConversation/main.go b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/GetConversation/main.go index 623dbcf21249..980812b93f17 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/GetConversation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/GetConversation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/GetOperation/main.go index 01d55ddfb7bf..eb688ae44476 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/GetSession/main.go b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/GetSession/main.go index d03274a40bbc..c0ea460af895 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/GetSession/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/GetSession/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/ListConversations/main.go b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/ListConversations/main.go index e59cbb14957b..97e39478c3f2 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/ListConversations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/ListConversations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/ListOperations/main.go index 896a85d3a62a..e9d7bc365139 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/ListSessions/main.go b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/ListSessions/main.go index 20fe48cce213..020b4b14413a 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/ListSessions/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/ListSessions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/UpdateConversation/main.go b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/UpdateConversation/main.go index 5d7e58dfd234..fc8f4efde09b 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/UpdateConversation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/UpdateConversation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/UpdateSession/main.go b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/UpdateSession/main.go index c50a0b71c330..dace5722b290 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/UpdateSession/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/ConversationalSearchClient/UpdateSession/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/CancelOperation/main.go index 77a4d6b4ce3a..470bc62eb59b 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/CreateDataStore/main.go b/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/CreateDataStore/main.go index e7e83c6a929e..1a7ac66ce96d 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/CreateDataStore/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/CreateDataStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/DeleteDataStore/main.go b/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/DeleteDataStore/main.go index 13e3d4a4579b..b0960b703076 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/DeleteDataStore/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/DeleteDataStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/GetDataStore/main.go b/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/GetDataStore/main.go index 4ab62c34f970..57771830b2e7 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/GetDataStore/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/GetDataStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/GetOperation/main.go index ab956020be1a..b7d82073ffc3 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/ListDataStores/main.go b/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/ListDataStores/main.go index 80785e19dd04..743b9816b83f 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/ListDataStores/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/ListDataStores/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/ListOperations/main.go index 04a4c4184a5b..e4bfb8a8a87c 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/UpdateDataStore/main.go b/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/UpdateDataStore/main.go index e9a058fe3f27..a6a369e21904 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/UpdateDataStore/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/DataStoreClient/UpdateDataStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/BatchGetDocumentsMetadata/main.go b/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/BatchGetDocumentsMetadata/main.go index 438fb5f25846..bfd34d6bb61f 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/BatchGetDocumentsMetadata/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/BatchGetDocumentsMetadata/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/CancelOperation/main.go index acb38e613794..99c6298db469 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/CreateDocument/main.go b/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/CreateDocument/main.go index 0d63d7266558..75bf31ff907d 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/CreateDocument/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/CreateDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/DeleteDocument/main.go b/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/DeleteDocument/main.go index 9c7d17bfe66d..0652010964ac 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/DeleteDocument/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/DeleteDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/GetDocument/main.go b/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/GetDocument/main.go index 287c119c530a..e4f4de071ef0 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/GetDocument/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/GetDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/GetOperation/main.go index d4f888f40e5e..248dd392aa01 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/ImportDocuments/main.go b/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/ImportDocuments/main.go index a9a67283208c..b957a6bd07f1 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/ImportDocuments/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/ImportDocuments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/ListDocuments/main.go b/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/ListDocuments/main.go index f3b58f946721..7138782bdafc 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/ListDocuments/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/ListDocuments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/ListOperations/main.go index e0b85e807c22..5c791d79de31 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/PurgeDocuments/main.go b/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/PurgeDocuments/main.go index 524ed1bfa3bf..ee7bfac77e6d 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/PurgeDocuments/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/PurgeDocuments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/UpdateDocument/main.go b/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/UpdateDocument/main.go index 215e2f591ac9..02cdae95777c 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/UpdateDocument/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/DocumentClient/UpdateDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/EngineClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/EngineClient/CancelOperation/main.go index 080f2e5cf698..9cc935f09acc 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/EngineClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/EngineClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/EngineClient/CreateEngine/main.go b/internal/generated/snippets/discoveryengine/apiv1/EngineClient/CreateEngine/main.go index c2c7f00bbf8b..833b0929387c 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/EngineClient/CreateEngine/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/EngineClient/CreateEngine/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/EngineClient/DeleteEngine/main.go b/internal/generated/snippets/discoveryengine/apiv1/EngineClient/DeleteEngine/main.go index f9de5e32e6df..a20c9ae3666e 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/EngineClient/DeleteEngine/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/EngineClient/DeleteEngine/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/EngineClient/GetEngine/main.go b/internal/generated/snippets/discoveryengine/apiv1/EngineClient/GetEngine/main.go index 243e052bb01d..9fd74064a150 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/EngineClient/GetEngine/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/EngineClient/GetEngine/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/EngineClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/EngineClient/GetOperation/main.go index 6d94ed306d8c..ec2158cb2e78 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/EngineClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/EngineClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/EngineClient/ListEngines/main.go b/internal/generated/snippets/discoveryengine/apiv1/EngineClient/ListEngines/main.go index d251b9a4b441..f9a5d697efce 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/EngineClient/ListEngines/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/EngineClient/ListEngines/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/EngineClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1/EngineClient/ListOperations/main.go index 4463734efb70..8d8ecb024756 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/EngineClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/EngineClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/EngineClient/UpdateEngine/main.go b/internal/generated/snippets/discoveryengine/apiv1/EngineClient/UpdateEngine/main.go index d6490fafe85e..0ddab69adc5c 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/EngineClient/UpdateEngine/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/EngineClient/UpdateEngine/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/GroundedGenerationClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/GroundedGenerationClient/CancelOperation/main.go index 64a0edc79ff8..e214f8bc7599 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/GroundedGenerationClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/GroundedGenerationClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/GroundedGenerationClient/CheckGrounding/main.go b/internal/generated/snippets/discoveryengine/apiv1/GroundedGenerationClient/CheckGrounding/main.go index 5cb521559274..38bcabcb49c2 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/GroundedGenerationClient/CheckGrounding/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/GroundedGenerationClient/CheckGrounding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/GroundedGenerationClient/GenerateGroundedContent/main.go b/internal/generated/snippets/discoveryengine/apiv1/GroundedGenerationClient/GenerateGroundedContent/main.go index 6af02760dd84..be2c706bee37 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/GroundedGenerationClient/GenerateGroundedContent/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/GroundedGenerationClient/GenerateGroundedContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/GroundedGenerationClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/GroundedGenerationClient/GetOperation/main.go index 24e2f8be8759..3e67572cef31 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/GroundedGenerationClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/GroundedGenerationClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/GroundedGenerationClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1/GroundedGenerationClient/ListOperations/main.go index 9fc266f6e4c3..1bf80711b68f 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/GroundedGenerationClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/GroundedGenerationClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/GroundedGenerationClient/StreamGenerateGroundedContent/main.go b/internal/generated/snippets/discoveryengine/apiv1/GroundedGenerationClient/StreamGenerateGroundedContent/main.go index 806c8bcaeb83..6198e2da14a2 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/GroundedGenerationClient/StreamGenerateGroundedContent/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/GroundedGenerationClient/StreamGenerateGroundedContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/ProjectClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/ProjectClient/CancelOperation/main.go index c4881a809cbf..46eaac57fd30 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/ProjectClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/ProjectClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/ProjectClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/ProjectClient/GetOperation/main.go index 27383170b87b..9d7df5be730a 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/ProjectClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/ProjectClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/ProjectClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1/ProjectClient/ListOperations/main.go index 71dfeee667da..b9bbb87f57d4 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/ProjectClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/ProjectClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/ProjectClient/ProvisionProject/main.go b/internal/generated/snippets/discoveryengine/apiv1/ProjectClient/ProvisionProject/main.go index 470f5dd3ac22..985b60daeba7 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/ProjectClient/ProvisionProject/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/ProjectClient/ProvisionProject/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/RankClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/RankClient/CancelOperation/main.go index a04c8cd7d019..00be04800a16 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/RankClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/RankClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/RankClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/RankClient/GetOperation/main.go index fb6277f220a8..d255b96d587e 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/RankClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/RankClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/RankClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1/RankClient/ListOperations/main.go index 622be742cbc1..bf6f82f6dae9 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/RankClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/RankClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/RankClient/Rank/main.go b/internal/generated/snippets/discoveryengine/apiv1/RankClient/Rank/main.go index 0dbb09cda7b2..d15fb5cb33bc 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/RankClient/Rank/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/RankClient/Rank/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/RecommendationClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/RecommendationClient/CancelOperation/main.go index 7ca190f3480b..7236755a5e2d 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/RecommendationClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/RecommendationClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/RecommendationClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/RecommendationClient/GetOperation/main.go index dcaf6940ef78..a42bb966dc7b 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/RecommendationClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/RecommendationClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/RecommendationClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1/RecommendationClient/ListOperations/main.go index a05afe4ba36f..8d338b646c7e 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/RecommendationClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/RecommendationClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/RecommendationClient/Recommend/main.go b/internal/generated/snippets/discoveryengine/apiv1/RecommendationClient/Recommend/main.go index f965a1d0552b..4b050a132bd4 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/RecommendationClient/Recommend/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/RecommendationClient/Recommend/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/CancelOperation/main.go index 8a670ccf301a..7cc744efd925 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/CreateSchema/main.go b/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/CreateSchema/main.go index dd258bd769e8..4a1b809236d4 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/CreateSchema/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/CreateSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/DeleteSchema/main.go b/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/DeleteSchema/main.go index 3ed8053525dd..7784e1e4cf5a 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/DeleteSchema/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/DeleteSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/GetOperation/main.go index 44d6edeedb36..1b63a07a64db 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/GetSchema/main.go b/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/GetSchema/main.go index a9a3df000856..b31951f8482c 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/GetSchema/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/GetSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/ListOperations/main.go index d739ad87e643..1e2eb5686e3f 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/ListSchemas/main.go b/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/ListSchemas/main.go index ae421e1dda9a..8e5f429d0c1b 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/ListSchemas/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/ListSchemas/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/UpdateSchema/main.go b/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/UpdateSchema/main.go index 82d4fda15611..941b5c2134f1 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/UpdateSchema/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SchemaClient/UpdateSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SearchClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/SearchClient/CancelOperation/main.go index 01a09c4ef17b..1420720c9c77 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SearchClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SearchClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SearchClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/SearchClient/GetOperation/main.go index 52e1c63485b5..1e8ce8a304d1 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SearchClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SearchClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SearchClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1/SearchClient/ListOperations/main.go index 3e244375f224..14ae6130fc06 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SearchClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SearchClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SearchClient/Search/main.go b/internal/generated/snippets/discoveryengine/apiv1/SearchClient/Search/main.go index f77017abc35c..b31f2c987cb0 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SearchClient/Search/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SearchClient/Search/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SearchClient/SearchLite/main.go b/internal/generated/snippets/discoveryengine/apiv1/SearchClient/SearchLite/main.go index 734cac4fc270..cdc9302a7589 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SearchClient/SearchLite/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SearchClient/SearchLite/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SearchTuningClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/SearchTuningClient/CancelOperation/main.go index f475bdd73d53..39a59be2c766 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SearchTuningClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SearchTuningClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SearchTuningClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/SearchTuningClient/GetOperation/main.go index 26b6ac64306f..96808e066f08 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SearchTuningClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SearchTuningClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SearchTuningClient/ListCustomModels/main.go b/internal/generated/snippets/discoveryengine/apiv1/SearchTuningClient/ListCustomModels/main.go index 82cd33b62108..0e1c546e9e06 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SearchTuningClient/ListCustomModels/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SearchTuningClient/ListCustomModels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SearchTuningClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1/SearchTuningClient/ListOperations/main.go index 551dda0bdc0f..4f041fc90214 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SearchTuningClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SearchTuningClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SearchTuningClient/TrainCustomModel/main.go b/internal/generated/snippets/discoveryengine/apiv1/SearchTuningClient/TrainCustomModel/main.go index 302b874b29ef..30fbdea81e01 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SearchTuningClient/TrainCustomModel/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SearchTuningClient/TrainCustomModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/BatchCreateTargetSites/main.go b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/BatchCreateTargetSites/main.go index 28b792538404..e0ed14b19872 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/BatchCreateTargetSites/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/BatchCreateTargetSites/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/BatchVerifyTargetSites/main.go b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/BatchVerifyTargetSites/main.go index c4dba9e0fa7b..ad194a508e37 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/BatchVerifyTargetSites/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/BatchVerifyTargetSites/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/CancelOperation/main.go index fc60b5319d02..cbc0ece0059a 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/CreateTargetSite/main.go b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/CreateTargetSite/main.go index 398e75d31863..a5449b398184 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/CreateTargetSite/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/CreateTargetSite/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/DeleteTargetSite/main.go b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/DeleteTargetSite/main.go index 65d48f7477fe..49a3a0806eb7 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/DeleteTargetSite/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/DeleteTargetSite/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/DisableAdvancedSiteSearch/main.go b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/DisableAdvancedSiteSearch/main.go index 67ab9fdc3d3a..fdf1aef75a2a 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/DisableAdvancedSiteSearch/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/DisableAdvancedSiteSearch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/EnableAdvancedSiteSearch/main.go b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/EnableAdvancedSiteSearch/main.go index 56f534da0db9..69f945265671 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/EnableAdvancedSiteSearch/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/EnableAdvancedSiteSearch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/FetchDomainVerificationStatus/main.go b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/FetchDomainVerificationStatus/main.go index 410a95373664..5f1de52ceb8c 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/FetchDomainVerificationStatus/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/FetchDomainVerificationStatus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/GetOperation/main.go index 90321eef4a48..4e26d3d5556f 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/GetSiteSearchEngine/main.go b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/GetSiteSearchEngine/main.go index 9fe78d8f89e1..3cb54452f172 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/GetSiteSearchEngine/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/GetSiteSearchEngine/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/GetTargetSite/main.go b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/GetTargetSite/main.go index 520f6ab12e6d..665dddabf537 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/GetTargetSite/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/GetTargetSite/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/ListOperations/main.go index 691ccc837243..4cde5a33c7c7 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/ListTargetSites/main.go b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/ListTargetSites/main.go index 588272a511f7..a417a6017ee1 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/ListTargetSites/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/ListTargetSites/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/RecrawlUris/main.go b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/RecrawlUris/main.go index c3bcef27fd7e..fe58d69913b2 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/RecrawlUris/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/RecrawlUris/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/UpdateTargetSite/main.go b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/UpdateTargetSite/main.go index 644693e61b97..cdbc71ef8a45 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/UpdateTargetSite/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/SiteSearchEngineClient/UpdateTargetSite/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/UserEventClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/UserEventClient/CancelOperation/main.go index 4e53c475070c..eed21da2b338 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/UserEventClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/UserEventClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/UserEventClient/CollectUserEvent/main.go b/internal/generated/snippets/discoveryengine/apiv1/UserEventClient/CollectUserEvent/main.go index 72d35518290d..10017d2e083a 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/UserEventClient/CollectUserEvent/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/UserEventClient/CollectUserEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/UserEventClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1/UserEventClient/GetOperation/main.go index f64ca526e946..85007287a4ef 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/UserEventClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/UserEventClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/UserEventClient/ImportUserEvents/main.go b/internal/generated/snippets/discoveryengine/apiv1/UserEventClient/ImportUserEvents/main.go index 2c8d22079be4..93dda9b55451 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/UserEventClient/ImportUserEvents/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/UserEventClient/ImportUserEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/UserEventClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1/UserEventClient/ListOperations/main.go index c9507330bb47..4c7cd2b735d2 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/UserEventClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/UserEventClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/UserEventClient/PurgeUserEvents/main.go b/internal/generated/snippets/discoveryengine/apiv1/UserEventClient/PurgeUserEvents/main.go index 5c0af49d176a..56b37f7c871b 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/UserEventClient/PurgeUserEvents/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/UserEventClient/PurgeUserEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/UserEventClient/WriteUserEvent/main.go b/internal/generated/snippets/discoveryengine/apiv1/UserEventClient/WriteUserEvent/main.go index d369b9bcec3f..8cf029984c08 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/UserEventClient/WriteUserEvent/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1/UserEventClient/WriteUserEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1/snippet_metadata.google.cloud.discoveryengine.v1.json b/internal/generated/snippets/discoveryengine/apiv1/snippet_metadata.google.cloud.discoveryengine.v1.json index 21e8560cf187..f11ea646867e 100644 --- a/internal/generated/snippets/discoveryengine/apiv1/snippet_metadata.google.cloud.discoveryengine.v1.json +++ b/internal/generated/snippets/discoveryengine/apiv1/snippet_metadata.google.cloud.discoveryengine.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/discoveryengine/apiv1", - "version": "1.16.0", + "version": "1.16.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/AclConfigClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/AclConfigClient/CancelOperation/main.go index c6b7a4678472..2cde01e46886 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/AclConfigClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/AclConfigClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/AclConfigClient/GetAclConfig/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/AclConfigClient/GetAclConfig/main.go index 224d0ffa3ce0..cebaac206236 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/AclConfigClient/GetAclConfig/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/AclConfigClient/GetAclConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/AclConfigClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/AclConfigClient/GetOperation/main.go index eb5485cdb2df..0c26ce176904 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/AclConfigClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/AclConfigClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/AclConfigClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/AclConfigClient/ListOperations/main.go index c35d5e6d7e50..810ed0828627 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/AclConfigClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/AclConfigClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/AclConfigClient/UpdateAclConfig/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/AclConfigClient/UpdateAclConfig/main.go index 0cdeb82403fd..eb4a4bd81eb4 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/AclConfigClient/UpdateAclConfig/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/AclConfigClient/UpdateAclConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ChunkClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ChunkClient/CancelOperation/main.go index d8552ed3fb47..00103eb47758 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ChunkClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ChunkClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ChunkClient/GetChunk/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ChunkClient/GetChunk/main.go index f46b915d24ab..0b657c8068db 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ChunkClient/GetChunk/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ChunkClient/GetChunk/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ChunkClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ChunkClient/GetOperation/main.go index 0e06c507598c..7edbff6b742c 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ChunkClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ChunkClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ChunkClient/ListChunks/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ChunkClient/ListChunks/main.go index 0211e4ea8b58..62227325e155 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ChunkClient/ListChunks/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ChunkClient/ListChunks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ChunkClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ChunkClient/ListOperations/main.go index d4356e15aecc..bd73c1af3119 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ChunkClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ChunkClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/CancelOperation/main.go index c1ecbe413950..dce2903f0028 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/CompleteQuery/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/CompleteQuery/main.go index 5076ebcd6e04..59edb0673575 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/CompleteQuery/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/CompleteQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/GetOperation/main.go index 829a5710a8fc..a23db2f2c5ef 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/ImportCompletionSuggestions/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/ImportCompletionSuggestions/main.go index 8dc009babfd1..2861c281380b 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/ImportCompletionSuggestions/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/ImportCompletionSuggestions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/ImportSuggestionDenyListEntries/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/ImportSuggestionDenyListEntries/main.go index 86053768fe0d..2a7867543387 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/ImportSuggestionDenyListEntries/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/ImportSuggestionDenyListEntries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/ListOperations/main.go index 43911d0280e9..dd09bcdae06e 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/PurgeCompletionSuggestions/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/PurgeCompletionSuggestions/main.go index c843af1ce151..066673d36fdd 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/PurgeCompletionSuggestions/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/PurgeCompletionSuggestions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/PurgeSuggestionDenyListEntries/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/PurgeSuggestionDenyListEntries/main.go index 8921c7f75458..76f719902980 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/PurgeSuggestionDenyListEntries/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/CompletionClient/PurgeSuggestionDenyListEntries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/CancelOperation/main.go index 6727fa7e8064..2e367ca8a982 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/CreateControl/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/CreateControl/main.go index 0467dce0a5f6..612eacb5b66c 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/CreateControl/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/CreateControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/DeleteControl/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/DeleteControl/main.go index f30e4a844328..ea14647f95e2 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/DeleteControl/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/DeleteControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/GetControl/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/GetControl/main.go index c5f03cb1a6e3..c669dd651e18 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/GetControl/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/GetControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/GetOperation/main.go index fdd7dc1dc325..cacdad6beef8 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/ListControls/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/ListControls/main.go index 287ff8bcb196..5b259f58858b 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/ListControls/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/ListControls/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/ListOperations/main.go index 458888f401e7..d627488387a6 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/UpdateControl/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/UpdateControl/main.go index b8b2f3c1d519..0bd3df239e78 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/UpdateControl/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ControlClient/UpdateControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/AnswerQuery/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/AnswerQuery/main.go index 050db71b3943..1588d62fa6c6 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/AnswerQuery/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/AnswerQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/CancelOperation/main.go index 3b0baae2ac23..5744cbaf0e86 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/ConverseConversation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/ConverseConversation/main.go index f706080113da..3c7712874d9d 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/ConverseConversation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/ConverseConversation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/CreateConversation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/CreateConversation/main.go index 1f923f7de439..740d9ba14293 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/CreateConversation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/CreateConversation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/CreateSession/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/CreateSession/main.go index 4bd37a762566..257e3072ddc3 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/CreateSession/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/CreateSession/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/DeleteConversation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/DeleteConversation/main.go index 68235b124ebf..8568fe79b918 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/DeleteConversation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/DeleteConversation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/DeleteSession/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/DeleteSession/main.go index 1dee094ee981..cfbe2fc1e11a 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/DeleteSession/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/DeleteSession/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/GetAnswer/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/GetAnswer/main.go index a13c5ba3f7ae..4a5741b3d146 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/GetAnswer/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/GetAnswer/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/GetConversation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/GetConversation/main.go index 20aeaf9ec7a0..75f72abbd68d 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/GetConversation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/GetConversation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/GetOperation/main.go index 4b39639d645d..23e31d04048e 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/GetSession/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/GetSession/main.go index ef7047146153..fac9c217cd75 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/GetSession/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/GetSession/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/ListConversations/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/ListConversations/main.go index 2dc46351a6e5..af1adf2091f1 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/ListConversations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/ListConversations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/ListOperations/main.go index 0f354c4a5393..736511b854b6 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/ListSessions/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/ListSessions/main.go index 1dd21a1ced43..dc6185aa7cf4 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/ListSessions/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/ListSessions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/UpdateConversation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/UpdateConversation/main.go index f5f55e4ff948..5cf872e7fba7 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/UpdateConversation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/UpdateConversation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/UpdateSession/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/UpdateSession/main.go index bdeffaaf47b0..b4fe1c9f4cc8 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/UpdateSession/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ConversationalSearchClient/UpdateSession/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/CancelOperation/main.go index 07495169e765..b1a9400a75cd 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/CreateDataStore/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/CreateDataStore/main.go index dfb09b73dcb9..ec849856b463 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/CreateDataStore/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/CreateDataStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/DeleteDataStore/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/DeleteDataStore/main.go index b17055b4bc43..a786c4b6971d 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/DeleteDataStore/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/DeleteDataStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/GetDataStore/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/GetDataStore/main.go index a343f8cbcd7e..a3011bd1a4ab 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/GetDataStore/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/GetDataStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/GetDocumentProcessingConfig/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/GetDocumentProcessingConfig/main.go index 7e3e2a3fd53a..c0dcf47f30ed 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/GetDocumentProcessingConfig/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/GetDocumentProcessingConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/GetOperation/main.go index 58ac8ae6dccf..92cf8de72a16 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/ListDataStores/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/ListDataStores/main.go index 5197ec1f0cb6..e32ae7140fc3 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/ListDataStores/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/ListDataStores/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/ListOperations/main.go index 995b1b770c10..4726b06dce72 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/UpdateDataStore/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/UpdateDataStore/main.go index e56e03f96961..65a096bdbd9e 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/UpdateDataStore/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/UpdateDataStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/UpdateDocumentProcessingConfig/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/UpdateDocumentProcessingConfig/main.go index 01706f830fc3..8eda85319aa3 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/UpdateDocumentProcessingConfig/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/DataStoreClient/UpdateDocumentProcessingConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/BatchGetDocumentsMetadata/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/BatchGetDocumentsMetadata/main.go index 29f3bbb51a6b..f1621ec9ffb0 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/BatchGetDocumentsMetadata/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/BatchGetDocumentsMetadata/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/CancelOperation/main.go index a8e0151d04d1..79e8a5a92c2f 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/CreateDocument/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/CreateDocument/main.go index 5fbc5891c565..0adf3bedd21b 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/CreateDocument/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/CreateDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/DeleteDocument/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/DeleteDocument/main.go index 12dc2f491e66..b42fd7fd4913 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/DeleteDocument/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/DeleteDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/GetDocument/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/GetDocument/main.go index 650c848fbcf7..2506eabe7767 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/GetDocument/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/GetDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/GetOperation/main.go index cbade4412323..5c1085a58811 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/GetProcessedDocument/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/GetProcessedDocument/main.go index e2d5626082fb..4c9ed622dde7 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/GetProcessedDocument/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/GetProcessedDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/ImportDocuments/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/ImportDocuments/main.go index fa884f7531d4..e2c387cc51e2 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/ImportDocuments/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/ImportDocuments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/ListDocuments/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/ListDocuments/main.go index a54714c6599b..cd3b0dc55c2b 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/ListDocuments/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/ListDocuments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/ListOperations/main.go index cb7010f047ea..1b30b842d89f 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/PurgeDocuments/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/PurgeDocuments/main.go index b84cff1a7b98..feb0210ad517 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/PurgeDocuments/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/PurgeDocuments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/UpdateDocument/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/UpdateDocument/main.go index 59b7b2b44eb6..c0e25198a391 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/UpdateDocument/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/DocumentClient/UpdateDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/CancelOperation/main.go index 4e06ab4f49a0..61bcb6b223c2 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/CreateEngine/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/CreateEngine/main.go index e75af8b62929..20fab5c18501 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/CreateEngine/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/CreateEngine/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/DeleteEngine/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/DeleteEngine/main.go index 2ca2be427a20..b2f94cb72394 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/DeleteEngine/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/DeleteEngine/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/GetEngine/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/GetEngine/main.go index 620924b93349..71cb6f751d04 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/GetEngine/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/GetEngine/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/GetOperation/main.go index f605e662c989..eafffb0c1602 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/ListEngines/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/ListEngines/main.go index 2fe466d4b370..1a26f9729e1a 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/ListEngines/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/ListEngines/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/ListOperations/main.go index cbc3ed4f6dfd..aef35267d5bf 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/PauseEngine/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/PauseEngine/main.go index 1494a897ec95..88fea8117b51 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/PauseEngine/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/PauseEngine/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/ResumeEngine/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/ResumeEngine/main.go index c07cba3ad7eb..44f1547ff216 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/ResumeEngine/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/ResumeEngine/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/TuneEngine/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/TuneEngine/main.go index a9eb0a0b16dd..9de0b7a410f2 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/TuneEngine/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/TuneEngine/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/UpdateEngine/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/UpdateEngine/main.go index 8ab995b4cc42..d031c9b5070a 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/UpdateEngine/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/EngineClient/UpdateEngine/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/EstimateBillingClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/EstimateBillingClient/CancelOperation/main.go index d3fd31ea6590..2e887df4ec7c 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/EstimateBillingClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/EstimateBillingClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/EstimateBillingClient/EstimateDataSize/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/EstimateBillingClient/EstimateDataSize/main.go index c9948b08a86e..c9cf914561e3 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/EstimateBillingClient/EstimateDataSize/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/EstimateBillingClient/EstimateDataSize/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/EstimateBillingClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/EstimateBillingClient/GetOperation/main.go index f9b03561a9d0..d3fc7a1f5fa9 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/EstimateBillingClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/EstimateBillingClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/EstimateBillingClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/EstimateBillingClient/ListOperations/main.go index caee7b54bb88..19151c31fc4d 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/EstimateBillingClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/EstimateBillingClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/EvaluationClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/EvaluationClient/CancelOperation/main.go index dedf470e81a6..ef7992a22575 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/EvaluationClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/EvaluationClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/EvaluationClient/CreateEvaluation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/EvaluationClient/CreateEvaluation/main.go index 336a88d8ca99..25d5fc79761d 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/EvaluationClient/CreateEvaluation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/EvaluationClient/CreateEvaluation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/EvaluationClient/GetEvaluation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/EvaluationClient/GetEvaluation/main.go index 20a8ae1a95ff..74f023b3bee3 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/EvaluationClient/GetEvaluation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/EvaluationClient/GetEvaluation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/EvaluationClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/EvaluationClient/GetOperation/main.go index 79ed5172f2aa..76ae14f437e1 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/EvaluationClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/EvaluationClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/EvaluationClient/ListEvaluationResults/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/EvaluationClient/ListEvaluationResults/main.go index 364eef1a5c8b..86e7e39cd6ae 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/EvaluationClient/ListEvaluationResults/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/EvaluationClient/ListEvaluationResults/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/EvaluationClient/ListEvaluations/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/EvaluationClient/ListEvaluations/main.go index c09550839795..fe4cae56771f 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/EvaluationClient/ListEvaluations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/EvaluationClient/ListEvaluations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/EvaluationClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/EvaluationClient/ListOperations/main.go index 93a7de56e505..7d916cc5c430 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/EvaluationClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/EvaluationClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/GroundedGenerationClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/GroundedGenerationClient/CancelOperation/main.go index f51d4b35c3cb..d3ac5349329c 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/GroundedGenerationClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/GroundedGenerationClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/GroundedGenerationClient/CheckGrounding/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/GroundedGenerationClient/CheckGrounding/main.go index 49a3a0817354..51e3ceddf5cb 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/GroundedGenerationClient/CheckGrounding/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/GroundedGenerationClient/CheckGrounding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/GroundedGenerationClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/GroundedGenerationClient/GetOperation/main.go index 8f39de9b59c3..48efdc1903b0 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/GroundedGenerationClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/GroundedGenerationClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/GroundedGenerationClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/GroundedGenerationClient/ListOperations/main.go index 1a20fc52ec0e..1e6b62deb615 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/GroundedGenerationClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/GroundedGenerationClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ProjectClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ProjectClient/CancelOperation/main.go index 25285bf9bda7..e4f358b396dc 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ProjectClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ProjectClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ProjectClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ProjectClient/GetOperation/main.go index 2baafde1b042..21ab981e99bd 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ProjectClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ProjectClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ProjectClient/GetProject/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ProjectClient/GetProject/main.go index c38f5bcbeb46..49c66e742955 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ProjectClient/GetProject/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ProjectClient/GetProject/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ProjectClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ProjectClient/ListOperations/main.go index 0b61f8cda3a5..2eecf4d4acb2 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ProjectClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ProjectClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ProjectClient/ProvisionProject/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ProjectClient/ProvisionProject/main.go index cb22d929c04c..b8257a901d46 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ProjectClient/ProvisionProject/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ProjectClient/ProvisionProject/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ProjectClient/ReportConsentChange/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ProjectClient/ReportConsentChange/main.go index d5c2b18cbbe2..596c6ce25cbb 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ProjectClient/ReportConsentChange/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ProjectClient/ReportConsentChange/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/RankClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/RankClient/CancelOperation/main.go index ca9cd7e073ff..2b9a028003d8 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/RankClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/RankClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/RankClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/RankClient/GetOperation/main.go index 6e6585d6ddfd..96287688a861 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/RankClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/RankClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/RankClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/RankClient/ListOperations/main.go index fa8821578be8..ef54fbf16b95 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/RankClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/RankClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/RankClient/Rank/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/RankClient/Rank/main.go index c6e74be30d1c..c01c9e959422 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/RankClient/Rank/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/RankClient/Rank/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/RecommendationClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/RecommendationClient/CancelOperation/main.go index ffade0e971ed..d1634e952336 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/RecommendationClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/RecommendationClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/RecommendationClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/RecommendationClient/GetOperation/main.go index f23a98254d57..d16c18541890 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/RecommendationClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/RecommendationClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/RecommendationClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/RecommendationClient/ListOperations/main.go index f72f01530ae8..bb64731feea2 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/RecommendationClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/RecommendationClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/RecommendationClient/Recommend/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/RecommendationClient/Recommend/main.go index 39e676041869..ee58eec4ddac 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/RecommendationClient/Recommend/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/RecommendationClient/Recommend/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/CancelOperation/main.go index 2dc7de1eee67..ad6a0fc101a9 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/CreateSampleQuery/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/CreateSampleQuery/main.go index f7f06a209749..fde0919a7ef4 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/CreateSampleQuery/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/CreateSampleQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/DeleteSampleQuery/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/DeleteSampleQuery/main.go index 0b4e8e90e26b..6c9e6162fcf3 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/DeleteSampleQuery/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/DeleteSampleQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/GetOperation/main.go index 0e19c589021a..dd01946396e2 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/GetSampleQuery/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/GetSampleQuery/main.go index 1195989bcf3c..94b4b694d82a 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/GetSampleQuery/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/GetSampleQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/ImportSampleQueries/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/ImportSampleQueries/main.go index 098128677a6a..4e0043bd78de 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/ImportSampleQueries/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/ImportSampleQueries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/ListOperations/main.go index af544dbc3861..2249a215d2e7 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/ListSampleQueries/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/ListSampleQueries/main.go index 6bc326959b94..43a69c24d139 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/ListSampleQueries/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/ListSampleQueries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/UpdateSampleQuery/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/UpdateSampleQuery/main.go index 834b7dfc3126..9d847daebe6c 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/UpdateSampleQuery/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQueryClient/UpdateSampleQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/CancelOperation/main.go index 4c9dbecc26e3..817322d1fd80 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/CreateSampleQuerySet/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/CreateSampleQuerySet/main.go index 7694988e4349..e2cea284a49a 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/CreateSampleQuerySet/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/CreateSampleQuerySet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/DeleteSampleQuerySet/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/DeleteSampleQuerySet/main.go index eb9bd169c486..46c4ae6aceaf 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/DeleteSampleQuerySet/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/DeleteSampleQuerySet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/GetOperation/main.go index dce003ca76c2..d5e52e41cd5a 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/GetSampleQuerySet/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/GetSampleQuerySet/main.go index 624babe97a1c..5d34caf42499 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/GetSampleQuerySet/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/GetSampleQuerySet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/ListOperations/main.go index d01c77f6c75d..f057aa79d618 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/ListSampleQuerySets/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/ListSampleQuerySets/main.go index 79cbd0f01d44..6bfa58b9a713 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/ListSampleQuerySets/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/ListSampleQuerySets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/UpdateSampleQuerySet/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/UpdateSampleQuerySet/main.go index 8340c8fec6a9..ba91329dd452 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/UpdateSampleQuerySet/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SampleQuerySetClient/UpdateSampleQuerySet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/CancelOperation/main.go index 7ff06238321f..ce806a3ea6c5 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/CreateSchema/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/CreateSchema/main.go index 291ec2af668b..a698f3fb2482 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/CreateSchema/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/CreateSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/DeleteSchema/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/DeleteSchema/main.go index aadc20f0cb34..cb892074baf0 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/DeleteSchema/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/DeleteSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/GetOperation/main.go index 6ed275e39592..5c6fade94d73 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/GetSchema/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/GetSchema/main.go index e0d6433c9a5a..b0a159ef9127 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/GetSchema/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/GetSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/ListOperations/main.go index 872d4dec216f..614d8cc757f0 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/ListSchemas/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/ListSchemas/main.go index 6d8858495310..fd2e9218d2cd 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/ListSchemas/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/ListSchemas/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/UpdateSchema/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/UpdateSchema/main.go index 89c568d928bb..cc1eb39ecf17 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/UpdateSchema/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SchemaClient/UpdateSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SearchClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SearchClient/CancelOperation/main.go index c1097d18cbd5..3aad2096ceb1 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SearchClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SearchClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SearchClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SearchClient/GetOperation/main.go index 170177657fb2..9243dd8abbda 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SearchClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SearchClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SearchClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SearchClient/ListOperations/main.go index 63b063db456a..c058165d87e1 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SearchClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SearchClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SearchClient/Search/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SearchClient/Search/main.go index 7b66a89df4d6..da87d9b19c30 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SearchClient/Search/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SearchClient/Search/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SearchTuningClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SearchTuningClient/CancelOperation/main.go index bf87069b4800..930732302f4c 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SearchTuningClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SearchTuningClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SearchTuningClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SearchTuningClient/GetOperation/main.go index cf92836799e1..81fb3516202f 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SearchTuningClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SearchTuningClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SearchTuningClient/ListCustomModels/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SearchTuningClient/ListCustomModels/main.go index 431a21910d36..e36083ef311c 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SearchTuningClient/ListCustomModels/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SearchTuningClient/ListCustomModels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SearchTuningClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SearchTuningClient/ListOperations/main.go index 426dbcd4d6d3..59109b7ddd15 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SearchTuningClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SearchTuningClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SearchTuningClient/TrainCustomModel/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SearchTuningClient/TrainCustomModel/main.go index 9157762102a5..10581bb3fece 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SearchTuningClient/TrainCustomModel/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SearchTuningClient/TrainCustomModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ServingConfigClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ServingConfigClient/CancelOperation/main.go index 565fd228cda0..2a3cd497cd6a 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ServingConfigClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ServingConfigClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ServingConfigClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ServingConfigClient/GetOperation/main.go index 779bb547db7a..35c699fabf3c 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ServingConfigClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ServingConfigClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ServingConfigClient/GetServingConfig/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ServingConfigClient/GetServingConfig/main.go index cb76c2d019a7..7a8cbf77de17 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ServingConfigClient/GetServingConfig/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ServingConfigClient/GetServingConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ServingConfigClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ServingConfigClient/ListOperations/main.go index 92e8f65352d9..a338ca990d85 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ServingConfigClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ServingConfigClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ServingConfigClient/ListServingConfigs/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ServingConfigClient/ListServingConfigs/main.go index a58914167f59..808f36bc653d 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ServingConfigClient/ListServingConfigs/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ServingConfigClient/ListServingConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/ServingConfigClient/UpdateServingConfig/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/ServingConfigClient/UpdateServingConfig/main.go index c940f25067b3..28a27c734bd6 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/ServingConfigClient/UpdateServingConfig/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/ServingConfigClient/UpdateServingConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/BatchCreateTargetSites/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/BatchCreateTargetSites/main.go index 19f3e1412b00..405d99bcd52c 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/BatchCreateTargetSites/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/BatchCreateTargetSites/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/BatchVerifyTargetSites/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/BatchVerifyTargetSites/main.go index b4f6356a4d68..d8ad02a7a8d3 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/BatchVerifyTargetSites/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/BatchVerifyTargetSites/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/CancelOperation/main.go index 1b468154ee29..01ecf938912b 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/CreateTargetSite/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/CreateTargetSite/main.go index b1f5a37e0918..2ee8eb9c5d56 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/CreateTargetSite/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/CreateTargetSite/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/DeleteTargetSite/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/DeleteTargetSite/main.go index 94f7a7db9c6f..224bfb5d7c6a 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/DeleteTargetSite/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/DeleteTargetSite/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/DisableAdvancedSiteSearch/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/DisableAdvancedSiteSearch/main.go index 11d8f13285a5..00d3e4a8820d 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/DisableAdvancedSiteSearch/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/DisableAdvancedSiteSearch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/EnableAdvancedSiteSearch/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/EnableAdvancedSiteSearch/main.go index 5577b46bd138..da9bf71a2a3d 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/EnableAdvancedSiteSearch/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/EnableAdvancedSiteSearch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/FetchDomainVerificationStatus/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/FetchDomainVerificationStatus/main.go index 352347b95285..3611ba9f5a22 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/FetchDomainVerificationStatus/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/FetchDomainVerificationStatus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/GetOperation/main.go index 85aca2169791..f7ce06691a79 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/GetSiteSearchEngine/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/GetSiteSearchEngine/main.go index f787f3f953fd..8aa06386f1f2 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/GetSiteSearchEngine/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/GetSiteSearchEngine/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/GetTargetSite/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/GetTargetSite/main.go index ff9433763690..2846d19021f0 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/GetTargetSite/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/GetTargetSite/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/GetUriPatternDocumentData/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/GetUriPatternDocumentData/main.go index e88c926fb3a0..7aa60f4b2980 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/GetUriPatternDocumentData/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/GetUriPatternDocumentData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/ListOperations/main.go index ec05653542ca..147cf2259ffa 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/ListTargetSites/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/ListTargetSites/main.go index 3488d27f6776..9c37a251ec96 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/ListTargetSites/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/ListTargetSites/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/RecrawlUris/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/RecrawlUris/main.go index 540f953acba5..a724f25bbaf1 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/RecrawlUris/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/RecrawlUris/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/SetUriPatternDocumentData/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/SetUriPatternDocumentData/main.go index 9f75d75989b3..a12c1d87b9a6 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/SetUriPatternDocumentData/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/SetUriPatternDocumentData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/UpdateTargetSite/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/UpdateTargetSite/main.go index fb631b81a506..f750174376bb 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/UpdateTargetSite/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/SiteSearchEngineClient/UpdateTargetSite/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/UserEventClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/UserEventClient/CancelOperation/main.go index bd351e967ac7..285cf0c683ce 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/UserEventClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/UserEventClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/UserEventClient/CollectUserEvent/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/UserEventClient/CollectUserEvent/main.go index d84704a83360..ccb1b9d51c4e 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/UserEventClient/CollectUserEvent/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/UserEventClient/CollectUserEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/UserEventClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/UserEventClient/GetOperation/main.go index c34c6b7c122d..e18869a24396 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/UserEventClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/UserEventClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/UserEventClient/ImportUserEvents/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/UserEventClient/ImportUserEvents/main.go index 670a80033a1c..14fac3199f97 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/UserEventClient/ImportUserEvents/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/UserEventClient/ImportUserEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/UserEventClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/UserEventClient/ListOperations/main.go index f2550cd6ac38..8c5ad7f9d371 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/UserEventClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/UserEventClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/UserEventClient/PurgeUserEvents/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/UserEventClient/PurgeUserEvents/main.go index d552cefe48eb..867110a82056 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/UserEventClient/PurgeUserEvents/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/UserEventClient/PurgeUserEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/UserEventClient/WriteUserEvent/main.go b/internal/generated/snippets/discoveryengine/apiv1alpha/UserEventClient/WriteUserEvent/main.go index db65f3a6657d..579b35ed570d 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/UserEventClient/WriteUserEvent/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/UserEventClient/WriteUserEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1alpha/snippet_metadata.google.cloud.discoveryengine.v1alpha.json b/internal/generated/snippets/discoveryengine/apiv1alpha/snippet_metadata.google.cloud.discoveryengine.v1alpha.json index 1b72b1951fe2..854e218d256e 100644 --- a/internal/generated/snippets/discoveryengine/apiv1alpha/snippet_metadata.google.cloud.discoveryengine.v1alpha.json +++ b/internal/generated/snippets/discoveryengine/apiv1alpha/snippet_metadata.google.cloud.discoveryengine.v1alpha.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/discoveryengine/apiv1alpha", - "version": "1.16.0", + "version": "1.16.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/AdvancedCompleteQuery/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/AdvancedCompleteQuery/main.go index d6c7fcf5059c..a2db893e1d5b 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/AdvancedCompleteQuery/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/AdvancedCompleteQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/CancelOperation/main.go index fa3d054f2074..1e2a8618b523 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/CompleteQuery/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/CompleteQuery/main.go index af8e9a11ba3a..c703c2300eae 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/CompleteQuery/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/CompleteQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/GetOperation/main.go index 3f8f0a9fc91b..eb1dd38872ad 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/ImportCompletionSuggestions/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/ImportCompletionSuggestions/main.go index 1cdaf2ff36df..23ff48c82440 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/ImportCompletionSuggestions/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/ImportCompletionSuggestions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/ImportSuggestionDenyListEntries/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/ImportSuggestionDenyListEntries/main.go index a931994e8dd0..75dc53e47e8e 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/ImportSuggestionDenyListEntries/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/ImportSuggestionDenyListEntries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/ListOperations/main.go index 3ded4bf49310..3046dff93437 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/PurgeCompletionSuggestions/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/PurgeCompletionSuggestions/main.go index 0e4faac6d416..156735ff60a9 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/PurgeCompletionSuggestions/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/PurgeCompletionSuggestions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/PurgeSuggestionDenyListEntries/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/PurgeSuggestionDenyListEntries/main.go index 656938585bde..7eb62d0db66f 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/PurgeSuggestionDenyListEntries/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/CompletionClient/PurgeSuggestionDenyListEntries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/CancelOperation/main.go index d347f0232853..b1af97d84ea7 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/CreateControl/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/CreateControl/main.go index bc7193b5cbd5..41d53b5e5c95 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/CreateControl/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/CreateControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/DeleteControl/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/DeleteControl/main.go index 00dc1c29882e..868ca075ffa8 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/DeleteControl/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/DeleteControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/GetControl/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/GetControl/main.go index 3852df35baf7..a7ebd33a258d 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/GetControl/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/GetControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/GetOperation/main.go index 530a0e127c3b..c4e21691c395 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/ListControls/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/ListControls/main.go index f482fcd9a568..dec7e7474313 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/ListControls/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/ListControls/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/ListOperations/main.go index e8bf999e6788..c4d54eadd98b 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/UpdateControl/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/UpdateControl/main.go index aa188b8a7e45..ee14e1a8d23d 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/UpdateControl/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ControlClient/UpdateControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/AnswerQuery/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/AnswerQuery/main.go index cd71b0478b4d..82ff9250aa6f 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/AnswerQuery/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/AnswerQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/CancelOperation/main.go index 581c1b277dfd..7290a8160acd 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/ConverseConversation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/ConverseConversation/main.go index 603566105ae0..32e95e86b81f 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/ConverseConversation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/ConverseConversation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/CreateConversation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/CreateConversation/main.go index 61d486578fa5..2fe01c403238 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/CreateConversation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/CreateConversation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/CreateSession/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/CreateSession/main.go index 91daeb158111..da3a044b573e 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/CreateSession/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/CreateSession/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/DeleteConversation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/DeleteConversation/main.go index 2bcae31f6221..21c8eb15b9c1 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/DeleteConversation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/DeleteConversation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/DeleteSession/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/DeleteSession/main.go index 1f692c055876..c41a71251b47 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/DeleteSession/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/DeleteSession/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/GetAnswer/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/GetAnswer/main.go index ed4ed67e83f0..b2e67bc62470 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/GetAnswer/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/GetAnswer/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/GetConversation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/GetConversation/main.go index 9f62c93d06c2..8f1bf5dc4d42 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/GetConversation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/GetConversation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/GetOperation/main.go index ca6764f1a798..1d978aa2a94c 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/GetSession/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/GetSession/main.go index df970cc6cefe..4b39e3b27ec1 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/GetSession/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/GetSession/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/ListConversations/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/ListConversations/main.go index a8ceed74a382..75707bcde8b5 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/ListConversations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/ListConversations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/ListOperations/main.go index fab0daf346fa..b2e9a94b8558 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/ListSessions/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/ListSessions/main.go index 75c2ef35fbf9..de9590f033ed 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/ListSessions/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/ListSessions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/UpdateConversation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/UpdateConversation/main.go index 7423623bfe61..cdf46aff23f3 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/UpdateConversation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/UpdateConversation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/UpdateSession/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/UpdateSession/main.go index cde7dc03effd..68cc06a975b1 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/UpdateSession/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ConversationalSearchClient/UpdateSession/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/CancelOperation/main.go index 7033dbe71c3e..c28c13ea5a59 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/CreateDataStore/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/CreateDataStore/main.go index 6c9780b3072c..05b7a7dd4979 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/CreateDataStore/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/CreateDataStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/DeleteDataStore/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/DeleteDataStore/main.go index 1b618fb3b22e..13ffa32e3b9d 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/DeleteDataStore/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/DeleteDataStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/GetDataStore/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/GetDataStore/main.go index df6857652a6c..f9cf87901800 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/GetDataStore/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/GetDataStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/GetOperation/main.go index 3e3f9caf1597..fb4c5b87769f 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/ListDataStores/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/ListDataStores/main.go index c19db0ab2bdd..e89c990569bf 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/ListDataStores/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/ListDataStores/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/ListOperations/main.go index 261115c2a5f1..be40967896f2 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/UpdateDataStore/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/UpdateDataStore/main.go index 4bc3b0143c72..10d64f00c0c1 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/UpdateDataStore/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/DataStoreClient/UpdateDataStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/BatchGetDocumentsMetadata/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/BatchGetDocumentsMetadata/main.go index e3f3396ff92f..f83343c84e6f 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/BatchGetDocumentsMetadata/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/BatchGetDocumentsMetadata/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/CancelOperation/main.go index f415cd0f00de..d737bac1503e 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/CreateDocument/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/CreateDocument/main.go index a29f86c57983..2d3459394ff2 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/CreateDocument/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/CreateDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/DeleteDocument/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/DeleteDocument/main.go index 7cc0558c92c6..f2e3fae9f572 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/DeleteDocument/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/DeleteDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/GetDocument/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/GetDocument/main.go index 3c5f6cf134c8..7fa866b308e4 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/GetDocument/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/GetDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/GetOperation/main.go index f60eb4dd1dca..8ea27c58142d 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/ImportDocuments/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/ImportDocuments/main.go index 0f36ecdfad5b..9f29b4880c12 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/ImportDocuments/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/ImportDocuments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/ListDocuments/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/ListDocuments/main.go index 48b83deb3eb8..ea9b1964f66e 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/ListDocuments/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/ListDocuments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/ListOperations/main.go index fd588a5828de..3b2b4f315a56 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/PurgeDocuments/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/PurgeDocuments/main.go index 587e4f2ae322..a80a920f70c6 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/PurgeDocuments/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/PurgeDocuments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/UpdateDocument/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/UpdateDocument/main.go index f4af3007a788..7d7a9ee189c1 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/UpdateDocument/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/DocumentClient/UpdateDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/CancelOperation/main.go index e944316c17cf..61290e080c35 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/CreateEngine/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/CreateEngine/main.go index dda1eb31908e..57e02fc413b1 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/CreateEngine/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/CreateEngine/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/DeleteEngine/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/DeleteEngine/main.go index 2672cc5b868b..2b9fd717c177 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/DeleteEngine/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/DeleteEngine/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/GetEngine/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/GetEngine/main.go index 335db58abf13..04794a5dfc0c 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/GetEngine/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/GetEngine/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/GetOperation/main.go index 0315e715d3c2..ba9fad4e076f 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/ListEngines/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/ListEngines/main.go index 3aba916cc314..67ef3e4a9e67 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/ListEngines/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/ListEngines/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/ListOperations/main.go index 90874b9ed47b..3994e67dbf88 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/PauseEngine/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/PauseEngine/main.go index 9f300d480f70..6901548d1d71 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/PauseEngine/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/PauseEngine/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/ResumeEngine/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/ResumeEngine/main.go index b4d9e6bbdae6..518547ecffe9 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/ResumeEngine/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/ResumeEngine/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/TuneEngine/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/TuneEngine/main.go index e48448a24b5e..2d657fa72232 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/TuneEngine/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/TuneEngine/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/UpdateEngine/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/UpdateEngine/main.go index a798fde66073..f54186b0eea9 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/UpdateEngine/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/EngineClient/UpdateEngine/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/EvaluationClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/EvaluationClient/CancelOperation/main.go index 7475f04d1f6d..971c80cd852a 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/EvaluationClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/EvaluationClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/EvaluationClient/CreateEvaluation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/EvaluationClient/CreateEvaluation/main.go index c396f5c3edc1..774808800c10 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/EvaluationClient/CreateEvaluation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/EvaluationClient/CreateEvaluation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/EvaluationClient/GetEvaluation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/EvaluationClient/GetEvaluation/main.go index f69586afc0cb..29acf1ead666 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/EvaluationClient/GetEvaluation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/EvaluationClient/GetEvaluation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/EvaluationClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/EvaluationClient/GetOperation/main.go index cc51f1142ca8..8de57c6db52b 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/EvaluationClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/EvaluationClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/EvaluationClient/ListEvaluationResults/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/EvaluationClient/ListEvaluationResults/main.go index 3d857dc2559a..640f25810120 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/EvaluationClient/ListEvaluationResults/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/EvaluationClient/ListEvaluationResults/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/EvaluationClient/ListEvaluations/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/EvaluationClient/ListEvaluations/main.go index b0ce1db3f8e6..32d02dea86dd 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/EvaluationClient/ListEvaluations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/EvaluationClient/ListEvaluations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/EvaluationClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/EvaluationClient/ListOperations/main.go index d6589c371048..4eb4244cebab 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/EvaluationClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/EvaluationClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/GroundedGenerationClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/GroundedGenerationClient/CancelOperation/main.go index 810bbf3b09b9..03bee14707ce 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/GroundedGenerationClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/GroundedGenerationClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/GroundedGenerationClient/CheckGrounding/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/GroundedGenerationClient/CheckGrounding/main.go index e0ce948c07b8..5e45f94725ec 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/GroundedGenerationClient/CheckGrounding/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/GroundedGenerationClient/CheckGrounding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/GroundedGenerationClient/GenerateGroundedContent/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/GroundedGenerationClient/GenerateGroundedContent/main.go index 71cc54001767..a0215bf1fa32 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/GroundedGenerationClient/GenerateGroundedContent/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/GroundedGenerationClient/GenerateGroundedContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/GroundedGenerationClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/GroundedGenerationClient/GetOperation/main.go index 176b0e31f0aa..2a3027d1bfb0 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/GroundedGenerationClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/GroundedGenerationClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/GroundedGenerationClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/GroundedGenerationClient/ListOperations/main.go index bb22ec6f90b5..e31a5f5d5f48 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/GroundedGenerationClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/GroundedGenerationClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/GroundedGenerationClient/StreamGenerateGroundedContent/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/GroundedGenerationClient/StreamGenerateGroundedContent/main.go index 56c66b3ff924..c01301843597 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/GroundedGenerationClient/StreamGenerateGroundedContent/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/GroundedGenerationClient/StreamGenerateGroundedContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ProjectClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ProjectClient/CancelOperation/main.go index 2a12f6842caf..6b8b2e1f1db5 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ProjectClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ProjectClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ProjectClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ProjectClient/GetOperation/main.go index 99baf4fbe28b..d1e652b2f293 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ProjectClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ProjectClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ProjectClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ProjectClient/ListOperations/main.go index 501f3fd54bac..966ecdb187d7 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ProjectClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ProjectClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ProjectClient/ProvisionProject/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ProjectClient/ProvisionProject/main.go index 4727fc7752a2..e3fbcc6cfb2e 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ProjectClient/ProvisionProject/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ProjectClient/ProvisionProject/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/RankClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/RankClient/CancelOperation/main.go index 488313cbe82e..1eb6ce9801a1 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/RankClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/RankClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/RankClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/RankClient/GetOperation/main.go index 953517fa9859..16eb3ba31198 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/RankClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/RankClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/RankClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/RankClient/ListOperations/main.go index 9271d55ba4c7..4c6f1f399e34 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/RankClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/RankClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/RankClient/Rank/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/RankClient/Rank/main.go index ca4951954028..f17ec5ee62a0 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/RankClient/Rank/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/RankClient/Rank/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/RecommendationClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/RecommendationClient/CancelOperation/main.go index e7a808ce986e..486f3eb1b0f2 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/RecommendationClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/RecommendationClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/RecommendationClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/RecommendationClient/GetOperation/main.go index 78895ce49d09..b565ffc87aac 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/RecommendationClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/RecommendationClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/RecommendationClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/RecommendationClient/ListOperations/main.go index 1a7fe9f42403..b392f2cf78e2 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/RecommendationClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/RecommendationClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/RecommendationClient/Recommend/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/RecommendationClient/Recommend/main.go index d29f370b910f..daf61b978864 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/RecommendationClient/Recommend/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/RecommendationClient/Recommend/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/CancelOperation/main.go index 69b29920fa93..a975db19cf5d 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/CreateSampleQuery/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/CreateSampleQuery/main.go index b7e4102b6882..ed526da9ce36 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/CreateSampleQuery/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/CreateSampleQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/DeleteSampleQuery/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/DeleteSampleQuery/main.go index d88480226d61..15c578da4ddc 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/DeleteSampleQuery/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/DeleteSampleQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/GetOperation/main.go index 7c0a1eb58584..7751f3cbe1be 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/GetSampleQuery/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/GetSampleQuery/main.go index a08d32fc140b..ac8037c37347 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/GetSampleQuery/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/GetSampleQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/ImportSampleQueries/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/ImportSampleQueries/main.go index d05597616f5e..5b97fca95e1c 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/ImportSampleQueries/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/ImportSampleQueries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/ListOperations/main.go index 24efc336c8dd..0d3118d08a5b 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/ListSampleQueries/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/ListSampleQueries/main.go index 17edb2bd39ad..eb96c23a2920 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/ListSampleQueries/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/ListSampleQueries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/UpdateSampleQuery/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/UpdateSampleQuery/main.go index ee0f6979d973..c7bd69cde866 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/UpdateSampleQuery/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQueryClient/UpdateSampleQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/CancelOperation/main.go index 183647b9bc82..28146abeb556 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/CreateSampleQuerySet/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/CreateSampleQuerySet/main.go index 11891cbb68bf..43afe3d7ef1d 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/CreateSampleQuerySet/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/CreateSampleQuerySet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/DeleteSampleQuerySet/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/DeleteSampleQuerySet/main.go index 414dfc6c4a6f..51070ca94e5e 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/DeleteSampleQuerySet/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/DeleteSampleQuerySet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/GetOperation/main.go index f4e592dd0055..ed6aa1c20818 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/GetSampleQuerySet/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/GetSampleQuerySet/main.go index 144552876a0c..0d6a8ba26a83 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/GetSampleQuerySet/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/GetSampleQuerySet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/ListOperations/main.go index 082155596483..0466c87cd87d 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/ListSampleQuerySets/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/ListSampleQuerySets/main.go index 7fb7cf40d5aa..36c6d829ab81 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/ListSampleQuerySets/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/ListSampleQuerySets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/UpdateSampleQuerySet/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/UpdateSampleQuerySet/main.go index 0b00122f7dc0..ffdd62b01e52 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/UpdateSampleQuerySet/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SampleQuerySetClient/UpdateSampleQuerySet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/CancelOperation/main.go index 978650af8fb5..c9eefed7a40e 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/CreateSchema/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/CreateSchema/main.go index 2c58e82bb007..eeba95abc5f9 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/CreateSchema/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/CreateSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/DeleteSchema/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/DeleteSchema/main.go index b8492f0608bc..853881a121fd 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/DeleteSchema/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/DeleteSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/GetOperation/main.go index 0650fe616466..942bdd3c303b 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/GetSchema/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/GetSchema/main.go index 3c3a6f7f4d52..e371759a8391 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/GetSchema/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/GetSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/ListOperations/main.go index 4ec597ad90b1..d0c2a5423d78 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/ListSchemas/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/ListSchemas/main.go index 6252837b1bd7..e42188b53219 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/ListSchemas/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/ListSchemas/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/UpdateSchema/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/UpdateSchema/main.go index e801846ba619..10770040cc95 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/UpdateSchema/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SchemaClient/UpdateSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SearchClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SearchClient/CancelOperation/main.go index d366e8281872..ac1d1c727c59 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SearchClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SearchClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SearchClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SearchClient/GetOperation/main.go index 724bece6540f..a2c8d955a439 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SearchClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SearchClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SearchClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SearchClient/ListOperations/main.go index d968830a569d..eb24a748596a 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SearchClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SearchClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SearchClient/Search/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SearchClient/Search/main.go index cd4e477e1e60..784ee0b18aaf 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SearchClient/Search/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SearchClient/Search/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SearchClient/SearchLite/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SearchClient/SearchLite/main.go index 47245fa4af22..c006e5709753 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SearchClient/SearchLite/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SearchClient/SearchLite/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SearchTuningClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SearchTuningClient/CancelOperation/main.go index ad1291565965..624578927494 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SearchTuningClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SearchTuningClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SearchTuningClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SearchTuningClient/GetOperation/main.go index 4f0e705791ae..cd1a114bc087 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SearchTuningClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SearchTuningClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SearchTuningClient/ListCustomModels/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SearchTuningClient/ListCustomModels/main.go index 2b5fdd675956..e957d5baffd2 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SearchTuningClient/ListCustomModels/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SearchTuningClient/ListCustomModels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SearchTuningClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SearchTuningClient/ListOperations/main.go index 4c7c433e2094..08a2ce0df3fc 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SearchTuningClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SearchTuningClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SearchTuningClient/TrainCustomModel/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SearchTuningClient/TrainCustomModel/main.go index dcb84d39b394..1d2c2bbf7bba 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SearchTuningClient/TrainCustomModel/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SearchTuningClient/TrainCustomModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ServingConfigClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ServingConfigClient/CancelOperation/main.go index 490d7e5e1cee..012f2ea4f987 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ServingConfigClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ServingConfigClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ServingConfigClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ServingConfigClient/GetOperation/main.go index 6b97a9304fff..4f13664a36a7 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ServingConfigClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ServingConfigClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ServingConfigClient/GetServingConfig/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ServingConfigClient/GetServingConfig/main.go index 39d76627094b..0fc3e619581e 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ServingConfigClient/GetServingConfig/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ServingConfigClient/GetServingConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ServingConfigClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ServingConfigClient/ListOperations/main.go index c0ed9372e5bb..bec9ff520a78 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ServingConfigClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ServingConfigClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ServingConfigClient/ListServingConfigs/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ServingConfigClient/ListServingConfigs/main.go index b3c37822142b..0a2c64796516 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ServingConfigClient/ListServingConfigs/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ServingConfigClient/ListServingConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/ServingConfigClient/UpdateServingConfig/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/ServingConfigClient/UpdateServingConfig/main.go index 4a5d174acc13..941b69a094e7 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/ServingConfigClient/UpdateServingConfig/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/ServingConfigClient/UpdateServingConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/BatchCreateTargetSites/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/BatchCreateTargetSites/main.go index aac898dfe4a6..8b833c4f35e5 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/BatchCreateTargetSites/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/BatchCreateTargetSites/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/BatchVerifyTargetSites/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/BatchVerifyTargetSites/main.go index a86d8ebe6182..0bc034c69bdd 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/BatchVerifyTargetSites/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/BatchVerifyTargetSites/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/CancelOperation/main.go index 7625943a503c..4fdc0a836f58 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/CreateSitemap/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/CreateSitemap/main.go index 403146e9d3b6..a0a6e137d3dd 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/CreateSitemap/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/CreateSitemap/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/CreateTargetSite/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/CreateTargetSite/main.go index a39936f81b5c..faa914c0b7a3 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/CreateTargetSite/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/CreateTargetSite/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/DeleteSitemap/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/DeleteSitemap/main.go index 76d471d804d0..7430bbdb9871 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/DeleteSitemap/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/DeleteSitemap/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/DeleteTargetSite/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/DeleteTargetSite/main.go index 179a2d8ceb74..ae920641f59e 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/DeleteTargetSite/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/DeleteTargetSite/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/DisableAdvancedSiteSearch/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/DisableAdvancedSiteSearch/main.go index 0b4637e34913..7f60a9963e3f 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/DisableAdvancedSiteSearch/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/DisableAdvancedSiteSearch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/EnableAdvancedSiteSearch/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/EnableAdvancedSiteSearch/main.go index 16da8a134ba0..d39586b59669 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/EnableAdvancedSiteSearch/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/EnableAdvancedSiteSearch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/FetchDomainVerificationStatus/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/FetchDomainVerificationStatus/main.go index c3962dc0f65e..0e22f63e21df 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/FetchDomainVerificationStatus/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/FetchDomainVerificationStatus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/FetchSitemaps/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/FetchSitemaps/main.go index efc23569594a..834de98e9b08 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/FetchSitemaps/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/FetchSitemaps/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/GetOperation/main.go index 723d7b164f2d..d9b5d856bca7 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/GetSiteSearchEngine/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/GetSiteSearchEngine/main.go index 6b55eb1ab2f9..6977d48d67b7 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/GetSiteSearchEngine/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/GetSiteSearchEngine/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/GetTargetSite/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/GetTargetSite/main.go index 5c84609bc61a..f60d92736a65 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/GetTargetSite/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/GetTargetSite/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/ListOperations/main.go index 5e7715480b54..b543e87adda4 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/ListTargetSites/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/ListTargetSites/main.go index 45c4b304a3d4..b1f22b965e38 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/ListTargetSites/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/ListTargetSites/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/RecrawlUris/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/RecrawlUris/main.go index 363b62515614..93f2f34bffb4 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/RecrawlUris/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/RecrawlUris/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/UpdateTargetSite/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/UpdateTargetSite/main.go index 289a0d3aa9cb..90b1242c9960 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/UpdateTargetSite/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/SiteSearchEngineClient/UpdateTargetSite/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/UserEventClient/CancelOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/UserEventClient/CancelOperation/main.go index 2ded8e9b66d7..565e907faf1f 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/UserEventClient/CancelOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/UserEventClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/UserEventClient/CollectUserEvent/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/UserEventClient/CollectUserEvent/main.go index 52f0a3dcd467..1370080fe214 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/UserEventClient/CollectUserEvent/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/UserEventClient/CollectUserEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/UserEventClient/GetOperation/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/UserEventClient/GetOperation/main.go index fcbd577ed8fa..6d00d563666e 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/UserEventClient/GetOperation/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/UserEventClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/UserEventClient/ImportUserEvents/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/UserEventClient/ImportUserEvents/main.go index a6062dc37fd7..52d469e9fd39 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/UserEventClient/ImportUserEvents/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/UserEventClient/ImportUserEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/UserEventClient/ListOperations/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/UserEventClient/ListOperations/main.go index 785e9388e1e8..b993a8d6ba0e 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/UserEventClient/ListOperations/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/UserEventClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/UserEventClient/PurgeUserEvents/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/UserEventClient/PurgeUserEvents/main.go index 10b55307d939..984b1c83a1de 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/UserEventClient/PurgeUserEvents/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/UserEventClient/PurgeUserEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/UserEventClient/WriteUserEvent/main.go b/internal/generated/snippets/discoveryengine/apiv1beta/UserEventClient/WriteUserEvent/main.go index afd92418a20c..81880d7e60e2 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/UserEventClient/WriteUserEvent/main.go +++ b/internal/generated/snippets/discoveryengine/apiv1beta/UserEventClient/WriteUserEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/discoveryengine/apiv1beta/snippet_metadata.google.cloud.discoveryengine.v1beta.json b/internal/generated/snippets/discoveryengine/apiv1beta/snippet_metadata.google.cloud.discoveryengine.v1beta.json index 3ffc045c5b82..a6bc18ccc281 100644 --- a/internal/generated/snippets/discoveryengine/apiv1beta/snippet_metadata.google.cloud.discoveryengine.v1beta.json +++ b/internal/generated/snippets/discoveryengine/apiv1beta/snippet_metadata.google.cloud.discoveryengine.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/discoveryengine/apiv1beta", - "version": "1.16.0", + "version": "1.16.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/dlp/apiv2/Client/ActivateJobTrigger/main.go b/internal/generated/snippets/dlp/apiv2/Client/ActivateJobTrigger/main.go index 0d233a599012..ddf2f4ade832 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/ActivateJobTrigger/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/ActivateJobTrigger/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/CancelDlpJob/main.go b/internal/generated/snippets/dlp/apiv2/Client/CancelDlpJob/main.go index 39537aff3849..9d2737052037 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/CancelDlpJob/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/CancelDlpJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/CreateConnection/main.go b/internal/generated/snippets/dlp/apiv2/Client/CreateConnection/main.go index 206f7ff0cc75..bb508b386eeb 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/CreateConnection/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/CreateConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/CreateDeidentifyTemplate/main.go b/internal/generated/snippets/dlp/apiv2/Client/CreateDeidentifyTemplate/main.go index 3683c3af2245..124ca8371982 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/CreateDeidentifyTemplate/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/CreateDeidentifyTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/CreateDiscoveryConfig/main.go b/internal/generated/snippets/dlp/apiv2/Client/CreateDiscoveryConfig/main.go index e38704a35279..0bea2eff800a 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/CreateDiscoveryConfig/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/CreateDiscoveryConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/CreateDlpJob/main.go b/internal/generated/snippets/dlp/apiv2/Client/CreateDlpJob/main.go index 202f8334a53a..1521621aa908 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/CreateDlpJob/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/CreateDlpJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/CreateInspectTemplate/main.go b/internal/generated/snippets/dlp/apiv2/Client/CreateInspectTemplate/main.go index 46e238ebcff0..9c286755ba4f 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/CreateInspectTemplate/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/CreateInspectTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/CreateJobTrigger/main.go b/internal/generated/snippets/dlp/apiv2/Client/CreateJobTrigger/main.go index bf3248f14bbe..53d3f36a9e71 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/CreateJobTrigger/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/CreateJobTrigger/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/CreateStoredInfoType/main.go b/internal/generated/snippets/dlp/apiv2/Client/CreateStoredInfoType/main.go index 1496c09d93fa..c912862ff95a 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/CreateStoredInfoType/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/CreateStoredInfoType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/DeidentifyContent/main.go b/internal/generated/snippets/dlp/apiv2/Client/DeidentifyContent/main.go index c2f0e5f6a48d..861ab73e3393 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/DeidentifyContent/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/DeidentifyContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/DeleteConnection/main.go b/internal/generated/snippets/dlp/apiv2/Client/DeleteConnection/main.go index 2d29c95cb533..8e277827dd1f 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/DeleteConnection/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/DeleteConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/DeleteDeidentifyTemplate/main.go b/internal/generated/snippets/dlp/apiv2/Client/DeleteDeidentifyTemplate/main.go index 312789544af2..ea3c94c9147f 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/DeleteDeidentifyTemplate/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/DeleteDeidentifyTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/DeleteDiscoveryConfig/main.go b/internal/generated/snippets/dlp/apiv2/Client/DeleteDiscoveryConfig/main.go index 57ac1c4dd098..514cfa3f93b0 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/DeleteDiscoveryConfig/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/DeleteDiscoveryConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/DeleteDlpJob/main.go b/internal/generated/snippets/dlp/apiv2/Client/DeleteDlpJob/main.go index d3ea8f474dc6..c3fee64f730c 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/DeleteDlpJob/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/DeleteDlpJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/DeleteFileStoreDataProfile/main.go b/internal/generated/snippets/dlp/apiv2/Client/DeleteFileStoreDataProfile/main.go index 16be5e6659cc..f591df2ac5de 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/DeleteFileStoreDataProfile/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/DeleteFileStoreDataProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/DeleteInspectTemplate/main.go b/internal/generated/snippets/dlp/apiv2/Client/DeleteInspectTemplate/main.go index 42092fae29ab..8d99ec841c27 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/DeleteInspectTemplate/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/DeleteInspectTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/DeleteJobTrigger/main.go b/internal/generated/snippets/dlp/apiv2/Client/DeleteJobTrigger/main.go index d0a67771a1c0..5092d6beccdf 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/DeleteJobTrigger/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/DeleteJobTrigger/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/DeleteStoredInfoType/main.go b/internal/generated/snippets/dlp/apiv2/Client/DeleteStoredInfoType/main.go index 25c7c3b92f5d..64ce2d404bfb 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/DeleteStoredInfoType/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/DeleteStoredInfoType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/DeleteTableDataProfile/main.go b/internal/generated/snippets/dlp/apiv2/Client/DeleteTableDataProfile/main.go index 80cca8b52251..f7db911c0ac9 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/DeleteTableDataProfile/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/DeleteTableDataProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/FinishDlpJob/main.go b/internal/generated/snippets/dlp/apiv2/Client/FinishDlpJob/main.go index 545cc1cd0d1f..474c1650742e 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/FinishDlpJob/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/FinishDlpJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/GetColumnDataProfile/main.go b/internal/generated/snippets/dlp/apiv2/Client/GetColumnDataProfile/main.go index a4347a75d82f..c8b8fcb4bf42 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/GetColumnDataProfile/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/GetColumnDataProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/GetConnection/main.go b/internal/generated/snippets/dlp/apiv2/Client/GetConnection/main.go index 9d87eae44df5..48f4c3a1120b 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/GetConnection/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/GetConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/GetDeidentifyTemplate/main.go b/internal/generated/snippets/dlp/apiv2/Client/GetDeidentifyTemplate/main.go index 30b89525f539..d768f5791aea 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/GetDeidentifyTemplate/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/GetDeidentifyTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/GetDiscoveryConfig/main.go b/internal/generated/snippets/dlp/apiv2/Client/GetDiscoveryConfig/main.go index abe32550d392..48a5a89659ea 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/GetDiscoveryConfig/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/GetDiscoveryConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/GetDlpJob/main.go b/internal/generated/snippets/dlp/apiv2/Client/GetDlpJob/main.go index 40439feef395..217dd75a3056 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/GetDlpJob/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/GetDlpJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/GetFileStoreDataProfile/main.go b/internal/generated/snippets/dlp/apiv2/Client/GetFileStoreDataProfile/main.go index fbe26023e8de..0be2ffe1771c 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/GetFileStoreDataProfile/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/GetFileStoreDataProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/GetInspectTemplate/main.go b/internal/generated/snippets/dlp/apiv2/Client/GetInspectTemplate/main.go index d11c499d483e..7fdb091ff6ef 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/GetInspectTemplate/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/GetInspectTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/GetJobTrigger/main.go b/internal/generated/snippets/dlp/apiv2/Client/GetJobTrigger/main.go index ef7437ed0ff9..d59a797b4f69 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/GetJobTrigger/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/GetJobTrigger/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/GetProjectDataProfile/main.go b/internal/generated/snippets/dlp/apiv2/Client/GetProjectDataProfile/main.go index c4f565999050..5826a1b23c6d 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/GetProjectDataProfile/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/GetProjectDataProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/GetStoredInfoType/main.go b/internal/generated/snippets/dlp/apiv2/Client/GetStoredInfoType/main.go index ad3156f5e004..686fd9fdd32b 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/GetStoredInfoType/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/GetStoredInfoType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/GetTableDataProfile/main.go b/internal/generated/snippets/dlp/apiv2/Client/GetTableDataProfile/main.go index a143703011df..999a763518c3 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/GetTableDataProfile/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/GetTableDataProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/HybridInspectDlpJob/main.go b/internal/generated/snippets/dlp/apiv2/Client/HybridInspectDlpJob/main.go index 74665e2b4a7b..2c074a21e7e7 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/HybridInspectDlpJob/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/HybridInspectDlpJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/HybridInspectJobTrigger/main.go b/internal/generated/snippets/dlp/apiv2/Client/HybridInspectJobTrigger/main.go index 3c0f7fd1f0b7..efe162400c25 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/HybridInspectJobTrigger/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/HybridInspectJobTrigger/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/InspectContent/main.go b/internal/generated/snippets/dlp/apiv2/Client/InspectContent/main.go index e372d0525019..7ebdacd8820b 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/InspectContent/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/InspectContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/ListColumnDataProfiles/main.go b/internal/generated/snippets/dlp/apiv2/Client/ListColumnDataProfiles/main.go index 6da6b515a1ac..03881542be4c 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/ListColumnDataProfiles/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/ListColumnDataProfiles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/ListConnections/main.go b/internal/generated/snippets/dlp/apiv2/Client/ListConnections/main.go index caaaccd079b5..023e98f0d8c6 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/ListConnections/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/ListConnections/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/ListDeidentifyTemplates/main.go b/internal/generated/snippets/dlp/apiv2/Client/ListDeidentifyTemplates/main.go index b496e41d322d..2e14dc44399a 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/ListDeidentifyTemplates/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/ListDeidentifyTemplates/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/ListDiscoveryConfigs/main.go b/internal/generated/snippets/dlp/apiv2/Client/ListDiscoveryConfigs/main.go index c98027cf2384..618b726c7502 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/ListDiscoveryConfigs/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/ListDiscoveryConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/ListDlpJobs/main.go b/internal/generated/snippets/dlp/apiv2/Client/ListDlpJobs/main.go index a05cc22a0277..6b82b72e3a51 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/ListDlpJobs/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/ListDlpJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/ListFileStoreDataProfiles/main.go b/internal/generated/snippets/dlp/apiv2/Client/ListFileStoreDataProfiles/main.go index a274e35bc4b4..9f5f2b1fe33f 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/ListFileStoreDataProfiles/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/ListFileStoreDataProfiles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/ListInfoTypes/main.go b/internal/generated/snippets/dlp/apiv2/Client/ListInfoTypes/main.go index a77a382b66f5..27c5def63174 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/ListInfoTypes/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/ListInfoTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/ListInspectTemplates/main.go b/internal/generated/snippets/dlp/apiv2/Client/ListInspectTemplates/main.go index d0d405677929..9afe843ae075 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/ListInspectTemplates/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/ListInspectTemplates/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/ListJobTriggers/main.go b/internal/generated/snippets/dlp/apiv2/Client/ListJobTriggers/main.go index 5b46c61b8ea0..250883bc6e74 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/ListJobTriggers/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/ListJobTriggers/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/ListProjectDataProfiles/main.go b/internal/generated/snippets/dlp/apiv2/Client/ListProjectDataProfiles/main.go index 91dcc6c6be4e..1f1542262ad7 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/ListProjectDataProfiles/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/ListProjectDataProfiles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/ListStoredInfoTypes/main.go b/internal/generated/snippets/dlp/apiv2/Client/ListStoredInfoTypes/main.go index 373c52852dc7..2bd9a680477f 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/ListStoredInfoTypes/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/ListStoredInfoTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/ListTableDataProfiles/main.go b/internal/generated/snippets/dlp/apiv2/Client/ListTableDataProfiles/main.go index ac449c80ff39..8bf0718f0605 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/ListTableDataProfiles/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/ListTableDataProfiles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/RedactImage/main.go b/internal/generated/snippets/dlp/apiv2/Client/RedactImage/main.go index 169b368452d6..e86f1ea04767 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/RedactImage/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/RedactImage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/ReidentifyContent/main.go b/internal/generated/snippets/dlp/apiv2/Client/ReidentifyContent/main.go index b1112a6b545e..d2d9546e87b2 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/ReidentifyContent/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/ReidentifyContent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/SearchConnections/main.go b/internal/generated/snippets/dlp/apiv2/Client/SearchConnections/main.go index dd4ccc51369a..14416a921c09 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/SearchConnections/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/SearchConnections/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/UpdateConnection/main.go b/internal/generated/snippets/dlp/apiv2/Client/UpdateConnection/main.go index 2378613e58ff..ad584941599e 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/UpdateConnection/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/UpdateConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/UpdateDeidentifyTemplate/main.go b/internal/generated/snippets/dlp/apiv2/Client/UpdateDeidentifyTemplate/main.go index 54e6fad341ed..e3b903338920 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/UpdateDeidentifyTemplate/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/UpdateDeidentifyTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/UpdateDiscoveryConfig/main.go b/internal/generated/snippets/dlp/apiv2/Client/UpdateDiscoveryConfig/main.go index da088f980d17..e036fa345116 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/UpdateDiscoveryConfig/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/UpdateDiscoveryConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/UpdateInspectTemplate/main.go b/internal/generated/snippets/dlp/apiv2/Client/UpdateInspectTemplate/main.go index 24483bd6b94b..a10b9759521d 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/UpdateInspectTemplate/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/UpdateInspectTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/UpdateJobTrigger/main.go b/internal/generated/snippets/dlp/apiv2/Client/UpdateJobTrigger/main.go index 6e8b841bd9eb..4d7f093f235b 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/UpdateJobTrigger/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/UpdateJobTrigger/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/Client/UpdateStoredInfoType/main.go b/internal/generated/snippets/dlp/apiv2/Client/UpdateStoredInfoType/main.go index d150f038e5bf..c6800f43e518 100644 --- a/internal/generated/snippets/dlp/apiv2/Client/UpdateStoredInfoType/main.go +++ b/internal/generated/snippets/dlp/apiv2/Client/UpdateStoredInfoType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/dlp/apiv2/snippet_metadata.google.privacy.dlp.v2.json b/internal/generated/snippets/dlp/apiv2/snippet_metadata.google.privacy.dlp.v2.json index ef555758ec42..acbf9b23d553 100644 --- a/internal/generated/snippets/dlp/apiv2/snippet_metadata.google.privacy.dlp.v2.json +++ b/internal/generated/snippets/dlp/apiv2/snippet_metadata.google.privacy.dlp.v2.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/dlp/apiv2", - "version": "1.20.0", + "version": "1.20.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/BatchProcessDocuments/main.go b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/BatchProcessDocuments/main.go index 732508c61c36..42757b8155c7 100644 --- a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/BatchProcessDocuments/main.go +++ b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/BatchProcessDocuments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/CancelOperation/main.go b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/CancelOperation/main.go index 28d0c8473260..07388339bdf9 100644 --- a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/CancelOperation/main.go +++ b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/CreateProcessor/main.go b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/CreateProcessor/main.go index d50d0e28a65e..da6cbf39181a 100644 --- a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/CreateProcessor/main.go +++ b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/CreateProcessor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/DeleteProcessor/main.go b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/DeleteProcessor/main.go index 724d33b92912..4a0495ac4036 100644 --- a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/DeleteProcessor/main.go +++ b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/DeleteProcessor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/DeleteProcessorVersion/main.go b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/DeleteProcessorVersion/main.go index a43cb7222a8a..ae5729227226 100644 --- a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/DeleteProcessorVersion/main.go +++ b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/DeleteProcessorVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/DeployProcessorVersion/main.go b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/DeployProcessorVersion/main.go index 9617d0e2ef0a..0bfe557410e0 100644 --- a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/DeployProcessorVersion/main.go +++ b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/DeployProcessorVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/DisableProcessor/main.go b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/DisableProcessor/main.go index 3c9b16b86b95..bb21375945d1 100644 --- a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/DisableProcessor/main.go +++ b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/DisableProcessor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/EnableProcessor/main.go b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/EnableProcessor/main.go index bdb9f00309f1..6c261fd4b54a 100644 --- a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/EnableProcessor/main.go +++ b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/EnableProcessor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/EvaluateProcessorVersion/main.go b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/EvaluateProcessorVersion/main.go index eae64b457b4d..5629841a7722 100644 --- a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/EvaluateProcessorVersion/main.go +++ b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/EvaluateProcessorVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/FetchProcessorTypes/main.go b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/FetchProcessorTypes/main.go index 5b8694efadc5..aa9b1eb55f63 100644 --- a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/FetchProcessorTypes/main.go +++ b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/FetchProcessorTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/GetEvaluation/main.go b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/GetEvaluation/main.go index 16cc854e2352..03b61bed67e0 100644 --- a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/GetEvaluation/main.go +++ b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/GetEvaluation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/GetLocation/main.go b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/GetLocation/main.go index 2444c5824002..9de8b35153f4 100644 --- a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/GetLocation/main.go +++ b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/GetOperation/main.go b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/GetOperation/main.go index f54990fecc27..5d4e3e01781f 100644 --- a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/GetOperation/main.go +++ b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/GetProcessor/main.go b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/GetProcessor/main.go index 84f4ea5bda59..d0c8f0ab237d 100644 --- a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/GetProcessor/main.go +++ b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/GetProcessor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/GetProcessorType/main.go b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/GetProcessorType/main.go index d9b45eb5d8bc..a1984c708fed 100644 --- a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/GetProcessorType/main.go +++ b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/GetProcessorType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/GetProcessorVersion/main.go b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/GetProcessorVersion/main.go index d459248cb30d..f5084e4c5cf5 100644 --- a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/GetProcessorVersion/main.go +++ b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/GetProcessorVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ListEvaluations/main.go b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ListEvaluations/main.go index e20eee62b366..59ba10ef75ed 100644 --- a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ListEvaluations/main.go +++ b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ListEvaluations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ListLocations/main.go b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ListLocations/main.go index b53d8c2d7a82..a3d7e8f2f515 100644 --- a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ListLocations/main.go +++ b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ListOperations/main.go b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ListOperations/main.go index ae85811bfd7b..9085511cd2ee 100644 --- a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ListOperations/main.go +++ b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ListProcessorTypes/main.go b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ListProcessorTypes/main.go index 1cfde2fea2d3..575b7ec8c214 100644 --- a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ListProcessorTypes/main.go +++ b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ListProcessorTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ListProcessorVersions/main.go b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ListProcessorVersions/main.go index 1abdb0c4a2aa..5764ae393d07 100644 --- a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ListProcessorVersions/main.go +++ b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ListProcessorVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ListProcessors/main.go b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ListProcessors/main.go index 09aa3bde1fa9..71d39170db2f 100644 --- a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ListProcessors/main.go +++ b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ListProcessors/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ProcessDocument/main.go b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ProcessDocument/main.go index 57ad6580bd03..c2664c1eb8d7 100644 --- a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ProcessDocument/main.go +++ b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ProcessDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ReviewDocument/main.go b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ReviewDocument/main.go index 3b25d5e10f9d..778795f33848 100644 --- a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ReviewDocument/main.go +++ b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/ReviewDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/SetDefaultProcessorVersion/main.go b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/SetDefaultProcessorVersion/main.go index 692a86bcc932..a95fc5df7615 100644 --- a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/SetDefaultProcessorVersion/main.go +++ b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/SetDefaultProcessorVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/TrainProcessorVersion/main.go b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/TrainProcessorVersion/main.go index bca26eababbf..d2554087bbaf 100644 --- a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/TrainProcessorVersion/main.go +++ b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/TrainProcessorVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/UndeployProcessorVersion/main.go b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/UndeployProcessorVersion/main.go index 102026284b08..47e00ef42ffb 100644 --- a/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/UndeployProcessorVersion/main.go +++ b/internal/generated/snippets/documentai/apiv1/DocumentProcessorClient/UndeployProcessorVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1/snippet_metadata.google.cloud.documentai.v1.json b/internal/generated/snippets/documentai/apiv1/snippet_metadata.google.cloud.documentai.v1.json index 1a5bdadd1cbf..fecdd13f6063 100644 --- a/internal/generated/snippets/documentai/apiv1/snippet_metadata.google.cloud.documentai.v1.json +++ b/internal/generated/snippets/documentai/apiv1/snippet_metadata.google.cloud.documentai.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/documentai/apiv1", - "version": "1.35.0", + "version": "1.35.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/BatchDeleteDocuments/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/BatchDeleteDocuments/main.go index aecfc74a366a..d1bc5691f6e3 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/BatchDeleteDocuments/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/BatchDeleteDocuments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/CancelOperation/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/CancelOperation/main.go index 31f1685d2823..3faf0ded763e 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/CancelOperation/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/GetDatasetSchema/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/GetDatasetSchema/main.go index 55e7c2cc8ac4..c11d15175904 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/GetDatasetSchema/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/GetDatasetSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/GetDocument/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/GetDocument/main.go index 45fdd8d23d77..43a8d4616b1a 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/GetDocument/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/GetDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/GetLocation/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/GetLocation/main.go index d4025bb6c708..5dc1e7f8acd5 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/GetLocation/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/GetOperation/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/GetOperation/main.go index 0e7b4f9d147e..5f3c2eb8e015 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/GetOperation/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/ImportDocuments/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/ImportDocuments/main.go index 8b6e37ba6037..d343a764a57d 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/ImportDocuments/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/ImportDocuments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/ListDocuments/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/ListDocuments/main.go index aa4d6484b334..2543cefa9baf 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/ListDocuments/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/ListDocuments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/ListLocations/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/ListLocations/main.go index 1655fec11979..071417a1a27e 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/ListLocations/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/ListOperations/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/ListOperations/main.go index 26dec1b14357..8c8e65a05a68 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/ListOperations/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/UpdateDataset/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/UpdateDataset/main.go index 5a66202d983d..2f5dcbb00f98 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/UpdateDataset/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/UpdateDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/UpdateDatasetSchema/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/UpdateDatasetSchema/main.go index 7cdffac0071e..765e55c5c3b6 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/UpdateDatasetSchema/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentClient/UpdateDatasetSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/BatchProcessDocuments/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/BatchProcessDocuments/main.go index 0ede16dd238f..732b5fe4134e 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/BatchProcessDocuments/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/BatchProcessDocuments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/CancelOperation/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/CancelOperation/main.go index 2a231efe4016..ee603d02a140 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/CancelOperation/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/CreateProcessor/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/CreateProcessor/main.go index ee24be5d7bb3..96f0d19b810c 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/CreateProcessor/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/CreateProcessor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/DeleteProcessor/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/DeleteProcessor/main.go index 230d98b0215d..9572957de643 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/DeleteProcessor/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/DeleteProcessor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/DeleteProcessorVersion/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/DeleteProcessorVersion/main.go index 5ea86ff2370f..f2f7bf7a7738 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/DeleteProcessorVersion/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/DeleteProcessorVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/DeployProcessorVersion/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/DeployProcessorVersion/main.go index c46cc1d7ef5f..738e1ed2f798 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/DeployProcessorVersion/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/DeployProcessorVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/DisableProcessor/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/DisableProcessor/main.go index 57d71ae6ba3b..106b313ade04 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/DisableProcessor/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/DisableProcessor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/EnableProcessor/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/EnableProcessor/main.go index 5744b4511e24..4aca9c045d31 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/EnableProcessor/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/EnableProcessor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/EvaluateProcessorVersion/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/EvaluateProcessorVersion/main.go index 9ea6b3995def..3ae26a39c3f8 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/EvaluateProcessorVersion/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/EvaluateProcessorVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/FetchProcessorTypes/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/FetchProcessorTypes/main.go index b761c6f0b6fb..7f16d6e2ad98 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/FetchProcessorTypes/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/FetchProcessorTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/GetEvaluation/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/GetEvaluation/main.go index 8b35b7c14e3a..743cf7257dd7 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/GetEvaluation/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/GetEvaluation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/GetLocation/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/GetLocation/main.go index 41c2d50e37d7..343576089547 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/GetLocation/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/GetOperation/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/GetOperation/main.go index fe4f907c2ef4..9cd64c7c99ff 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/GetOperation/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/GetProcessor/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/GetProcessor/main.go index cb1314d08df6..670678635353 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/GetProcessor/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/GetProcessor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/GetProcessorType/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/GetProcessorType/main.go index f34ce9015532..38fc0b638d6e 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/GetProcessorType/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/GetProcessorType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/GetProcessorVersion/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/GetProcessorVersion/main.go index ec112e4420d1..fcec3762fbf7 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/GetProcessorVersion/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/GetProcessorVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ImportProcessorVersion/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ImportProcessorVersion/main.go index 4133bc46b8bd..2fb7876cee07 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ImportProcessorVersion/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ImportProcessorVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ListEvaluations/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ListEvaluations/main.go index e947f4aa6828..82b726a89b78 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ListEvaluations/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ListEvaluations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ListLocations/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ListLocations/main.go index 65fc6d420141..1a7238e4e144 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ListLocations/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ListOperations/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ListOperations/main.go index 1ca789593b73..aefa57f47f44 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ListOperations/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ListProcessorTypes/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ListProcessorTypes/main.go index 6eac627b4102..08d5e8420bc9 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ListProcessorTypes/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ListProcessorTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ListProcessorVersions/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ListProcessorVersions/main.go index ed871db41d85..d62d20e67734 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ListProcessorVersions/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ListProcessorVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ListProcessors/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ListProcessors/main.go index 7f01c29cba6c..9f8876d950f9 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ListProcessors/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ListProcessors/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ProcessDocument/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ProcessDocument/main.go index 34aa2dc34030..1fcd25be4bfa 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ProcessDocument/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ProcessDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ReviewDocument/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ReviewDocument/main.go index 4f006fb5b367..6b5c66c577be 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ReviewDocument/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/ReviewDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/SetDefaultProcessorVersion/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/SetDefaultProcessorVersion/main.go index c8dfde0fa273..d32a351d4c54 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/SetDefaultProcessorVersion/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/SetDefaultProcessorVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/TrainProcessorVersion/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/TrainProcessorVersion/main.go index c8ffcb0071ef..e02a5e3a935f 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/TrainProcessorVersion/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/TrainProcessorVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/UndeployProcessorVersion/main.go b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/UndeployProcessorVersion/main.go index d364dbe435e2..e5accad6c466 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/UndeployProcessorVersion/main.go +++ b/internal/generated/snippets/documentai/apiv1beta3/DocumentProcessorClient/UndeployProcessorVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/documentai/apiv1beta3/snippet_metadata.google.cloud.documentai.v1beta3.json b/internal/generated/snippets/documentai/apiv1beta3/snippet_metadata.google.cloud.documentai.v1beta3.json index 080a66112109..0190445739ac 100644 --- a/internal/generated/snippets/documentai/apiv1beta3/snippet_metadata.google.cloud.documentai.v1beta3.json +++ b/internal/generated/snippets/documentai/apiv1beta3/snippet_metadata.google.cloud.documentai.v1beta3.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/documentai/apiv1beta3", - "version": "1.35.0", + "version": "1.35.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/domains/apiv1beta1/Client/ConfigureContactSettings/main.go b/internal/generated/snippets/domains/apiv1beta1/Client/ConfigureContactSettings/main.go index b30bcdce7534..61d56c9a2c56 100644 --- a/internal/generated/snippets/domains/apiv1beta1/Client/ConfigureContactSettings/main.go +++ b/internal/generated/snippets/domains/apiv1beta1/Client/ConfigureContactSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/domains/apiv1beta1/Client/ConfigureDnsSettings/main.go b/internal/generated/snippets/domains/apiv1beta1/Client/ConfigureDnsSettings/main.go index 990dbd8f6165..0c47691796f9 100644 --- a/internal/generated/snippets/domains/apiv1beta1/Client/ConfigureDnsSettings/main.go +++ b/internal/generated/snippets/domains/apiv1beta1/Client/ConfigureDnsSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/domains/apiv1beta1/Client/ConfigureManagementSettings/main.go b/internal/generated/snippets/domains/apiv1beta1/Client/ConfigureManagementSettings/main.go index 4a9a3eb1673f..9833a157526e 100644 --- a/internal/generated/snippets/domains/apiv1beta1/Client/ConfigureManagementSettings/main.go +++ b/internal/generated/snippets/domains/apiv1beta1/Client/ConfigureManagementSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/domains/apiv1beta1/Client/DeleteRegistration/main.go b/internal/generated/snippets/domains/apiv1beta1/Client/DeleteRegistration/main.go index 8c9149ce0c4e..e6705cc69c69 100644 --- a/internal/generated/snippets/domains/apiv1beta1/Client/DeleteRegistration/main.go +++ b/internal/generated/snippets/domains/apiv1beta1/Client/DeleteRegistration/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/domains/apiv1beta1/Client/ExportRegistration/main.go b/internal/generated/snippets/domains/apiv1beta1/Client/ExportRegistration/main.go index e4e3b4b3f730..b9344ffecf66 100644 --- a/internal/generated/snippets/domains/apiv1beta1/Client/ExportRegistration/main.go +++ b/internal/generated/snippets/domains/apiv1beta1/Client/ExportRegistration/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/domains/apiv1beta1/Client/GetRegistration/main.go b/internal/generated/snippets/domains/apiv1beta1/Client/GetRegistration/main.go index 347b69b70f0f..63fd9f424be4 100644 --- a/internal/generated/snippets/domains/apiv1beta1/Client/GetRegistration/main.go +++ b/internal/generated/snippets/domains/apiv1beta1/Client/GetRegistration/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/domains/apiv1beta1/Client/ListRegistrations/main.go b/internal/generated/snippets/domains/apiv1beta1/Client/ListRegistrations/main.go index 51d11ee8578e..62de06c37da9 100644 --- a/internal/generated/snippets/domains/apiv1beta1/Client/ListRegistrations/main.go +++ b/internal/generated/snippets/domains/apiv1beta1/Client/ListRegistrations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/domains/apiv1beta1/Client/RegisterDomain/main.go b/internal/generated/snippets/domains/apiv1beta1/Client/RegisterDomain/main.go index 1d6d3b9b15e3..beea74427b52 100644 --- a/internal/generated/snippets/domains/apiv1beta1/Client/RegisterDomain/main.go +++ b/internal/generated/snippets/domains/apiv1beta1/Client/RegisterDomain/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/domains/apiv1beta1/Client/ResetAuthorizationCode/main.go b/internal/generated/snippets/domains/apiv1beta1/Client/ResetAuthorizationCode/main.go index 7d239b6a1dc1..db55308dd262 100644 --- a/internal/generated/snippets/domains/apiv1beta1/Client/ResetAuthorizationCode/main.go +++ b/internal/generated/snippets/domains/apiv1beta1/Client/ResetAuthorizationCode/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/domains/apiv1beta1/Client/RetrieveAuthorizationCode/main.go b/internal/generated/snippets/domains/apiv1beta1/Client/RetrieveAuthorizationCode/main.go index 87bb1c7e9089..9253e9710316 100644 --- a/internal/generated/snippets/domains/apiv1beta1/Client/RetrieveAuthorizationCode/main.go +++ b/internal/generated/snippets/domains/apiv1beta1/Client/RetrieveAuthorizationCode/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/domains/apiv1beta1/Client/RetrieveRegisterParameters/main.go b/internal/generated/snippets/domains/apiv1beta1/Client/RetrieveRegisterParameters/main.go index ea0bec069dc2..a5b5d9ad0283 100644 --- a/internal/generated/snippets/domains/apiv1beta1/Client/RetrieveRegisterParameters/main.go +++ b/internal/generated/snippets/domains/apiv1beta1/Client/RetrieveRegisterParameters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/domains/apiv1beta1/Client/RetrieveTransferParameters/main.go b/internal/generated/snippets/domains/apiv1beta1/Client/RetrieveTransferParameters/main.go index 7c60ad387df8..74b6286259a1 100644 --- a/internal/generated/snippets/domains/apiv1beta1/Client/RetrieveTransferParameters/main.go +++ b/internal/generated/snippets/domains/apiv1beta1/Client/RetrieveTransferParameters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/domains/apiv1beta1/Client/SearchDomains/main.go b/internal/generated/snippets/domains/apiv1beta1/Client/SearchDomains/main.go index 32e2fd231e4f..31ce9d94e349 100644 --- a/internal/generated/snippets/domains/apiv1beta1/Client/SearchDomains/main.go +++ b/internal/generated/snippets/domains/apiv1beta1/Client/SearchDomains/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/domains/apiv1beta1/Client/TransferDomain/main.go b/internal/generated/snippets/domains/apiv1beta1/Client/TransferDomain/main.go index f340fef967e1..3509c85049d4 100644 --- a/internal/generated/snippets/domains/apiv1beta1/Client/TransferDomain/main.go +++ b/internal/generated/snippets/domains/apiv1beta1/Client/TransferDomain/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/domains/apiv1beta1/Client/UpdateRegistration/main.go b/internal/generated/snippets/domains/apiv1beta1/Client/UpdateRegistration/main.go index b784989ea74e..e01d3fe7400f 100644 --- a/internal/generated/snippets/domains/apiv1beta1/Client/UpdateRegistration/main.go +++ b/internal/generated/snippets/domains/apiv1beta1/Client/UpdateRegistration/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgecontainer/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/edgecontainer/apiv1/Client/CancelOperation/main.go index 6835038b656f..e01ebcda2727 100644 --- a/internal/generated/snippets/edgecontainer/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/edgecontainer/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgecontainer/apiv1/Client/CreateCluster/main.go b/internal/generated/snippets/edgecontainer/apiv1/Client/CreateCluster/main.go index b123ee8da2ea..e1dc96f3c289 100644 --- a/internal/generated/snippets/edgecontainer/apiv1/Client/CreateCluster/main.go +++ b/internal/generated/snippets/edgecontainer/apiv1/Client/CreateCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgecontainer/apiv1/Client/CreateNodePool/main.go b/internal/generated/snippets/edgecontainer/apiv1/Client/CreateNodePool/main.go index da0d60aceb23..8fc99917c954 100644 --- a/internal/generated/snippets/edgecontainer/apiv1/Client/CreateNodePool/main.go +++ b/internal/generated/snippets/edgecontainer/apiv1/Client/CreateNodePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgecontainer/apiv1/Client/CreateVpnConnection/main.go b/internal/generated/snippets/edgecontainer/apiv1/Client/CreateVpnConnection/main.go index 2260288cc96b..330ae1e0c34f 100644 --- a/internal/generated/snippets/edgecontainer/apiv1/Client/CreateVpnConnection/main.go +++ b/internal/generated/snippets/edgecontainer/apiv1/Client/CreateVpnConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgecontainer/apiv1/Client/DeleteCluster/main.go b/internal/generated/snippets/edgecontainer/apiv1/Client/DeleteCluster/main.go index 679094536208..c240b424ae79 100644 --- a/internal/generated/snippets/edgecontainer/apiv1/Client/DeleteCluster/main.go +++ b/internal/generated/snippets/edgecontainer/apiv1/Client/DeleteCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgecontainer/apiv1/Client/DeleteNodePool/main.go b/internal/generated/snippets/edgecontainer/apiv1/Client/DeleteNodePool/main.go index e3951ecb508f..57cd0ea56d37 100644 --- a/internal/generated/snippets/edgecontainer/apiv1/Client/DeleteNodePool/main.go +++ b/internal/generated/snippets/edgecontainer/apiv1/Client/DeleteNodePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgecontainer/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/edgecontainer/apiv1/Client/DeleteOperation/main.go index 7faeda1d3088..383015d7028d 100644 --- a/internal/generated/snippets/edgecontainer/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/edgecontainer/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgecontainer/apiv1/Client/DeleteVpnConnection/main.go b/internal/generated/snippets/edgecontainer/apiv1/Client/DeleteVpnConnection/main.go index 54a3b1ec4a8d..667b1551b41f 100644 --- a/internal/generated/snippets/edgecontainer/apiv1/Client/DeleteVpnConnection/main.go +++ b/internal/generated/snippets/edgecontainer/apiv1/Client/DeleteVpnConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgecontainer/apiv1/Client/GenerateAccessToken/main.go b/internal/generated/snippets/edgecontainer/apiv1/Client/GenerateAccessToken/main.go index 04858eeb9d2a..827c43c3a65d 100644 --- a/internal/generated/snippets/edgecontainer/apiv1/Client/GenerateAccessToken/main.go +++ b/internal/generated/snippets/edgecontainer/apiv1/Client/GenerateAccessToken/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgecontainer/apiv1/Client/GenerateOfflineCredential/main.go b/internal/generated/snippets/edgecontainer/apiv1/Client/GenerateOfflineCredential/main.go index 06ad65e4eafc..141346c584ad 100644 --- a/internal/generated/snippets/edgecontainer/apiv1/Client/GenerateOfflineCredential/main.go +++ b/internal/generated/snippets/edgecontainer/apiv1/Client/GenerateOfflineCredential/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgecontainer/apiv1/Client/GetCluster/main.go b/internal/generated/snippets/edgecontainer/apiv1/Client/GetCluster/main.go index 91af1527996a..ea64a622e37d 100644 --- a/internal/generated/snippets/edgecontainer/apiv1/Client/GetCluster/main.go +++ b/internal/generated/snippets/edgecontainer/apiv1/Client/GetCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgecontainer/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/edgecontainer/apiv1/Client/GetLocation/main.go index 6d9a925e3e7c..7d3214dcfd7c 100644 --- a/internal/generated/snippets/edgecontainer/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/edgecontainer/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgecontainer/apiv1/Client/GetMachine/main.go b/internal/generated/snippets/edgecontainer/apiv1/Client/GetMachine/main.go index ca1f18b56023..cf40ca5bcc9a 100644 --- a/internal/generated/snippets/edgecontainer/apiv1/Client/GetMachine/main.go +++ b/internal/generated/snippets/edgecontainer/apiv1/Client/GetMachine/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgecontainer/apiv1/Client/GetNodePool/main.go b/internal/generated/snippets/edgecontainer/apiv1/Client/GetNodePool/main.go index 7037d412e0ff..249fccfdb161 100644 --- a/internal/generated/snippets/edgecontainer/apiv1/Client/GetNodePool/main.go +++ b/internal/generated/snippets/edgecontainer/apiv1/Client/GetNodePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgecontainer/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/edgecontainer/apiv1/Client/GetOperation/main.go index 87a8ab0a1982..6685281148a8 100644 --- a/internal/generated/snippets/edgecontainer/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/edgecontainer/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgecontainer/apiv1/Client/GetServerConfig/main.go b/internal/generated/snippets/edgecontainer/apiv1/Client/GetServerConfig/main.go index 2b28721c168f..43a6867f439b 100644 --- a/internal/generated/snippets/edgecontainer/apiv1/Client/GetServerConfig/main.go +++ b/internal/generated/snippets/edgecontainer/apiv1/Client/GetServerConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgecontainer/apiv1/Client/GetVpnConnection/main.go b/internal/generated/snippets/edgecontainer/apiv1/Client/GetVpnConnection/main.go index f451963d683f..642eb37bb8bf 100644 --- a/internal/generated/snippets/edgecontainer/apiv1/Client/GetVpnConnection/main.go +++ b/internal/generated/snippets/edgecontainer/apiv1/Client/GetVpnConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgecontainer/apiv1/Client/ListClusters/main.go b/internal/generated/snippets/edgecontainer/apiv1/Client/ListClusters/main.go index d98fd8a90453..3e1357f68e20 100644 --- a/internal/generated/snippets/edgecontainer/apiv1/Client/ListClusters/main.go +++ b/internal/generated/snippets/edgecontainer/apiv1/Client/ListClusters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgecontainer/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/edgecontainer/apiv1/Client/ListLocations/main.go index 732259ba0624..93262939717d 100644 --- a/internal/generated/snippets/edgecontainer/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/edgecontainer/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgecontainer/apiv1/Client/ListMachines/main.go b/internal/generated/snippets/edgecontainer/apiv1/Client/ListMachines/main.go index e73d5daaa9c9..aba03f3d4e92 100644 --- a/internal/generated/snippets/edgecontainer/apiv1/Client/ListMachines/main.go +++ b/internal/generated/snippets/edgecontainer/apiv1/Client/ListMachines/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgecontainer/apiv1/Client/ListNodePools/main.go b/internal/generated/snippets/edgecontainer/apiv1/Client/ListNodePools/main.go index 327eaf6cc6d7..c6f3b3d305d4 100644 --- a/internal/generated/snippets/edgecontainer/apiv1/Client/ListNodePools/main.go +++ b/internal/generated/snippets/edgecontainer/apiv1/Client/ListNodePools/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgecontainer/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/edgecontainer/apiv1/Client/ListOperations/main.go index 4813871be50a..e350fe1dfd2e 100644 --- a/internal/generated/snippets/edgecontainer/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/edgecontainer/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgecontainer/apiv1/Client/ListVpnConnections/main.go b/internal/generated/snippets/edgecontainer/apiv1/Client/ListVpnConnections/main.go index 7c312b990598..bc2f35bd5772 100644 --- a/internal/generated/snippets/edgecontainer/apiv1/Client/ListVpnConnections/main.go +++ b/internal/generated/snippets/edgecontainer/apiv1/Client/ListVpnConnections/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgecontainer/apiv1/Client/UpdateCluster/main.go b/internal/generated/snippets/edgecontainer/apiv1/Client/UpdateCluster/main.go index 0cde0d376e7f..b798bf960a67 100644 --- a/internal/generated/snippets/edgecontainer/apiv1/Client/UpdateCluster/main.go +++ b/internal/generated/snippets/edgecontainer/apiv1/Client/UpdateCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgecontainer/apiv1/Client/UpdateNodePool/main.go b/internal/generated/snippets/edgecontainer/apiv1/Client/UpdateNodePool/main.go index 84442a55bfd9..ba9164241a49 100644 --- a/internal/generated/snippets/edgecontainer/apiv1/Client/UpdateNodePool/main.go +++ b/internal/generated/snippets/edgecontainer/apiv1/Client/UpdateNodePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgecontainer/apiv1/Client/UpgradeCluster/main.go b/internal/generated/snippets/edgecontainer/apiv1/Client/UpgradeCluster/main.go index c58ac63a00b9..8e0dfbd9bdf2 100644 --- a/internal/generated/snippets/edgecontainer/apiv1/Client/UpgradeCluster/main.go +++ b/internal/generated/snippets/edgecontainer/apiv1/Client/UpgradeCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgecontainer/apiv1/snippet_metadata.google.cloud.edgecontainer.v1.json b/internal/generated/snippets/edgecontainer/apiv1/snippet_metadata.google.cloud.edgecontainer.v1.json index 1e5a279512fd..b026b5c25464 100644 --- a/internal/generated/snippets/edgecontainer/apiv1/snippet_metadata.google.cloud.edgecontainer.v1.json +++ b/internal/generated/snippets/edgecontainer/apiv1/snippet_metadata.google.cloud.edgecontainer.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/edgecontainer/apiv1", - "version": "1.4.0", + "version": "1.4.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/CancelOperation/main.go index d8a14c1a4ac7..1215f774c20d 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/CreateInterconnectAttachment/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/CreateInterconnectAttachment/main.go index f1e9c8eaf8bc..b96f9eac6017 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/CreateInterconnectAttachment/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/CreateInterconnectAttachment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/CreateNetwork/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/CreateNetwork/main.go index 89a701893a7a..54e6183b5396 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/CreateNetwork/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/CreateNetwork/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/CreateRouter/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/CreateRouter/main.go index 9ea5854c28d3..68ee5f75c9e6 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/CreateRouter/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/CreateRouter/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/CreateSubnet/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/CreateSubnet/main.go index 73ad2a70f3c2..7f116220a38d 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/CreateSubnet/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/CreateSubnet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/DeleteInterconnectAttachment/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/DeleteInterconnectAttachment/main.go index d6f310fdf86a..b41846337673 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/DeleteInterconnectAttachment/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/DeleteInterconnectAttachment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/DeleteNetwork/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/DeleteNetwork/main.go index 3f650b538afa..a57334cdab75 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/DeleteNetwork/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/DeleteNetwork/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/DeleteOperation/main.go index dc310c4e9670..0b70f2b22bb4 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/DeleteRouter/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/DeleteRouter/main.go index 504fc96fa77d..984d3eb9640a 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/DeleteRouter/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/DeleteRouter/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/DeleteSubnet/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/DeleteSubnet/main.go index eebac76d7030..74de5afbf35a 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/DeleteSubnet/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/DeleteSubnet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/DiagnoseInterconnect/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/DiagnoseInterconnect/main.go index ae5e1b3c3070..800d9956b04b 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/DiagnoseInterconnect/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/DiagnoseInterconnect/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/DiagnoseNetwork/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/DiagnoseNetwork/main.go index b2d3e8e7cc05..61fd85303a5f 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/DiagnoseNetwork/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/DiagnoseNetwork/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/DiagnoseRouter/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/DiagnoseRouter/main.go index ba403ac113b7..9fd1ef1eebf4 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/DiagnoseRouter/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/DiagnoseRouter/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/GetInterconnect/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/GetInterconnect/main.go index ebf5c88fca47..92980da57d41 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/GetInterconnect/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/GetInterconnect/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/GetInterconnectAttachment/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/GetInterconnectAttachment/main.go index 5c0f347e184e..8c143182c04a 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/GetInterconnectAttachment/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/GetInterconnectAttachment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/GetLocation/main.go index d3d890206a99..d6bbb4fbe760 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/GetNetwork/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/GetNetwork/main.go index 8046c4ea6635..13556c194b1c 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/GetNetwork/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/GetNetwork/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/GetOperation/main.go index 5460f00c0a7a..0efc73b0ba1b 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/GetRouter/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/GetRouter/main.go index 6d3d5ecc6b7c..45df3e0981a6 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/GetRouter/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/GetRouter/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/GetSubnet/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/GetSubnet/main.go index 986390a030a4..8dc44dbe512b 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/GetSubnet/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/GetSubnet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/GetZone/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/GetZone/main.go index e6833aaefda0..0b766b1259e9 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/GetZone/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/GetZone/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/InitializeZone/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/InitializeZone/main.go index 5b6d82ac3264..b400aa8e7200 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/InitializeZone/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/InitializeZone/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/ListInterconnectAttachments/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/ListInterconnectAttachments/main.go index 7d0c94df1672..73d897ef33d7 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/ListInterconnectAttachments/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/ListInterconnectAttachments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/ListInterconnects/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/ListInterconnects/main.go index 836aa1776899..39f2b172d513 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/ListInterconnects/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/ListInterconnects/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/ListLocations/main.go index 43004ba92d5a..96cc85877db5 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/ListNetworks/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/ListNetworks/main.go index 767921ee4cc8..d383cc41fc9d 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/ListNetworks/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/ListNetworks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/ListOperations/main.go index 25986de4cd2b..77126192c58a 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/ListRouters/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/ListRouters/main.go index 185f16ec9e11..34bdb371faef 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/ListRouters/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/ListRouters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/ListSubnets/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/ListSubnets/main.go index afb4b1423ca1..7e07e0a7414d 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/ListSubnets/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/ListSubnets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/ListZones/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/ListZones/main.go index e5ec04144111..93e6745827f5 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/ListZones/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/ListZones/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/UpdateRouter/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/UpdateRouter/main.go index 33934f8e815c..f87a674d64a3 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/UpdateRouter/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/UpdateRouter/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/Client/UpdateSubnet/main.go b/internal/generated/snippets/edgenetwork/apiv1/Client/UpdateSubnet/main.go index af1c905efd4a..eca79c8a68e7 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/Client/UpdateSubnet/main.go +++ b/internal/generated/snippets/edgenetwork/apiv1/Client/UpdateSubnet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/edgenetwork/apiv1/snippet_metadata.google.cloud.edgenetwork.v1.json b/internal/generated/snippets/edgenetwork/apiv1/snippet_metadata.google.cloud.edgenetwork.v1.json index 1634b83c9969..ba936cdb9dee 100644 --- a/internal/generated/snippets/edgenetwork/apiv1/snippet_metadata.google.cloud.edgenetwork.v1.json +++ b/internal/generated/snippets/edgenetwork/apiv1/snippet_metadata.google.cloud.edgenetwork.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/edgenetwork/apiv1", - "version": "1.2.2", + "version": "1.2.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/essentialcontacts/apiv1/Client/ComputeContacts/main.go b/internal/generated/snippets/essentialcontacts/apiv1/Client/ComputeContacts/main.go index cab6c6e88ae5..f5487a67ee7c 100644 --- a/internal/generated/snippets/essentialcontacts/apiv1/Client/ComputeContacts/main.go +++ b/internal/generated/snippets/essentialcontacts/apiv1/Client/ComputeContacts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/essentialcontacts/apiv1/Client/CreateContact/main.go b/internal/generated/snippets/essentialcontacts/apiv1/Client/CreateContact/main.go index ea5e9d47ddf9..2462caf64cfc 100644 --- a/internal/generated/snippets/essentialcontacts/apiv1/Client/CreateContact/main.go +++ b/internal/generated/snippets/essentialcontacts/apiv1/Client/CreateContact/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/essentialcontacts/apiv1/Client/DeleteContact/main.go b/internal/generated/snippets/essentialcontacts/apiv1/Client/DeleteContact/main.go index 4ee2ae57873e..148fc70b83b8 100644 --- a/internal/generated/snippets/essentialcontacts/apiv1/Client/DeleteContact/main.go +++ b/internal/generated/snippets/essentialcontacts/apiv1/Client/DeleteContact/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/essentialcontacts/apiv1/Client/GetContact/main.go b/internal/generated/snippets/essentialcontacts/apiv1/Client/GetContact/main.go index f489ce914c72..fa7d440a9170 100644 --- a/internal/generated/snippets/essentialcontacts/apiv1/Client/GetContact/main.go +++ b/internal/generated/snippets/essentialcontacts/apiv1/Client/GetContact/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/essentialcontacts/apiv1/Client/ListContacts/main.go b/internal/generated/snippets/essentialcontacts/apiv1/Client/ListContacts/main.go index e0a1cd95079c..aee5ac4980ad 100644 --- a/internal/generated/snippets/essentialcontacts/apiv1/Client/ListContacts/main.go +++ b/internal/generated/snippets/essentialcontacts/apiv1/Client/ListContacts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/essentialcontacts/apiv1/Client/SendTestMessage/main.go b/internal/generated/snippets/essentialcontacts/apiv1/Client/SendTestMessage/main.go index 37487a602bf5..35539187b993 100644 --- a/internal/generated/snippets/essentialcontacts/apiv1/Client/SendTestMessage/main.go +++ b/internal/generated/snippets/essentialcontacts/apiv1/Client/SendTestMessage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/essentialcontacts/apiv1/Client/UpdateContact/main.go b/internal/generated/snippets/essentialcontacts/apiv1/Client/UpdateContact/main.go index 4c04dea77ba6..47ae4c8dabf2 100644 --- a/internal/generated/snippets/essentialcontacts/apiv1/Client/UpdateContact/main.go +++ b/internal/generated/snippets/essentialcontacts/apiv1/Client/UpdateContact/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/eventarc/apiv1/Client/CancelOperation/main.go index 66d74038c4d9..081b383eae35 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/CreateChannel/main.go b/internal/generated/snippets/eventarc/apiv1/Client/CreateChannel/main.go index e4a314028e46..f4f9a71d1664 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/CreateChannel/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/CreateChannel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/CreateChannelConnection/main.go b/internal/generated/snippets/eventarc/apiv1/Client/CreateChannelConnection/main.go index 1999115ffab8..d6fec6a8afc5 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/CreateChannelConnection/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/CreateChannelConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/CreateEnrollment/main.go b/internal/generated/snippets/eventarc/apiv1/Client/CreateEnrollment/main.go index 13241b69b318..76041024cac4 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/CreateEnrollment/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/CreateEnrollment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/CreateGoogleApiSource/main.go b/internal/generated/snippets/eventarc/apiv1/Client/CreateGoogleApiSource/main.go index 36c55e0541e4..a1a8432ca6a1 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/CreateGoogleApiSource/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/CreateGoogleApiSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/CreateMessageBus/main.go b/internal/generated/snippets/eventarc/apiv1/Client/CreateMessageBus/main.go index 58c26f12d502..621c0ac73357 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/CreateMessageBus/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/CreateMessageBus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/CreatePipeline/main.go b/internal/generated/snippets/eventarc/apiv1/Client/CreatePipeline/main.go index 7823ed25576a..f53e95cb8da7 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/CreatePipeline/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/CreatePipeline/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/CreateTrigger/main.go b/internal/generated/snippets/eventarc/apiv1/Client/CreateTrigger/main.go index 478ba6df8efa..ee502a1e1490 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/CreateTrigger/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/CreateTrigger/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/DeleteChannel/main.go b/internal/generated/snippets/eventarc/apiv1/Client/DeleteChannel/main.go index 721d78be6a07..2a5d4068953c 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/DeleteChannel/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/DeleteChannel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/DeleteChannelConnection/main.go b/internal/generated/snippets/eventarc/apiv1/Client/DeleteChannelConnection/main.go index 1ace6f1d502d..f982d86ef28e 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/DeleteChannelConnection/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/DeleteChannelConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/DeleteEnrollment/main.go b/internal/generated/snippets/eventarc/apiv1/Client/DeleteEnrollment/main.go index a9945612c279..b0a93f039580 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/DeleteEnrollment/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/DeleteEnrollment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/DeleteGoogleApiSource/main.go b/internal/generated/snippets/eventarc/apiv1/Client/DeleteGoogleApiSource/main.go index 8d3eab048419..f146de30580a 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/DeleteGoogleApiSource/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/DeleteGoogleApiSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/DeleteMessageBus/main.go b/internal/generated/snippets/eventarc/apiv1/Client/DeleteMessageBus/main.go index 21be8ab00a21..4a4da270670d 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/DeleteMessageBus/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/DeleteMessageBus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/eventarc/apiv1/Client/DeleteOperation/main.go index 789f7e697ba6..6a15d1a14df3 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/DeletePipeline/main.go b/internal/generated/snippets/eventarc/apiv1/Client/DeletePipeline/main.go index 947512f4fc77..9964c692eb07 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/DeletePipeline/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/DeletePipeline/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/DeleteTrigger/main.go b/internal/generated/snippets/eventarc/apiv1/Client/DeleteTrigger/main.go index 456e92011233..de5a27bf8670 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/DeleteTrigger/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/DeleteTrigger/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/GetChannel/main.go b/internal/generated/snippets/eventarc/apiv1/Client/GetChannel/main.go index 49fcda7d5994..462511253e33 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/GetChannel/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/GetChannel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/GetChannelConnection/main.go b/internal/generated/snippets/eventarc/apiv1/Client/GetChannelConnection/main.go index d2741347032d..5d1fed5f04b8 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/GetChannelConnection/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/GetChannelConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/GetEnrollment/main.go b/internal/generated/snippets/eventarc/apiv1/Client/GetEnrollment/main.go index 0f4b1e154999..792457fdc756 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/GetEnrollment/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/GetEnrollment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/GetGoogleApiSource/main.go b/internal/generated/snippets/eventarc/apiv1/Client/GetGoogleApiSource/main.go index 3b61e2a3ee45..19ca5ee39654 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/GetGoogleApiSource/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/GetGoogleApiSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/GetGoogleChannelConfig/main.go b/internal/generated/snippets/eventarc/apiv1/Client/GetGoogleChannelConfig/main.go index 5f66c22074e9..443b71e98997 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/GetGoogleChannelConfig/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/GetGoogleChannelConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/GetIamPolicy/main.go b/internal/generated/snippets/eventarc/apiv1/Client/GetIamPolicy/main.go index 8893e492ed97..64427403a4af 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/eventarc/apiv1/Client/GetLocation/main.go index 79d74b1037ab..989407e84564 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/GetMessageBus/main.go b/internal/generated/snippets/eventarc/apiv1/Client/GetMessageBus/main.go index f0b40125db10..3809f042de38 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/GetMessageBus/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/GetMessageBus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/eventarc/apiv1/Client/GetOperation/main.go index 6cf771a3f20f..c7d78977a37a 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/GetPipeline/main.go b/internal/generated/snippets/eventarc/apiv1/Client/GetPipeline/main.go index 9df24f7680be..7cbfe5e5d9b6 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/GetPipeline/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/GetPipeline/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/GetProvider/main.go b/internal/generated/snippets/eventarc/apiv1/Client/GetProvider/main.go index 2ea72af88099..78a6c920fe40 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/GetProvider/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/GetProvider/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/GetTrigger/main.go b/internal/generated/snippets/eventarc/apiv1/Client/GetTrigger/main.go index 02d33686e479..89a36b2b0955 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/GetTrigger/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/GetTrigger/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/ListChannelConnections/main.go b/internal/generated/snippets/eventarc/apiv1/Client/ListChannelConnections/main.go index df3f9636543f..0d76bc206586 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/ListChannelConnections/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/ListChannelConnections/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/ListChannels/main.go b/internal/generated/snippets/eventarc/apiv1/Client/ListChannels/main.go index 81d29960e229..8fa143fc2cad 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/ListChannels/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/ListChannels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/ListEnrollments/main.go b/internal/generated/snippets/eventarc/apiv1/Client/ListEnrollments/main.go index d55b313445fc..49c9e50dc4ed 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/ListEnrollments/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/ListEnrollments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/ListGoogleApiSources/main.go b/internal/generated/snippets/eventarc/apiv1/Client/ListGoogleApiSources/main.go index 96b63471092d..530660910987 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/ListGoogleApiSources/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/ListGoogleApiSources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/eventarc/apiv1/Client/ListLocations/main.go index 0d7da72061de..607dcbe096eb 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/ListMessageBusEnrollments/main.go b/internal/generated/snippets/eventarc/apiv1/Client/ListMessageBusEnrollments/main.go index 7c0884c91e6c..01c50c4851b2 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/ListMessageBusEnrollments/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/ListMessageBusEnrollments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/ListMessageBuses/main.go b/internal/generated/snippets/eventarc/apiv1/Client/ListMessageBuses/main.go index 7be30a90cdc1..76c16cdc205d 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/ListMessageBuses/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/ListMessageBuses/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/eventarc/apiv1/Client/ListOperations/main.go index bc6fbabc58f3..e0eff2d20260 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/ListPipelines/main.go b/internal/generated/snippets/eventarc/apiv1/Client/ListPipelines/main.go index b0ad4305a9d1..c94e64ed7dbb 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/ListPipelines/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/ListPipelines/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/ListProviders/main.go b/internal/generated/snippets/eventarc/apiv1/Client/ListProviders/main.go index 368ef65783e9..badcb5e47721 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/ListProviders/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/ListProviders/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/ListTriggers/main.go b/internal/generated/snippets/eventarc/apiv1/Client/ListTriggers/main.go index 0f3b690d84a5..e92fc9c40c83 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/ListTriggers/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/ListTriggers/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/SetIamPolicy/main.go b/internal/generated/snippets/eventarc/apiv1/Client/SetIamPolicy/main.go index 1f33dd68695d..a057f9c2ce7a 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/TestIamPermissions/main.go b/internal/generated/snippets/eventarc/apiv1/Client/TestIamPermissions/main.go index ab7c5e868c0d..3abf9e092973 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/UpdateChannel/main.go b/internal/generated/snippets/eventarc/apiv1/Client/UpdateChannel/main.go index f3049f1e1c9d..6538a98cd937 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/UpdateChannel/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/UpdateChannel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/UpdateEnrollment/main.go b/internal/generated/snippets/eventarc/apiv1/Client/UpdateEnrollment/main.go index 8eac68045c4a..5d10a426cc6a 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/UpdateEnrollment/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/UpdateEnrollment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/UpdateGoogleApiSource/main.go b/internal/generated/snippets/eventarc/apiv1/Client/UpdateGoogleApiSource/main.go index b99392936d92..338f0aea8491 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/UpdateGoogleApiSource/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/UpdateGoogleApiSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/UpdateGoogleChannelConfig/main.go b/internal/generated/snippets/eventarc/apiv1/Client/UpdateGoogleChannelConfig/main.go index 686b3fa40a02..ab5b18ea6a7e 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/UpdateGoogleChannelConfig/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/UpdateGoogleChannelConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/UpdateMessageBus/main.go b/internal/generated/snippets/eventarc/apiv1/Client/UpdateMessageBus/main.go index dde2a178b532..7ea6285be7a3 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/UpdateMessageBus/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/UpdateMessageBus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/UpdatePipeline/main.go b/internal/generated/snippets/eventarc/apiv1/Client/UpdatePipeline/main.go index 46ff4470f5f5..f2b30d6c3313 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/UpdatePipeline/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/UpdatePipeline/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/apiv1/Client/UpdateTrigger/main.go b/internal/generated/snippets/eventarc/apiv1/Client/UpdateTrigger/main.go index 01afcd3ea819..81370c45dce9 100644 --- a/internal/generated/snippets/eventarc/apiv1/Client/UpdateTrigger/main.go +++ b/internal/generated/snippets/eventarc/apiv1/Client/UpdateTrigger/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/publishing/apiv1/PublisherClient/Publish/main.go b/internal/generated/snippets/eventarc/publishing/apiv1/PublisherClient/Publish/main.go index 1eb5e4e552c3..9ca072e8fba8 100644 --- a/internal/generated/snippets/eventarc/publishing/apiv1/PublisherClient/Publish/main.go +++ b/internal/generated/snippets/eventarc/publishing/apiv1/PublisherClient/Publish/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/publishing/apiv1/PublisherClient/PublishChannelConnectionEvents/main.go b/internal/generated/snippets/eventarc/publishing/apiv1/PublisherClient/PublishChannelConnectionEvents/main.go index a9df66b570ff..319d922c091b 100644 --- a/internal/generated/snippets/eventarc/publishing/apiv1/PublisherClient/PublishChannelConnectionEvents/main.go +++ b/internal/generated/snippets/eventarc/publishing/apiv1/PublisherClient/PublishChannelConnectionEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/eventarc/publishing/apiv1/PublisherClient/PublishEvents/main.go b/internal/generated/snippets/eventarc/publishing/apiv1/PublisherClient/PublishEvents/main.go index 01331b3a18c8..6a2157fa4107 100644 --- a/internal/generated/snippets/eventarc/publishing/apiv1/PublisherClient/PublishEvents/main.go +++ b/internal/generated/snippets/eventarc/publishing/apiv1/PublisherClient/PublishEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/CancelOperation/main.go b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/CancelOperation/main.go index bbb1117d9a8c..b1aa6aab6bd1 100644 --- a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/CancelOperation/main.go +++ b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/CreateBackup/main.go b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/CreateBackup/main.go index c9c86a79ca7f..1b203eda9667 100644 --- a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/CreateBackup/main.go +++ b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/CreateBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/CreateInstance/main.go b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/CreateInstance/main.go index a2e1e197af3f..a6fd0cc7e4ca 100644 --- a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/CreateInstance/main.go +++ b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/CreateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/CreateSnapshot/main.go b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/CreateSnapshot/main.go index 3263eab5143e..d419a27f53b4 100644 --- a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/CreateSnapshot/main.go +++ b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/CreateSnapshot/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/DeleteBackup/main.go b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/DeleteBackup/main.go index d942fb761d7b..15139b1ab2a0 100644 --- a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/DeleteBackup/main.go +++ b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/DeleteBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/DeleteInstance/main.go b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/DeleteInstance/main.go index e99fad159b1b..af09fbdad318 100644 --- a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/DeleteInstance/main.go +++ b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/DeleteInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/DeleteOperation/main.go b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/DeleteOperation/main.go index 79352ba1c721..177532198ad6 100644 --- a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/DeleteOperation/main.go +++ b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/DeleteSnapshot/main.go b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/DeleteSnapshot/main.go index 9c9b4b431af4..5b1cd78710a3 100644 --- a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/DeleteSnapshot/main.go +++ b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/DeleteSnapshot/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/GetBackup/main.go b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/GetBackup/main.go index 3892fc33651e..27ff2e1f073f 100644 --- a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/GetBackup/main.go +++ b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/GetBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/GetInstance/main.go b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/GetInstance/main.go index 08b71098418e..e3d5fbfe5933 100644 --- a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/GetInstance/main.go +++ b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/GetInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/GetLocation/main.go b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/GetLocation/main.go index 0b6b0288d4db..3e4747d3333b 100644 --- a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/GetLocation/main.go +++ b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/GetOperation/main.go b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/GetOperation/main.go index 87c2cdf57313..960e574cad15 100644 --- a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/GetOperation/main.go +++ b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/GetSnapshot/main.go b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/GetSnapshot/main.go index dfcbeb4e6502..590c70ca91bf 100644 --- a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/GetSnapshot/main.go +++ b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/GetSnapshot/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/ListBackups/main.go b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/ListBackups/main.go index 0f1a9c6f6646..f28d5016c8d3 100644 --- a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/ListBackups/main.go +++ b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/ListBackups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/ListInstances/main.go b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/ListInstances/main.go index e60f2ab02415..0931e714ed48 100644 --- a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/ListInstances/main.go +++ b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/ListInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/ListLocations/main.go b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/ListLocations/main.go index 65e474473b0e..9d5a98254cd3 100644 --- a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/ListLocations/main.go +++ b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/ListOperations/main.go b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/ListOperations/main.go index 254c9ebd1840..bee0627470f5 100644 --- a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/ListOperations/main.go +++ b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/ListSnapshots/main.go b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/ListSnapshots/main.go index 5f64905b6700..66952a5114d2 100644 --- a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/ListSnapshots/main.go +++ b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/ListSnapshots/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/RestoreInstance/main.go b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/RestoreInstance/main.go index a8a6da39e827..81054fa60fab 100644 --- a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/RestoreInstance/main.go +++ b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/RestoreInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/RevertInstance/main.go b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/RevertInstance/main.go index 925669171dd8..17460197eb62 100644 --- a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/RevertInstance/main.go +++ b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/RevertInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/UpdateBackup/main.go b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/UpdateBackup/main.go index 3b0ca1efbb96..d408c5616ce2 100644 --- a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/UpdateBackup/main.go +++ b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/UpdateBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/UpdateInstance/main.go b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/UpdateInstance/main.go index d583a0dfe8b6..ffe43c852404 100644 --- a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/UpdateInstance/main.go +++ b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/UpdateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/UpdateSnapshot/main.go b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/UpdateSnapshot/main.go index da8c9c9bc208..600a17f3e5a3 100644 --- a/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/UpdateSnapshot/main.go +++ b/internal/generated/snippets/filestore/apiv1/CloudFilestoreManagerClient/UpdateSnapshot/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/filestore/apiv1/snippet_metadata.google.cloud.filestore.v1.json b/internal/generated/snippets/filestore/apiv1/snippet_metadata.google.cloud.filestore.v1.json index 4ecf12e6eb05..4e686b976358 100644 --- a/internal/generated/snippets/filestore/apiv1/snippet_metadata.google.cloud.filestore.v1.json +++ b/internal/generated/snippets/filestore/apiv1/snippet_metadata.google.cloud.filestore.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/filestore/apiv1", - "version": "1.9.2", + "version": "1.9.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/firestore/apiv1/Client/BatchWrite/main.go b/internal/generated/snippets/firestore/apiv1/Client/BatchWrite/main.go index 1a92bbd6a445..3ed83dee333f 100644 --- a/internal/generated/snippets/firestore/apiv1/Client/BatchWrite/main.go +++ b/internal/generated/snippets/firestore/apiv1/Client/BatchWrite/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/Client/BeginTransaction/main.go b/internal/generated/snippets/firestore/apiv1/Client/BeginTransaction/main.go index 37f5d63b9f39..c7c631a49f1f 100644 --- a/internal/generated/snippets/firestore/apiv1/Client/BeginTransaction/main.go +++ b/internal/generated/snippets/firestore/apiv1/Client/BeginTransaction/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/firestore/apiv1/Client/CancelOperation/main.go index edc78bb3db92..57f9f8cdf97c 100644 --- a/internal/generated/snippets/firestore/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/firestore/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/Client/Commit/main.go b/internal/generated/snippets/firestore/apiv1/Client/Commit/main.go index cc4dc64a5b00..b1d4e3cdc0ef 100644 --- a/internal/generated/snippets/firestore/apiv1/Client/Commit/main.go +++ b/internal/generated/snippets/firestore/apiv1/Client/Commit/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/Client/CreateDocument/main.go b/internal/generated/snippets/firestore/apiv1/Client/CreateDocument/main.go index 68c9b6ebc1fa..354617ca6e6b 100644 --- a/internal/generated/snippets/firestore/apiv1/Client/CreateDocument/main.go +++ b/internal/generated/snippets/firestore/apiv1/Client/CreateDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/Client/DeleteDocument/main.go b/internal/generated/snippets/firestore/apiv1/Client/DeleteDocument/main.go index 9e6c7e086e25..c16bd6aa7a01 100644 --- a/internal/generated/snippets/firestore/apiv1/Client/DeleteDocument/main.go +++ b/internal/generated/snippets/firestore/apiv1/Client/DeleteDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/firestore/apiv1/Client/DeleteOperation/main.go index 314064f58daa..46c0bd3094a4 100644 --- a/internal/generated/snippets/firestore/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/firestore/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/Client/GetDocument/main.go b/internal/generated/snippets/firestore/apiv1/Client/GetDocument/main.go index bef81f10634f..0d149292db08 100644 --- a/internal/generated/snippets/firestore/apiv1/Client/GetDocument/main.go +++ b/internal/generated/snippets/firestore/apiv1/Client/GetDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/firestore/apiv1/Client/GetOperation/main.go index 2c7c03c1b5d8..bab4f2a5cc42 100644 --- a/internal/generated/snippets/firestore/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/firestore/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/Client/ListCollectionIds/main.go b/internal/generated/snippets/firestore/apiv1/Client/ListCollectionIds/main.go index 7f7e31805031..cddfa692abc0 100644 --- a/internal/generated/snippets/firestore/apiv1/Client/ListCollectionIds/main.go +++ b/internal/generated/snippets/firestore/apiv1/Client/ListCollectionIds/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/Client/ListDocuments/main.go b/internal/generated/snippets/firestore/apiv1/Client/ListDocuments/main.go index b25967c2a7bf..6208ec7db42c 100644 --- a/internal/generated/snippets/firestore/apiv1/Client/ListDocuments/main.go +++ b/internal/generated/snippets/firestore/apiv1/Client/ListDocuments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/firestore/apiv1/Client/ListOperations/main.go index 477ca7b14950..168a4c13723a 100644 --- a/internal/generated/snippets/firestore/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/firestore/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/Client/Listen/main.go b/internal/generated/snippets/firestore/apiv1/Client/Listen/main.go index 836c8bcf46e4..dd18eeb7a58c 100644 --- a/internal/generated/snippets/firestore/apiv1/Client/Listen/main.go +++ b/internal/generated/snippets/firestore/apiv1/Client/Listen/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/Client/PartitionQuery/main.go b/internal/generated/snippets/firestore/apiv1/Client/PartitionQuery/main.go index 061536f8f673..dc7b20649aac 100644 --- a/internal/generated/snippets/firestore/apiv1/Client/PartitionQuery/main.go +++ b/internal/generated/snippets/firestore/apiv1/Client/PartitionQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/Client/Rollback/main.go b/internal/generated/snippets/firestore/apiv1/Client/Rollback/main.go index 9da7e4735c14..45450fc08168 100644 --- a/internal/generated/snippets/firestore/apiv1/Client/Rollback/main.go +++ b/internal/generated/snippets/firestore/apiv1/Client/Rollback/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/Client/UpdateDocument/main.go b/internal/generated/snippets/firestore/apiv1/Client/UpdateDocument/main.go index 9d35987bb44a..cfa7da5eb28a 100644 --- a/internal/generated/snippets/firestore/apiv1/Client/UpdateDocument/main.go +++ b/internal/generated/snippets/firestore/apiv1/Client/UpdateDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/Client/Write/main.go b/internal/generated/snippets/firestore/apiv1/Client/Write/main.go index b6c2dc567839..14b2c125ba16 100644 --- a/internal/generated/snippets/firestore/apiv1/Client/Write/main.go +++ b/internal/generated/snippets/firestore/apiv1/Client/Write/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/BulkDeleteDocuments/main.go b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/BulkDeleteDocuments/main.go index 35b5581ca183..d4d47bf2be9f 100644 --- a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/BulkDeleteDocuments/main.go +++ b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/BulkDeleteDocuments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/CancelOperation/main.go b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/CancelOperation/main.go index ff6e9177d6d9..803dec1d4906 100644 --- a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/CancelOperation/main.go +++ b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/CreateBackupSchedule/main.go b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/CreateBackupSchedule/main.go index b488bb21405d..165d771be6af 100644 --- a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/CreateBackupSchedule/main.go +++ b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/CreateBackupSchedule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/CreateDatabase/main.go b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/CreateDatabase/main.go index fea36b4b7e5b..4445dc69de3b 100644 --- a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/CreateDatabase/main.go +++ b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/CreateDatabase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/CreateIndex/main.go b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/CreateIndex/main.go index 54a317c494e8..543ffab6938d 100644 --- a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/CreateIndex/main.go +++ b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/CreateIndex/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/DeleteBackup/main.go b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/DeleteBackup/main.go index 2bf3d721399e..ed51859cbe55 100644 --- a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/DeleteBackup/main.go +++ b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/DeleteBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/DeleteBackupSchedule/main.go b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/DeleteBackupSchedule/main.go index 5133df999465..19ef925a9628 100644 --- a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/DeleteBackupSchedule/main.go +++ b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/DeleteBackupSchedule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/DeleteDatabase/main.go b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/DeleteDatabase/main.go index 4e8fcf2d11c1..68400b50eb41 100644 --- a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/DeleteDatabase/main.go +++ b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/DeleteDatabase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/DeleteIndex/main.go b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/DeleteIndex/main.go index e3eff1bd8494..e2ce9b290529 100644 --- a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/DeleteIndex/main.go +++ b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/DeleteIndex/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/DeleteOperation/main.go b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/DeleteOperation/main.go index 41210694ee5e..419158c0edba 100644 --- a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/DeleteOperation/main.go +++ b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ExportDocuments/main.go b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ExportDocuments/main.go index 9d122e55e9db..571269d3d767 100644 --- a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ExportDocuments/main.go +++ b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ExportDocuments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/GetBackup/main.go b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/GetBackup/main.go index e75d395a5074..d047efe2c426 100644 --- a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/GetBackup/main.go +++ b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/GetBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/GetBackupSchedule/main.go b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/GetBackupSchedule/main.go index f8f4b6579d53..3854fdb96df5 100644 --- a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/GetBackupSchedule/main.go +++ b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/GetBackupSchedule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/GetDatabase/main.go b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/GetDatabase/main.go index 8371cbb5cc4f..47e7e0300b7a 100644 --- a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/GetDatabase/main.go +++ b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/GetDatabase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/GetField/main.go b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/GetField/main.go index 7a0896cf1880..d221e9af8552 100644 --- a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/GetField/main.go +++ b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/GetField/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/GetIndex/main.go b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/GetIndex/main.go index 054bebdd8e48..37db040966d9 100644 --- a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/GetIndex/main.go +++ b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/GetIndex/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/GetOperation/main.go b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/GetOperation/main.go index 546459dc1ad9..07b587ba08c4 100644 --- a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/GetOperation/main.go +++ b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ImportDocuments/main.go b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ImportDocuments/main.go index c5c2a9d374b9..400b87346cba 100644 --- a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ImportDocuments/main.go +++ b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ImportDocuments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ListBackupSchedules/main.go b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ListBackupSchedules/main.go index f8accb4e4788..ada1f927bb95 100644 --- a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ListBackupSchedules/main.go +++ b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ListBackupSchedules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ListBackups/main.go b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ListBackups/main.go index ad854149de15..e57f5fb3ccb1 100644 --- a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ListBackups/main.go +++ b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ListBackups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ListDatabases/main.go b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ListDatabases/main.go index c5505d4426a7..27495794f724 100644 --- a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ListDatabases/main.go +++ b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ListDatabases/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ListFields/main.go b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ListFields/main.go index fd3e3306e8fa..a34825f634b4 100644 --- a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ListFields/main.go +++ b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ListFields/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ListIndexes/main.go b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ListIndexes/main.go index 80c75ade47bd..61a860baf510 100644 --- a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ListIndexes/main.go +++ b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ListIndexes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ListOperations/main.go b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ListOperations/main.go index 73f77f61ac62..6bcbd9038fd5 100644 --- a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ListOperations/main.go +++ b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/RestoreDatabase/main.go b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/RestoreDatabase/main.go index 4c9ac90109b1..d5185185b184 100644 --- a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/RestoreDatabase/main.go +++ b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/RestoreDatabase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/UpdateBackupSchedule/main.go b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/UpdateBackupSchedule/main.go index 84a5f1a63d47..ba8163014070 100644 --- a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/UpdateBackupSchedule/main.go +++ b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/UpdateBackupSchedule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/UpdateDatabase/main.go b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/UpdateDatabase/main.go index cf1a4475c835..3f78d3fe5d24 100644 --- a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/UpdateDatabase/main.go +++ b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/UpdateDatabase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/UpdateField/main.go b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/UpdateField/main.go index 30fb0c969d4c..62771e4993b6 100644 --- a/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/UpdateField/main.go +++ b/internal/generated/snippets/firestore/apiv1/admin/FirestoreAdminClient/UpdateField/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/CallFunction/main.go b/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/CallFunction/main.go index 1d80c9be9fd0..2924de17e683 100644 --- a/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/CallFunction/main.go +++ b/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/CallFunction/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/CreateFunction/main.go b/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/CreateFunction/main.go index 81d17b994d50..146ddeabae7a 100644 --- a/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/CreateFunction/main.go +++ b/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/CreateFunction/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/DeleteFunction/main.go b/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/DeleteFunction/main.go index acef2f436c4e..7994055af9ce 100644 --- a/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/DeleteFunction/main.go +++ b/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/DeleteFunction/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/GenerateDownloadUrl/main.go b/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/GenerateDownloadUrl/main.go index fde49083ddc1..0a263032208a 100644 --- a/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/GenerateDownloadUrl/main.go +++ b/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/GenerateDownloadUrl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/GenerateUploadUrl/main.go b/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/GenerateUploadUrl/main.go index c127cc4ad955..6c577d464347 100644 --- a/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/GenerateUploadUrl/main.go +++ b/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/GenerateUploadUrl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/GetFunction/main.go b/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/GetFunction/main.go index 865bd60abf56..c5fffb47b6b9 100644 --- a/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/GetFunction/main.go +++ b/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/GetFunction/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/GetIamPolicy/main.go b/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/GetIamPolicy/main.go index 36fd78d70c49..1a1b73965932 100644 --- a/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/GetOperation/main.go b/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/GetOperation/main.go index 87f933b5b36c..a6c793c41dac 100644 --- a/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/GetOperation/main.go +++ b/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/ListFunctions/main.go b/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/ListFunctions/main.go index ac54e0d4161b..c71fe9028868 100644 --- a/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/ListFunctions/main.go +++ b/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/ListFunctions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/ListLocations/main.go b/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/ListLocations/main.go index 8639ee448cdf..0abc4590b80a 100644 --- a/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/ListLocations/main.go +++ b/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/ListOperations/main.go b/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/ListOperations/main.go index 2ede8aec7fea..5d0874e0f0b6 100644 --- a/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/ListOperations/main.go +++ b/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/SetIamPolicy/main.go b/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/SetIamPolicy/main.go index ef48f32fae0a..13e41c99dc90 100644 --- a/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/TestIamPermissions/main.go b/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/TestIamPermissions/main.go index 753eac17ad7b..faaa9e436bb0 100644 --- a/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/UpdateFunction/main.go b/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/UpdateFunction/main.go index 9ff50efc69e9..9b5917bf3056 100644 --- a/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/UpdateFunction/main.go +++ b/internal/generated/snippets/functions/apiv1/CloudFunctionsClient/UpdateFunction/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv1/snippet_metadata.google.cloud.functions.v1.json b/internal/generated/snippets/functions/apiv1/snippet_metadata.google.cloud.functions.v1.json index 22020d2db312..ad8b38e4a0cc 100644 --- a/internal/generated/snippets/functions/apiv1/snippet_metadata.google.cloud.functions.v1.json +++ b/internal/generated/snippets/functions/apiv1/snippet_metadata.google.cloud.functions.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/functions/apiv1", - "version": "1.19.2", + "version": "1.19.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/functions/apiv2/FunctionClient/CreateFunction/main.go b/internal/generated/snippets/functions/apiv2/FunctionClient/CreateFunction/main.go index b8766705e9dd..b14fb3874a1b 100644 --- a/internal/generated/snippets/functions/apiv2/FunctionClient/CreateFunction/main.go +++ b/internal/generated/snippets/functions/apiv2/FunctionClient/CreateFunction/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv2/FunctionClient/DeleteFunction/main.go b/internal/generated/snippets/functions/apiv2/FunctionClient/DeleteFunction/main.go index 3db2f7eccfd5..c28176f723ae 100644 --- a/internal/generated/snippets/functions/apiv2/FunctionClient/DeleteFunction/main.go +++ b/internal/generated/snippets/functions/apiv2/FunctionClient/DeleteFunction/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv2/FunctionClient/GenerateDownloadUrl/main.go b/internal/generated/snippets/functions/apiv2/FunctionClient/GenerateDownloadUrl/main.go index 1109d861b046..3a8a2912696d 100644 --- a/internal/generated/snippets/functions/apiv2/FunctionClient/GenerateDownloadUrl/main.go +++ b/internal/generated/snippets/functions/apiv2/FunctionClient/GenerateDownloadUrl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv2/FunctionClient/GenerateUploadUrl/main.go b/internal/generated/snippets/functions/apiv2/FunctionClient/GenerateUploadUrl/main.go index 388bfc552dcf..a50c74d59234 100644 --- a/internal/generated/snippets/functions/apiv2/FunctionClient/GenerateUploadUrl/main.go +++ b/internal/generated/snippets/functions/apiv2/FunctionClient/GenerateUploadUrl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv2/FunctionClient/GetFunction/main.go b/internal/generated/snippets/functions/apiv2/FunctionClient/GetFunction/main.go index 45a9311cbc60..98bf8bb942c8 100644 --- a/internal/generated/snippets/functions/apiv2/FunctionClient/GetFunction/main.go +++ b/internal/generated/snippets/functions/apiv2/FunctionClient/GetFunction/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv2/FunctionClient/GetIamPolicy/main.go b/internal/generated/snippets/functions/apiv2/FunctionClient/GetIamPolicy/main.go index c52b56c5f485..28ee87505b32 100644 --- a/internal/generated/snippets/functions/apiv2/FunctionClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/functions/apiv2/FunctionClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv2/FunctionClient/GetOperation/main.go b/internal/generated/snippets/functions/apiv2/FunctionClient/GetOperation/main.go index d02eb6a75922..921f31d126d1 100644 --- a/internal/generated/snippets/functions/apiv2/FunctionClient/GetOperation/main.go +++ b/internal/generated/snippets/functions/apiv2/FunctionClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv2/FunctionClient/ListFunctions/main.go b/internal/generated/snippets/functions/apiv2/FunctionClient/ListFunctions/main.go index 4d4ce62d9b90..ea31f36f41d0 100644 --- a/internal/generated/snippets/functions/apiv2/FunctionClient/ListFunctions/main.go +++ b/internal/generated/snippets/functions/apiv2/FunctionClient/ListFunctions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv2/FunctionClient/ListLocations/main.go b/internal/generated/snippets/functions/apiv2/FunctionClient/ListLocations/main.go index 4b54c7a8fd20..55b08be6eb88 100644 --- a/internal/generated/snippets/functions/apiv2/FunctionClient/ListLocations/main.go +++ b/internal/generated/snippets/functions/apiv2/FunctionClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv2/FunctionClient/ListOperations/main.go b/internal/generated/snippets/functions/apiv2/FunctionClient/ListOperations/main.go index b1d6fb9b7ebd..d8fe76f936cd 100644 --- a/internal/generated/snippets/functions/apiv2/FunctionClient/ListOperations/main.go +++ b/internal/generated/snippets/functions/apiv2/FunctionClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv2/FunctionClient/ListRuntimes/main.go b/internal/generated/snippets/functions/apiv2/FunctionClient/ListRuntimes/main.go index b00a60addeff..0ceb85876cf2 100644 --- a/internal/generated/snippets/functions/apiv2/FunctionClient/ListRuntimes/main.go +++ b/internal/generated/snippets/functions/apiv2/FunctionClient/ListRuntimes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv2/FunctionClient/SetIamPolicy/main.go b/internal/generated/snippets/functions/apiv2/FunctionClient/SetIamPolicy/main.go index 255a43d844f5..0cab5ce5e498 100644 --- a/internal/generated/snippets/functions/apiv2/FunctionClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/functions/apiv2/FunctionClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv2/FunctionClient/TestIamPermissions/main.go b/internal/generated/snippets/functions/apiv2/FunctionClient/TestIamPermissions/main.go index b8bb4f66239c..e373c310c5c1 100644 --- a/internal/generated/snippets/functions/apiv2/FunctionClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/functions/apiv2/FunctionClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv2/FunctionClient/UpdateFunction/main.go b/internal/generated/snippets/functions/apiv2/FunctionClient/UpdateFunction/main.go index 671f300b7cfa..81ac6e5515d4 100644 --- a/internal/generated/snippets/functions/apiv2/FunctionClient/UpdateFunction/main.go +++ b/internal/generated/snippets/functions/apiv2/FunctionClient/UpdateFunction/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv2/snippet_metadata.google.cloud.functions.v2.json b/internal/generated/snippets/functions/apiv2/snippet_metadata.google.cloud.functions.v2.json index f118dd451d7c..49e7a62f38e6 100644 --- a/internal/generated/snippets/functions/apiv2/snippet_metadata.google.cloud.functions.v2.json +++ b/internal/generated/snippets/functions/apiv2/snippet_metadata.google.cloud.functions.v2.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/functions/apiv2", - "version": "1.19.2", + "version": "1.19.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/functions/apiv2beta/FunctionClient/CreateFunction/main.go b/internal/generated/snippets/functions/apiv2beta/FunctionClient/CreateFunction/main.go index be8c64133ee2..77ee312f475a 100644 --- a/internal/generated/snippets/functions/apiv2beta/FunctionClient/CreateFunction/main.go +++ b/internal/generated/snippets/functions/apiv2beta/FunctionClient/CreateFunction/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv2beta/FunctionClient/DeleteFunction/main.go b/internal/generated/snippets/functions/apiv2beta/FunctionClient/DeleteFunction/main.go index 4047de92437c..12b22c7838a2 100644 --- a/internal/generated/snippets/functions/apiv2beta/FunctionClient/DeleteFunction/main.go +++ b/internal/generated/snippets/functions/apiv2beta/FunctionClient/DeleteFunction/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv2beta/FunctionClient/GenerateDownloadUrl/main.go b/internal/generated/snippets/functions/apiv2beta/FunctionClient/GenerateDownloadUrl/main.go index 9d4f6587a80b..a23f9ba86d10 100644 --- a/internal/generated/snippets/functions/apiv2beta/FunctionClient/GenerateDownloadUrl/main.go +++ b/internal/generated/snippets/functions/apiv2beta/FunctionClient/GenerateDownloadUrl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv2beta/FunctionClient/GenerateUploadUrl/main.go b/internal/generated/snippets/functions/apiv2beta/FunctionClient/GenerateUploadUrl/main.go index 3b5ad9477f64..4a572aff5930 100644 --- a/internal/generated/snippets/functions/apiv2beta/FunctionClient/GenerateUploadUrl/main.go +++ b/internal/generated/snippets/functions/apiv2beta/FunctionClient/GenerateUploadUrl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv2beta/FunctionClient/GetFunction/main.go b/internal/generated/snippets/functions/apiv2beta/FunctionClient/GetFunction/main.go index 8f6dd3240772..f68663946deb 100644 --- a/internal/generated/snippets/functions/apiv2beta/FunctionClient/GetFunction/main.go +++ b/internal/generated/snippets/functions/apiv2beta/FunctionClient/GetFunction/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv2beta/FunctionClient/GetIamPolicy/main.go b/internal/generated/snippets/functions/apiv2beta/FunctionClient/GetIamPolicy/main.go index 73e4745f0b08..7b9f28643c59 100644 --- a/internal/generated/snippets/functions/apiv2beta/FunctionClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/functions/apiv2beta/FunctionClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv2beta/FunctionClient/GetOperation/main.go b/internal/generated/snippets/functions/apiv2beta/FunctionClient/GetOperation/main.go index 69b7315eda7c..1f35784c6992 100644 --- a/internal/generated/snippets/functions/apiv2beta/FunctionClient/GetOperation/main.go +++ b/internal/generated/snippets/functions/apiv2beta/FunctionClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv2beta/FunctionClient/ListFunctions/main.go b/internal/generated/snippets/functions/apiv2beta/FunctionClient/ListFunctions/main.go index dc4cc01b62af..22baaadb7c87 100644 --- a/internal/generated/snippets/functions/apiv2beta/FunctionClient/ListFunctions/main.go +++ b/internal/generated/snippets/functions/apiv2beta/FunctionClient/ListFunctions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv2beta/FunctionClient/ListLocations/main.go b/internal/generated/snippets/functions/apiv2beta/FunctionClient/ListLocations/main.go index 2d1e58ab8c33..b4ea332a155b 100644 --- a/internal/generated/snippets/functions/apiv2beta/FunctionClient/ListLocations/main.go +++ b/internal/generated/snippets/functions/apiv2beta/FunctionClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv2beta/FunctionClient/ListOperations/main.go b/internal/generated/snippets/functions/apiv2beta/FunctionClient/ListOperations/main.go index ac7f86db57fc..c1141404f062 100644 --- a/internal/generated/snippets/functions/apiv2beta/FunctionClient/ListOperations/main.go +++ b/internal/generated/snippets/functions/apiv2beta/FunctionClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv2beta/FunctionClient/ListRuntimes/main.go b/internal/generated/snippets/functions/apiv2beta/FunctionClient/ListRuntimes/main.go index e7c07ac5c320..26c91126eb4c 100644 --- a/internal/generated/snippets/functions/apiv2beta/FunctionClient/ListRuntimes/main.go +++ b/internal/generated/snippets/functions/apiv2beta/FunctionClient/ListRuntimes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv2beta/FunctionClient/SetIamPolicy/main.go b/internal/generated/snippets/functions/apiv2beta/FunctionClient/SetIamPolicy/main.go index 1652ed3ad4c9..fbb2f3e12d3b 100644 --- a/internal/generated/snippets/functions/apiv2beta/FunctionClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/functions/apiv2beta/FunctionClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv2beta/FunctionClient/TestIamPermissions/main.go b/internal/generated/snippets/functions/apiv2beta/FunctionClient/TestIamPermissions/main.go index 3b6f187eee45..9b708ce876d8 100644 --- a/internal/generated/snippets/functions/apiv2beta/FunctionClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/functions/apiv2beta/FunctionClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv2beta/FunctionClient/UpdateFunction/main.go b/internal/generated/snippets/functions/apiv2beta/FunctionClient/UpdateFunction/main.go index af4f5694829a..62af5f9a7bd6 100644 --- a/internal/generated/snippets/functions/apiv2beta/FunctionClient/UpdateFunction/main.go +++ b/internal/generated/snippets/functions/apiv2beta/FunctionClient/UpdateFunction/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/functions/apiv2beta/snippet_metadata.google.cloud.functions.v2beta.json b/internal/generated/snippets/functions/apiv2beta/snippet_metadata.google.cloud.functions.v2beta.json index f570cf6524ca..0a96d0022d55 100644 --- a/internal/generated/snippets/functions/apiv2beta/snippet_metadata.google.cloud.functions.v2beta.json +++ b/internal/generated/snippets/functions/apiv2beta/snippet_metadata.google.cloud.functions.v2beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/functions/apiv2beta", - "version": "1.19.2", + "version": "1.19.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/CancelOperation/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/CancelOperation/main.go index c8a399a15643..f814713655d4 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/CancelOperation/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/CreateBackup/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/CreateBackup/main.go index 9f4d2cc1fad3..6de210351708 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/CreateBackup/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/CreateBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/CreateBackupPlan/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/CreateBackupPlan/main.go index 6af1e1281ef0..7b309b77a82a 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/CreateBackupPlan/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/CreateBackupPlan/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/CreateRestore/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/CreateRestore/main.go index e4494ef0821f..db5d3ed54c29 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/CreateRestore/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/CreateRestore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/CreateRestorePlan/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/CreateRestorePlan/main.go index 3af8bf8c2315..de04fa38a597 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/CreateRestorePlan/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/CreateRestorePlan/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/DeleteBackup/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/DeleteBackup/main.go index eb2c1658d459..37dcf401a196 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/DeleteBackup/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/DeleteBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/DeleteBackupPlan/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/DeleteBackupPlan/main.go index 4a18d5a52d78..438fb167e418 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/DeleteBackupPlan/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/DeleteBackupPlan/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/DeleteOperation/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/DeleteOperation/main.go index 56487b627c73..54e40146d592 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/DeleteOperation/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/DeleteRestore/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/DeleteRestore/main.go index 2d7a3e301f8c..9b7ddbb775de 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/DeleteRestore/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/DeleteRestore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/DeleteRestorePlan/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/DeleteRestorePlan/main.go index 973c895741ad..587343921e2c 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/DeleteRestorePlan/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/DeleteRestorePlan/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetBackup/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetBackup/main.go index d43981371546..840642f95b49 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetBackup/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetBackupIndexDownloadUrl/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetBackupIndexDownloadUrl/main.go index 35a0083ac2ea..f50b065a3f10 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetBackupIndexDownloadUrl/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetBackupIndexDownloadUrl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetBackupPlan/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetBackupPlan/main.go index 9a39e8e10800..4757aa0b93be 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetBackupPlan/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetBackupPlan/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetIamPolicy/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetIamPolicy/main.go index dd7756e8fa53..002fb64b3fae 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetLocation/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetLocation/main.go index 842420dc2c95..792211d96240 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetLocation/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetOperation/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetOperation/main.go index c1e7c0d8196f..f12b5d109f4a 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetOperation/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetRestore/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetRestore/main.go index b0f4e0b14a35..7367dae5022e 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetRestore/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetRestore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetRestorePlan/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetRestorePlan/main.go index e8f6452d6b31..ae9a6c426a59 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetRestorePlan/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetRestorePlan/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetVolumeBackup/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetVolumeBackup/main.go index 6bd5c78a6a72..1af190d8622e 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetVolumeBackup/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetVolumeBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetVolumeRestore/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetVolumeRestore/main.go index ce96f553e44d..53763c6c1aa4 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetVolumeRestore/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/GetVolumeRestore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListBackupPlans/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListBackupPlans/main.go index 60764afa0b5b..d2cd30a05dff 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListBackupPlans/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListBackupPlans/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListBackups/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListBackups/main.go index b9135b329a1c..55ec4c8f8f45 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListBackups/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListBackups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListLocations/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListLocations/main.go index 1287b5f8bce2..c88b958fddd6 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListLocations/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListOperations/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListOperations/main.go index c79c0dddf9e0..c333c0e32871 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListOperations/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListRestorePlans/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListRestorePlans/main.go index 0c3b834ef751..5f3e926f2794 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListRestorePlans/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListRestorePlans/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListRestores/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListRestores/main.go index 7611aaa2b6f2..43e81eeee2ce 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListRestores/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListRestores/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListVolumeBackups/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListVolumeBackups/main.go index c5bfbd540ec1..f12cda06afb6 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListVolumeBackups/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListVolumeBackups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListVolumeRestores/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListVolumeRestores/main.go index e95e82496205..45ef4d493f58 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListVolumeRestores/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/ListVolumeRestores/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/SetIamPolicy/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/SetIamPolicy/main.go index b4766baffbfe..a2634712f5d5 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/TestIamPermissions/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/TestIamPermissions/main.go index 75d0dabde188..506b332c7b16 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/UpdateBackup/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/UpdateBackup/main.go index a16fb665889d..c93ca010cd4f 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/UpdateBackup/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/UpdateBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/UpdateBackupPlan/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/UpdateBackupPlan/main.go index 398933031dc7..ebf5b54b879f 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/UpdateBackupPlan/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/UpdateBackupPlan/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/UpdateRestore/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/UpdateRestore/main.go index 9ba34a93c40b..2cb664514f2b 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/UpdateRestore/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/UpdateRestore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/UpdateRestorePlan/main.go b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/UpdateRestorePlan/main.go index 7f3340e4512f..12f0e12d1934 100644 --- a/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/UpdateRestorePlan/main.go +++ b/internal/generated/snippets/gkebackup/apiv1/BackupForGKEClient/UpdateRestorePlan/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkebackup/apiv1/snippet_metadata.google.cloud.gkebackup.v1.json b/internal/generated/snippets/gkebackup/apiv1/snippet_metadata.google.cloud.gkebackup.v1.json index aa2593ab3d74..e4ee9e29fed3 100644 --- a/internal/generated/snippets/gkebackup/apiv1/snippet_metadata.google.cloud.gkebackup.v1.json +++ b/internal/generated/snippets/gkebackup/apiv1/snippet_metadata.google.cloud.gkebackup.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/gkebackup/apiv1", - "version": "1.6.2", + "version": "1.6.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/gkeconnect/gateway/apiv1/GatewayControlClient/GenerateCredentials/main.go b/internal/generated/snippets/gkeconnect/gateway/apiv1/GatewayControlClient/GenerateCredentials/main.go index 08703dcf5bed..35d0f0ab08e1 100644 --- a/internal/generated/snippets/gkeconnect/gateway/apiv1/GatewayControlClient/GenerateCredentials/main.go +++ b/internal/generated/snippets/gkeconnect/gateway/apiv1/GatewayControlClient/GenerateCredentials/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkeconnect/gateway/apiv1beta1/GatewayControlClient/GenerateCredentials/main.go b/internal/generated/snippets/gkeconnect/gateway/apiv1beta1/GatewayControlClient/GenerateCredentials/main.go index 835f08b50f7e..04ef44e225f5 100644 --- a/internal/generated/snippets/gkeconnect/gateway/apiv1beta1/GatewayControlClient/GenerateCredentials/main.go +++ b/internal/generated/snippets/gkeconnect/gateway/apiv1beta1/GatewayControlClient/GenerateCredentials/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/CancelOperation/main.go b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/CancelOperation/main.go index 6f978334a176..34438c2776a2 100644 --- a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/CancelOperation/main.go +++ b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/CreateMembership/main.go b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/CreateMembership/main.go index 31f77dffda7d..4b16b4e1bf20 100644 --- a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/CreateMembership/main.go +++ b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/CreateMembership/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/DeleteMembership/main.go b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/DeleteMembership/main.go index 0736452df214..14cb523508c0 100644 --- a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/DeleteMembership/main.go +++ b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/DeleteMembership/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/DeleteOperation/main.go b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/DeleteOperation/main.go index 622346cebce2..a31c1ebd67f5 100644 --- a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/DeleteOperation/main.go +++ b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/GenerateConnectManifest/main.go b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/GenerateConnectManifest/main.go index 059c2f699504..f659839cca6e 100644 --- a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/GenerateConnectManifest/main.go +++ b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/GenerateConnectManifest/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/GenerateExclusivityManifest/main.go b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/GenerateExclusivityManifest/main.go index d5e85aecf79c..dfa2072b60da 100644 --- a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/GenerateExclusivityManifest/main.go +++ b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/GenerateExclusivityManifest/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/GetIamPolicy/main.go b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/GetIamPolicy/main.go index d90785414ae0..f5f2d219ca2e 100644 --- a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/GetLocation/main.go b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/GetLocation/main.go index 58a39cf2e3a9..1003be01338c 100644 --- a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/GetLocation/main.go +++ b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/GetMembership/main.go b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/GetMembership/main.go index 3ca95c6357a6..d548698518d4 100644 --- a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/GetMembership/main.go +++ b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/GetMembership/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/GetOperation/main.go b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/GetOperation/main.go index dee91c0f6cf3..de86807b3550 100644 --- a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/GetOperation/main.go +++ b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/ListLocations/main.go b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/ListLocations/main.go index 3aea83771796..ccd245981885 100644 --- a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/ListLocations/main.go +++ b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/ListMemberships/main.go b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/ListMemberships/main.go index fc22c0ec956d..2d09b5bae3ba 100644 --- a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/ListMemberships/main.go +++ b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/ListMemberships/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/ListOperations/main.go b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/ListOperations/main.go index 5bd03b485a39..a5d6b6504929 100644 --- a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/ListOperations/main.go +++ b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/SetIamPolicy/main.go b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/SetIamPolicy/main.go index dc77ad7270eb..2c51bfa8395e 100644 --- a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/TestIamPermissions/main.go b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/TestIamPermissions/main.go index 580b84d0d38d..208c504f20c9 100644 --- a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/UpdateMembership/main.go b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/UpdateMembership/main.go index f3afd22e201f..4f041d77a4c7 100644 --- a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/UpdateMembership/main.go +++ b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/UpdateMembership/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/ValidateExclusivity/main.go b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/ValidateExclusivity/main.go index c2f70bd2e27d..58030d54758b 100644 --- a/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/ValidateExclusivity/main.go +++ b/internal/generated/snippets/gkehub/apiv1beta1/GkeHubMembershipClient/ValidateExclusivity/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/CancelOperation/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/CancelOperation/main.go index 684d9c40101b..1bfd8c82ccfb 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/CancelOperation/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/CreateAttachedCluster/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/CreateAttachedCluster/main.go index 4964900e2963..0db4c1c0d8d4 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/CreateAttachedCluster/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/CreateAttachedCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/DeleteAttachedCluster/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/DeleteAttachedCluster/main.go index 93bfdecec6ec..702e9b7e0586 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/DeleteAttachedCluster/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/DeleteAttachedCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/DeleteOperation/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/DeleteOperation/main.go index e5bca37c82f8..9dbc0c0604de 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/DeleteOperation/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/GenerateAttachedClusterAgentToken/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/GenerateAttachedClusterAgentToken/main.go index 71c6670c2c46..5a6b4a85ffa8 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/GenerateAttachedClusterAgentToken/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/GenerateAttachedClusterAgentToken/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/GenerateAttachedClusterInstallManifest/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/GenerateAttachedClusterInstallManifest/main.go index 5708408b2bb9..327bb52acba1 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/GenerateAttachedClusterInstallManifest/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/GenerateAttachedClusterInstallManifest/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/GetAttachedCluster/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/GetAttachedCluster/main.go index 28c4a2766e19..89b7761c5cb5 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/GetAttachedCluster/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/GetAttachedCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/GetAttachedServerConfig/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/GetAttachedServerConfig/main.go index 4962935e90fe..0bfd37483bc4 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/GetAttachedServerConfig/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/GetAttachedServerConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/GetOperation/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/GetOperation/main.go index 269f60047d73..a7004fc291e7 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/GetOperation/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/ImportAttachedCluster/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/ImportAttachedCluster/main.go index d969f50a8738..b1583511e41a 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/ImportAttachedCluster/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/ImportAttachedCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/ListAttachedClusters/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/ListAttachedClusters/main.go index 6c7e9c88660b..20d72bf4172e 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/ListAttachedClusters/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/ListAttachedClusters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/ListOperations/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/ListOperations/main.go index 8ed3f6338e56..7e0b8d7260a5 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/ListOperations/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/UpdateAttachedCluster/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/UpdateAttachedCluster/main.go index eacfe80994d8..dd7230decd03 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/UpdateAttachedCluster/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AttachedClustersClient/UpdateAttachedCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/CancelOperation/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/CancelOperation/main.go index 4b2890d3b39e..9f14491a229d 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/CancelOperation/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/CreateAwsCluster/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/CreateAwsCluster/main.go index 3c4d9284425f..687338b610f3 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/CreateAwsCluster/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/CreateAwsCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/CreateAwsNodePool/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/CreateAwsNodePool/main.go index 81d76cf72788..229267ab8115 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/CreateAwsNodePool/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/CreateAwsNodePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/DeleteAwsCluster/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/DeleteAwsCluster/main.go index 4ecf3226af73..5e2e3bb91e66 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/DeleteAwsCluster/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/DeleteAwsCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/DeleteAwsNodePool/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/DeleteAwsNodePool/main.go index 88ccdb5989a9..f26f088d8f84 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/DeleteAwsNodePool/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/DeleteAwsNodePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/DeleteOperation/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/DeleteOperation/main.go index 845396d1c25e..f9980c02b5d0 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/DeleteOperation/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GenerateAwsAccessToken/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GenerateAwsAccessToken/main.go index 18b3024138cb..56ca526a3cef 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GenerateAwsAccessToken/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GenerateAwsAccessToken/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GenerateAwsClusterAgentToken/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GenerateAwsClusterAgentToken/main.go index de2910345353..46dd04b190fe 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GenerateAwsClusterAgentToken/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GenerateAwsClusterAgentToken/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GetAwsCluster/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GetAwsCluster/main.go index dc744eb34d65..89f4fc79b0a4 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GetAwsCluster/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GetAwsCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GetAwsJsonWebKeys/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GetAwsJsonWebKeys/main.go index 0e39a60c170f..3c0382cbcf20 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GetAwsJsonWebKeys/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GetAwsJsonWebKeys/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GetAwsNodePool/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GetAwsNodePool/main.go index 295f9dd07a0c..38fee98e5710 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GetAwsNodePool/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GetAwsNodePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GetAwsOpenIdConfig/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GetAwsOpenIdConfig/main.go index dbfc99ab3aa3..e07e0d9a96da 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GetAwsOpenIdConfig/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GetAwsOpenIdConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GetAwsServerConfig/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GetAwsServerConfig/main.go index 32696681e2e7..5a2638a0f28f 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GetAwsServerConfig/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GetAwsServerConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GetOperation/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GetOperation/main.go index 4eca77e38462..77bc81fca2d2 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GetOperation/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/ListAwsClusters/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/ListAwsClusters/main.go index a679c2d0cd0c..9a719375de4e 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/ListAwsClusters/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/ListAwsClusters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/ListAwsNodePools/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/ListAwsNodePools/main.go index 632964a570d7..f2f4cec83116 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/ListAwsNodePools/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/ListAwsNodePools/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/ListOperations/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/ListOperations/main.go index f400bf90cf68..d826f5374f35 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/ListOperations/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/RollbackAwsNodePoolUpdate/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/RollbackAwsNodePoolUpdate/main.go index 1d22dbb7b529..1c738fcea947 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/RollbackAwsNodePoolUpdate/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/RollbackAwsNodePoolUpdate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/UpdateAwsCluster/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/UpdateAwsCluster/main.go index 8699ec1d8e53..ea7223a69902 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/UpdateAwsCluster/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/UpdateAwsCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/UpdateAwsNodePool/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/UpdateAwsNodePool/main.go index b8ae6cbbbc1b..e75fd237699b 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/UpdateAwsNodePool/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AwsClustersClient/UpdateAwsNodePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/CancelOperation/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/CancelOperation/main.go index 9a45cd174c05..b4cf1724eadd 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/CancelOperation/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/CreateAzureClient/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/CreateAzureClient/main.go index 8b13f169cbe6..3e5f2e96ae66 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/CreateAzureClient/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/CreateAzureClient/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/CreateAzureCluster/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/CreateAzureCluster/main.go index efdeb4cfb5cb..6c6d73f14392 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/CreateAzureCluster/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/CreateAzureCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/CreateAzureNodePool/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/CreateAzureNodePool/main.go index 4891f8c6df32..914cefc27355 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/CreateAzureNodePool/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/CreateAzureNodePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/DeleteAzureClient/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/DeleteAzureClient/main.go index fe46f3b91d89..058f6a36f203 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/DeleteAzureClient/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/DeleteAzureClient/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/DeleteAzureCluster/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/DeleteAzureCluster/main.go index aa96cd85ce35..79f759c9db4e 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/DeleteAzureCluster/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/DeleteAzureCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/DeleteAzureNodePool/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/DeleteAzureNodePool/main.go index e065d1a8ca9c..929595a446c7 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/DeleteAzureNodePool/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/DeleteAzureNodePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/DeleteOperation/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/DeleteOperation/main.go index 2842cac47a5e..395fef4368b8 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/DeleteOperation/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GenerateAzureAccessToken/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GenerateAzureAccessToken/main.go index 9c5b20f65a17..e5364b02da6d 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GenerateAzureAccessToken/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GenerateAzureAccessToken/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GenerateAzureClusterAgentToken/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GenerateAzureClusterAgentToken/main.go index 7e0c1a5e15e4..3d6db5281b17 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GenerateAzureClusterAgentToken/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GenerateAzureClusterAgentToken/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GetAzureClient/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GetAzureClient/main.go index 324cfcbf8a38..3d05ce8e6f8a 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GetAzureClient/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GetAzureClient/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GetAzureCluster/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GetAzureCluster/main.go index 26818936dbb7..1dea8f60f23a 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GetAzureCluster/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GetAzureCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GetAzureJsonWebKeys/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GetAzureJsonWebKeys/main.go index 5b26200aff84..0591c28c6e61 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GetAzureJsonWebKeys/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GetAzureJsonWebKeys/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GetAzureNodePool/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GetAzureNodePool/main.go index d6c533cb6ec0..0e21a6b9d062 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GetAzureNodePool/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GetAzureNodePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GetAzureOpenIdConfig/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GetAzureOpenIdConfig/main.go index 84e7fbfe5724..629bf844e05c 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GetAzureOpenIdConfig/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GetAzureOpenIdConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GetAzureServerConfig/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GetAzureServerConfig/main.go index f264b4ee704a..495ced36238b 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GetAzureServerConfig/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GetAzureServerConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GetOperation/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GetOperation/main.go index 96407a8ee805..07bfe1bda209 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GetOperation/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/ListAzureClients/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/ListAzureClients/main.go index 7a7e32255aa9..4cf3aaf36a92 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/ListAzureClients/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/ListAzureClients/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/ListAzureClusters/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/ListAzureClusters/main.go index fba0b9e6560b..f77aa09b33b8 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/ListAzureClusters/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/ListAzureClusters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/ListAzureNodePools/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/ListAzureNodePools/main.go index 80776b50e9ea..3cedc1ab54fd 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/ListAzureNodePools/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/ListAzureNodePools/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/ListOperations/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/ListOperations/main.go index d12d6aafd250..5ce958add2db 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/ListOperations/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/UpdateAzureCluster/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/UpdateAzureCluster/main.go index 5150627f3437..3cbe77a00209 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/UpdateAzureCluster/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/UpdateAzureCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/UpdateAzureNodePool/main.go b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/UpdateAzureNodePool/main.go index c4a4a9ad4e04..0181976b3c0c 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/UpdateAzureNodePool/main.go +++ b/internal/generated/snippets/gkemulticloud/apiv1/AzureClustersClient/UpdateAzureNodePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gkemulticloud/apiv1/snippet_metadata.google.cloud.gkemulticloud.v1.json b/internal/generated/snippets/gkemulticloud/apiv1/snippet_metadata.google.cloud.gkemulticloud.v1.json index f5423f8f345b..edb04a552d7a 100644 --- a/internal/generated/snippets/gkemulticloud/apiv1/snippet_metadata.google.cloud.gkemulticloud.v1.json +++ b/internal/generated/snippets/gkemulticloud/apiv1/snippet_metadata.google.cloud.gkemulticloud.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/gkemulticloud/apiv1", - "version": "1.4.1", + "version": "1.5.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/gsuiteaddons/apiv1/Client/CreateDeployment/main.go b/internal/generated/snippets/gsuiteaddons/apiv1/Client/CreateDeployment/main.go index 6f7329dae88a..0fcc0c57a544 100644 --- a/internal/generated/snippets/gsuiteaddons/apiv1/Client/CreateDeployment/main.go +++ b/internal/generated/snippets/gsuiteaddons/apiv1/Client/CreateDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gsuiteaddons/apiv1/Client/DeleteDeployment/main.go b/internal/generated/snippets/gsuiteaddons/apiv1/Client/DeleteDeployment/main.go index 24ef8b586234..00f5661cd006 100644 --- a/internal/generated/snippets/gsuiteaddons/apiv1/Client/DeleteDeployment/main.go +++ b/internal/generated/snippets/gsuiteaddons/apiv1/Client/DeleteDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gsuiteaddons/apiv1/Client/GetAuthorization/main.go b/internal/generated/snippets/gsuiteaddons/apiv1/Client/GetAuthorization/main.go index 2552fcfaaeee..029dd6d0412b 100644 --- a/internal/generated/snippets/gsuiteaddons/apiv1/Client/GetAuthorization/main.go +++ b/internal/generated/snippets/gsuiteaddons/apiv1/Client/GetAuthorization/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gsuiteaddons/apiv1/Client/GetDeployment/main.go b/internal/generated/snippets/gsuiteaddons/apiv1/Client/GetDeployment/main.go index dedf18595932..1ac639aff448 100644 --- a/internal/generated/snippets/gsuiteaddons/apiv1/Client/GetDeployment/main.go +++ b/internal/generated/snippets/gsuiteaddons/apiv1/Client/GetDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gsuiteaddons/apiv1/Client/GetInstallStatus/main.go b/internal/generated/snippets/gsuiteaddons/apiv1/Client/GetInstallStatus/main.go index dd0c513a632c..2239a27b2da1 100644 --- a/internal/generated/snippets/gsuiteaddons/apiv1/Client/GetInstallStatus/main.go +++ b/internal/generated/snippets/gsuiteaddons/apiv1/Client/GetInstallStatus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gsuiteaddons/apiv1/Client/InstallDeployment/main.go b/internal/generated/snippets/gsuiteaddons/apiv1/Client/InstallDeployment/main.go index fb9e91bc7ddd..a1eafb8fd948 100644 --- a/internal/generated/snippets/gsuiteaddons/apiv1/Client/InstallDeployment/main.go +++ b/internal/generated/snippets/gsuiteaddons/apiv1/Client/InstallDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gsuiteaddons/apiv1/Client/ListDeployments/main.go b/internal/generated/snippets/gsuiteaddons/apiv1/Client/ListDeployments/main.go index 33b0cd37f385..b9cead9d6ee1 100644 --- a/internal/generated/snippets/gsuiteaddons/apiv1/Client/ListDeployments/main.go +++ b/internal/generated/snippets/gsuiteaddons/apiv1/Client/ListDeployments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gsuiteaddons/apiv1/Client/ReplaceDeployment/main.go b/internal/generated/snippets/gsuiteaddons/apiv1/Client/ReplaceDeployment/main.go index c078eee785b7..cd69fe41bf49 100644 --- a/internal/generated/snippets/gsuiteaddons/apiv1/Client/ReplaceDeployment/main.go +++ b/internal/generated/snippets/gsuiteaddons/apiv1/Client/ReplaceDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/gsuiteaddons/apiv1/Client/UninstallDeployment/main.go b/internal/generated/snippets/gsuiteaddons/apiv1/Client/UninstallDeployment/main.go index 10d2fcf0e994..6276aaf3c989 100644 --- a/internal/generated/snippets/gsuiteaddons/apiv1/Client/UninstallDeployment/main.go +++ b/internal/generated/snippets/gsuiteaddons/apiv1/Client/UninstallDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iam/apiv1/IamPolicyClient/GetIamPolicy/main.go b/internal/generated/snippets/iam/apiv1/IamPolicyClient/GetIamPolicy/main.go index 09f1f5bc4fac..78ce06d93005 100644 --- a/internal/generated/snippets/iam/apiv1/IamPolicyClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/iam/apiv1/IamPolicyClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iam/apiv1/IamPolicyClient/SetIamPolicy/main.go b/internal/generated/snippets/iam/apiv1/IamPolicyClient/SetIamPolicy/main.go index 576cf119041d..be906b627f00 100644 --- a/internal/generated/snippets/iam/apiv1/IamPolicyClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/iam/apiv1/IamPolicyClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iam/apiv1/IamPolicyClient/TestIamPermissions/main.go b/internal/generated/snippets/iam/apiv1/IamPolicyClient/TestIamPermissions/main.go index 14673701c939..eb255247426f 100644 --- a/internal/generated/snippets/iam/apiv1/IamPolicyClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/iam/apiv1/IamPolicyClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iam/apiv2/PoliciesClient/CreatePolicy/main.go b/internal/generated/snippets/iam/apiv2/PoliciesClient/CreatePolicy/main.go index e5e5b9451dc8..82dd18b554ee 100644 --- a/internal/generated/snippets/iam/apiv2/PoliciesClient/CreatePolicy/main.go +++ b/internal/generated/snippets/iam/apiv2/PoliciesClient/CreatePolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iam/apiv2/PoliciesClient/DeletePolicy/main.go b/internal/generated/snippets/iam/apiv2/PoliciesClient/DeletePolicy/main.go index 9c79af40accc..5f05a8b790d3 100644 --- a/internal/generated/snippets/iam/apiv2/PoliciesClient/DeletePolicy/main.go +++ b/internal/generated/snippets/iam/apiv2/PoliciesClient/DeletePolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iam/apiv2/PoliciesClient/GetOperation/main.go b/internal/generated/snippets/iam/apiv2/PoliciesClient/GetOperation/main.go index d322de528fb7..cc50584ae4d6 100644 --- a/internal/generated/snippets/iam/apiv2/PoliciesClient/GetOperation/main.go +++ b/internal/generated/snippets/iam/apiv2/PoliciesClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iam/apiv2/PoliciesClient/GetPolicy/main.go b/internal/generated/snippets/iam/apiv2/PoliciesClient/GetPolicy/main.go index 9f72ffa8fac9..cb4b08824850 100644 --- a/internal/generated/snippets/iam/apiv2/PoliciesClient/GetPolicy/main.go +++ b/internal/generated/snippets/iam/apiv2/PoliciesClient/GetPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iam/apiv2/PoliciesClient/ListPolicies/main.go b/internal/generated/snippets/iam/apiv2/PoliciesClient/ListPolicies/main.go index fd8e84c0cbd8..28846ef43e31 100644 --- a/internal/generated/snippets/iam/apiv2/PoliciesClient/ListPolicies/main.go +++ b/internal/generated/snippets/iam/apiv2/PoliciesClient/ListPolicies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iam/apiv2/PoliciesClient/UpdatePolicy/main.go b/internal/generated/snippets/iam/apiv2/PoliciesClient/UpdatePolicy/main.go index 375d16380726..34d1cc3a0fe5 100644 --- a/internal/generated/snippets/iam/apiv2/PoliciesClient/UpdatePolicy/main.go +++ b/internal/generated/snippets/iam/apiv2/PoliciesClient/UpdatePolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iam/credentials/apiv1/IamCredentialsClient/GenerateAccessToken/main.go b/internal/generated/snippets/iam/credentials/apiv1/IamCredentialsClient/GenerateAccessToken/main.go index 9cc900500674..5b0cae48e104 100644 --- a/internal/generated/snippets/iam/credentials/apiv1/IamCredentialsClient/GenerateAccessToken/main.go +++ b/internal/generated/snippets/iam/credentials/apiv1/IamCredentialsClient/GenerateAccessToken/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iam/credentials/apiv1/IamCredentialsClient/GenerateIdToken/main.go b/internal/generated/snippets/iam/credentials/apiv1/IamCredentialsClient/GenerateIdToken/main.go index 670c942c4685..d3497ca1ef9f 100644 --- a/internal/generated/snippets/iam/credentials/apiv1/IamCredentialsClient/GenerateIdToken/main.go +++ b/internal/generated/snippets/iam/credentials/apiv1/IamCredentialsClient/GenerateIdToken/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iam/credentials/apiv1/IamCredentialsClient/SignBlob/main.go b/internal/generated/snippets/iam/credentials/apiv1/IamCredentialsClient/SignBlob/main.go index 1c9ed8703c8e..76c248c86afd 100644 --- a/internal/generated/snippets/iam/credentials/apiv1/IamCredentialsClient/SignBlob/main.go +++ b/internal/generated/snippets/iam/credentials/apiv1/IamCredentialsClient/SignBlob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iam/credentials/apiv1/IamCredentialsClient/SignJwt/main.go b/internal/generated/snippets/iam/credentials/apiv1/IamCredentialsClient/SignJwt/main.go index 8e2c5f0874f4..9b3398a49965 100644 --- a/internal/generated/snippets/iam/credentials/apiv1/IamCredentialsClient/SignJwt/main.go +++ b/internal/generated/snippets/iam/credentials/apiv1/IamCredentialsClient/SignJwt/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/CreateTunnelDestGroup/main.go b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/CreateTunnelDestGroup/main.go index c95877ef9686..8e293a5463ec 100644 --- a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/CreateTunnelDestGroup/main.go +++ b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/CreateTunnelDestGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/DeleteTunnelDestGroup/main.go b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/DeleteTunnelDestGroup/main.go index 77b83d42133d..aa1365ea9c26 100644 --- a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/DeleteTunnelDestGroup/main.go +++ b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/DeleteTunnelDestGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/GetIamPolicy/main.go b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/GetIamPolicy/main.go index fc4041f394df..f644c9753955 100644 --- a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/GetIapSettings/main.go b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/GetIapSettings/main.go index 789610b6c8b5..89c4af25909c 100644 --- a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/GetIapSettings/main.go +++ b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/GetIapSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/GetTunnelDestGroup/main.go b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/GetTunnelDestGroup/main.go index d3ed5c34c94d..88ade1acfb25 100644 --- a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/GetTunnelDestGroup/main.go +++ b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/GetTunnelDestGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/ListTunnelDestGroups/main.go b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/ListTunnelDestGroups/main.go index 1fde203bfbb0..05cb61f9e986 100644 --- a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/ListTunnelDestGroups/main.go +++ b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/ListTunnelDestGroups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/SetIamPolicy/main.go b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/SetIamPolicy/main.go index 456406709f92..00a928b028fd 100644 --- a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/TestIamPermissions/main.go b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/TestIamPermissions/main.go index e4a83d4605ee..38695611ac8a 100644 --- a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/UpdateIapSettings/main.go b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/UpdateIapSettings/main.go index c97ccb525ca1..06085560eb4a 100644 --- a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/UpdateIapSettings/main.go +++ b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/UpdateIapSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/UpdateTunnelDestGroup/main.go b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/UpdateTunnelDestGroup/main.go index 2c88ef4150f7..fa884fb2e1b7 100644 --- a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/UpdateTunnelDestGroup/main.go +++ b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyAdminClient/UpdateTunnelDestGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/CreateBrand/main.go b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/CreateBrand/main.go index 768366d75329..e043ca81eb24 100644 --- a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/CreateBrand/main.go +++ b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/CreateBrand/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/CreateIdentityAwareProxyClient/main.go b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/CreateIdentityAwareProxyClient/main.go index 319185853e00..5bde9249fc8c 100644 --- a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/CreateIdentityAwareProxyClient/main.go +++ b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/CreateIdentityAwareProxyClient/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/DeleteIdentityAwareProxyClient/main.go b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/DeleteIdentityAwareProxyClient/main.go index d8afe130e9d4..69ed29369604 100644 --- a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/DeleteIdentityAwareProxyClient/main.go +++ b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/DeleteIdentityAwareProxyClient/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/GetBrand/main.go b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/GetBrand/main.go index 6568ce9dc680..173c4850d31f 100644 --- a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/GetBrand/main.go +++ b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/GetBrand/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/GetIdentityAwareProxyClient/main.go b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/GetIdentityAwareProxyClient/main.go index cb53e1989836..9fa797a3a52b 100644 --- a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/GetIdentityAwareProxyClient/main.go +++ b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/GetIdentityAwareProxyClient/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/ListBrands/main.go b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/ListBrands/main.go index 0461e55f084b..fe0023e89e39 100644 --- a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/ListBrands/main.go +++ b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/ListBrands/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/ListIdentityAwareProxyClients/main.go b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/ListIdentityAwareProxyClients/main.go index e4998593d122..9207650fb440 100644 --- a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/ListIdentityAwareProxyClients/main.go +++ b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/ListIdentityAwareProxyClients/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/ResetIdentityAwareProxyClientSecret/main.go b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/ResetIdentityAwareProxyClientSecret/main.go index c185a57fabff..9272b2c5bfa6 100644 --- a/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/ResetIdentityAwareProxyClientSecret/main.go +++ b/internal/generated/snippets/iap/apiv1/IdentityAwareProxyOAuthClient/ResetIdentityAwareProxyClientSecret/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/identitytoolkit/apiv2/AccountManagementClient/FinalizeMfaEnrollment/main.go b/internal/generated/snippets/identitytoolkit/apiv2/AccountManagementClient/FinalizeMfaEnrollment/main.go index 0fb013523fba..0684b5a68e4f 100644 --- a/internal/generated/snippets/identitytoolkit/apiv2/AccountManagementClient/FinalizeMfaEnrollment/main.go +++ b/internal/generated/snippets/identitytoolkit/apiv2/AccountManagementClient/FinalizeMfaEnrollment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/identitytoolkit/apiv2/AccountManagementClient/StartMfaEnrollment/main.go b/internal/generated/snippets/identitytoolkit/apiv2/AccountManagementClient/StartMfaEnrollment/main.go index 1fdda362a5c3..1f47c2c7f196 100644 --- a/internal/generated/snippets/identitytoolkit/apiv2/AccountManagementClient/StartMfaEnrollment/main.go +++ b/internal/generated/snippets/identitytoolkit/apiv2/AccountManagementClient/StartMfaEnrollment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/identitytoolkit/apiv2/AccountManagementClient/WithdrawMfa/main.go b/internal/generated/snippets/identitytoolkit/apiv2/AccountManagementClient/WithdrawMfa/main.go index 67de7b5afa50..b76d8ee02509 100644 --- a/internal/generated/snippets/identitytoolkit/apiv2/AccountManagementClient/WithdrawMfa/main.go +++ b/internal/generated/snippets/identitytoolkit/apiv2/AccountManagementClient/WithdrawMfa/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/identitytoolkit/apiv2/AuthenticationClient/FinalizeMfaSignIn/main.go b/internal/generated/snippets/identitytoolkit/apiv2/AuthenticationClient/FinalizeMfaSignIn/main.go index f60632262b32..d150dda2ab24 100644 --- a/internal/generated/snippets/identitytoolkit/apiv2/AuthenticationClient/FinalizeMfaSignIn/main.go +++ b/internal/generated/snippets/identitytoolkit/apiv2/AuthenticationClient/FinalizeMfaSignIn/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/identitytoolkit/apiv2/AuthenticationClient/StartMfaSignIn/main.go b/internal/generated/snippets/identitytoolkit/apiv2/AuthenticationClient/StartMfaSignIn/main.go index 4a7754335061..4bb7fc95b55b 100644 --- a/internal/generated/snippets/identitytoolkit/apiv2/AuthenticationClient/StartMfaSignIn/main.go +++ b/internal/generated/snippets/identitytoolkit/apiv2/AuthenticationClient/StartMfaSignIn/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/identitytoolkit/apiv2/snippet_metadata.google.cloud.identitytoolkit.v2.json b/internal/generated/snippets/identitytoolkit/apiv2/snippet_metadata.google.cloud.identitytoolkit.v2.json index 53aebcf033aa..4ef9a7e483a8 100644 --- a/internal/generated/snippets/identitytoolkit/apiv2/snippet_metadata.google.cloud.identitytoolkit.v2.json +++ b/internal/generated/snippets/identitytoolkit/apiv2/snippet_metadata.google.cloud.identitytoolkit.v2.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/identitytoolkit/apiv2", - "version": "0.2.2", + "version": "0.2.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/ids/apiv1/Client/CreateEndpoint/main.go b/internal/generated/snippets/ids/apiv1/Client/CreateEndpoint/main.go index 21e11f776bc3..897a97548cba 100644 --- a/internal/generated/snippets/ids/apiv1/Client/CreateEndpoint/main.go +++ b/internal/generated/snippets/ids/apiv1/Client/CreateEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ids/apiv1/Client/DeleteEndpoint/main.go b/internal/generated/snippets/ids/apiv1/Client/DeleteEndpoint/main.go index fe6e80063247..1bfc58cbefa0 100644 --- a/internal/generated/snippets/ids/apiv1/Client/DeleteEndpoint/main.go +++ b/internal/generated/snippets/ids/apiv1/Client/DeleteEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ids/apiv1/Client/GetEndpoint/main.go b/internal/generated/snippets/ids/apiv1/Client/GetEndpoint/main.go index 166255eaaac1..d472f69438a9 100644 --- a/internal/generated/snippets/ids/apiv1/Client/GetEndpoint/main.go +++ b/internal/generated/snippets/ids/apiv1/Client/GetEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/ids/apiv1/Client/ListEndpoints/main.go b/internal/generated/snippets/ids/apiv1/Client/ListEndpoints/main.go index 078f2ec60735..1c7424cf0b34 100644 --- a/internal/generated/snippets/ids/apiv1/Client/ListEndpoints/main.go +++ b/internal/generated/snippets/ids/apiv1/Client/ListEndpoints/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/BindDeviceToGateway/main.go b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/BindDeviceToGateway/main.go index d4cf1939adf7..ab0b62157d19 100644 --- a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/BindDeviceToGateway/main.go +++ b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/BindDeviceToGateway/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/CreateDevice/main.go b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/CreateDevice/main.go index 0238c36e5978..7f394ef3dafa 100644 --- a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/CreateDevice/main.go +++ b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/CreateDevice/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/CreateDeviceRegistry/main.go b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/CreateDeviceRegistry/main.go index 9f05ca84f2b2..089f36910758 100644 --- a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/CreateDeviceRegistry/main.go +++ b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/CreateDeviceRegistry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/DeleteDevice/main.go b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/DeleteDevice/main.go index 99a67e02d6b4..7a15d0a7d40d 100644 --- a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/DeleteDevice/main.go +++ b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/DeleteDevice/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/DeleteDeviceRegistry/main.go b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/DeleteDeviceRegistry/main.go index 3e26e100b0d8..db447e08c9f9 100644 --- a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/DeleteDeviceRegistry/main.go +++ b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/DeleteDeviceRegistry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/GetDevice/main.go b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/GetDevice/main.go index ce8a13116337..8077248e95bc 100644 --- a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/GetDevice/main.go +++ b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/GetDevice/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/GetDeviceRegistry/main.go b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/GetDeviceRegistry/main.go index c0cae434060d..7090ecdc2b95 100644 --- a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/GetDeviceRegistry/main.go +++ b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/GetDeviceRegistry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/GetIamPolicy/main.go b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/GetIamPolicy/main.go index 8c21c583763f..c0f0a4936724 100644 --- a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/ListDeviceConfigVersions/main.go b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/ListDeviceConfigVersions/main.go index 43d27f92a4cf..a18c258593e5 100644 --- a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/ListDeviceConfigVersions/main.go +++ b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/ListDeviceConfigVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/ListDeviceRegistries/main.go b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/ListDeviceRegistries/main.go index 2b93cfcef847..e1ba534c432c 100644 --- a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/ListDeviceRegistries/main.go +++ b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/ListDeviceRegistries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/ListDeviceStates/main.go b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/ListDeviceStates/main.go index 58aad6ec4fe0..33442e0ca374 100644 --- a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/ListDeviceStates/main.go +++ b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/ListDeviceStates/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/ListDevices/main.go b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/ListDevices/main.go index 5d6bc77f155a..62faaf8a8fe4 100644 --- a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/ListDevices/main.go +++ b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/ListDevices/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/ModifyCloudToDeviceConfig/main.go b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/ModifyCloudToDeviceConfig/main.go index 6885f750803f..c558b3d86d51 100644 --- a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/ModifyCloudToDeviceConfig/main.go +++ b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/ModifyCloudToDeviceConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/SendCommandToDevice/main.go b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/SendCommandToDevice/main.go index 6015d0b1b03f..e83f5ac88059 100644 --- a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/SendCommandToDevice/main.go +++ b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/SendCommandToDevice/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/SetIamPolicy/main.go b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/SetIamPolicy/main.go index fe1d13aa9fdf..92840ed7cfa0 100644 --- a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/TestIamPermissions/main.go b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/TestIamPermissions/main.go index 2047fb1ef202..9b7783bde492 100644 --- a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/UnbindDeviceFromGateway/main.go b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/UnbindDeviceFromGateway/main.go index e75b691a193c..6eae355e1e34 100644 --- a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/UnbindDeviceFromGateway/main.go +++ b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/UnbindDeviceFromGateway/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/UpdateDevice/main.go b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/UpdateDevice/main.go index 5d3802c5be46..2ab81d2fe434 100644 --- a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/UpdateDevice/main.go +++ b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/UpdateDevice/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/UpdateDeviceRegistry/main.go b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/UpdateDeviceRegistry/main.go index 236892f2f7ba..78bb30985044 100644 --- a/internal/generated/snippets/iot/apiv1/DeviceManagerClient/UpdateDeviceRegistry/main.go +++ b/internal/generated/snippets/iot/apiv1/DeviceManagerClient/UpdateDeviceRegistry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/GetAutokeyConfig/main.go b/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/GetAutokeyConfig/main.go index 9b311768ab42..388f8b24a967 100644 --- a/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/GetAutokeyConfig/main.go +++ b/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/GetAutokeyConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/GetIamPolicy/main.go b/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/GetIamPolicy/main.go index 7d048f8d93e0..04919662839d 100644 --- a/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/GetLocation/main.go b/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/GetLocation/main.go index a1d3b9d14104..9d56902dbc8f 100644 --- a/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/GetLocation/main.go +++ b/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/GetOperation/main.go b/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/GetOperation/main.go index 6f12d2ea4da1..d20db5080775 100644 --- a/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/GetOperation/main.go +++ b/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/ListLocations/main.go b/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/ListLocations/main.go index 687c0dc4a458..790e99e23c65 100644 --- a/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/ListLocations/main.go +++ b/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/SetIamPolicy/main.go b/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/SetIamPolicy/main.go index 7c2cdf7bc87d..98d15edf1f25 100644 --- a/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/ShowEffectiveAutokeyConfig/main.go b/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/ShowEffectiveAutokeyConfig/main.go index 236f835aee74..1cf2bdb3a0c8 100644 --- a/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/ShowEffectiveAutokeyConfig/main.go +++ b/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/ShowEffectiveAutokeyConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/TestIamPermissions/main.go b/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/TestIamPermissions/main.go index 0bceae2ea033..fae2216648dd 100644 --- a/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/UpdateAutokeyConfig/main.go b/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/UpdateAutokeyConfig/main.go index 07f400bf4675..e2bde7f2ab46 100644 --- a/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/UpdateAutokeyConfig/main.go +++ b/internal/generated/snippets/kms/apiv1/AutokeyAdminClient/UpdateAutokeyConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/AutokeyClient/CreateKeyHandle/main.go b/internal/generated/snippets/kms/apiv1/AutokeyClient/CreateKeyHandle/main.go index ef5f462ba39f..9ee6b5f20420 100644 --- a/internal/generated/snippets/kms/apiv1/AutokeyClient/CreateKeyHandle/main.go +++ b/internal/generated/snippets/kms/apiv1/AutokeyClient/CreateKeyHandle/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/AutokeyClient/GetIamPolicy/main.go b/internal/generated/snippets/kms/apiv1/AutokeyClient/GetIamPolicy/main.go index 6d413128baad..e8fb8405ea72 100644 --- a/internal/generated/snippets/kms/apiv1/AutokeyClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/kms/apiv1/AutokeyClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/AutokeyClient/GetKeyHandle/main.go b/internal/generated/snippets/kms/apiv1/AutokeyClient/GetKeyHandle/main.go index 05bcbcfc39f9..67884f50bb4c 100644 --- a/internal/generated/snippets/kms/apiv1/AutokeyClient/GetKeyHandle/main.go +++ b/internal/generated/snippets/kms/apiv1/AutokeyClient/GetKeyHandle/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/AutokeyClient/GetLocation/main.go b/internal/generated/snippets/kms/apiv1/AutokeyClient/GetLocation/main.go index 6a2c8fd43548..553df44bd140 100644 --- a/internal/generated/snippets/kms/apiv1/AutokeyClient/GetLocation/main.go +++ b/internal/generated/snippets/kms/apiv1/AutokeyClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/AutokeyClient/GetOperation/main.go b/internal/generated/snippets/kms/apiv1/AutokeyClient/GetOperation/main.go index 550cec793d1a..639f8c293060 100644 --- a/internal/generated/snippets/kms/apiv1/AutokeyClient/GetOperation/main.go +++ b/internal/generated/snippets/kms/apiv1/AutokeyClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/AutokeyClient/ListKeyHandles/main.go b/internal/generated/snippets/kms/apiv1/AutokeyClient/ListKeyHandles/main.go index 08a5638053ed..19bd150db78b 100644 --- a/internal/generated/snippets/kms/apiv1/AutokeyClient/ListKeyHandles/main.go +++ b/internal/generated/snippets/kms/apiv1/AutokeyClient/ListKeyHandles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/AutokeyClient/ListLocations/main.go b/internal/generated/snippets/kms/apiv1/AutokeyClient/ListLocations/main.go index 5476397059d2..6a7d45edde47 100644 --- a/internal/generated/snippets/kms/apiv1/AutokeyClient/ListLocations/main.go +++ b/internal/generated/snippets/kms/apiv1/AutokeyClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/AutokeyClient/SetIamPolicy/main.go b/internal/generated/snippets/kms/apiv1/AutokeyClient/SetIamPolicy/main.go index 65289c97f44d..6bb75423c5d7 100644 --- a/internal/generated/snippets/kms/apiv1/AutokeyClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/kms/apiv1/AutokeyClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/AutokeyClient/TestIamPermissions/main.go b/internal/generated/snippets/kms/apiv1/AutokeyClient/TestIamPermissions/main.go index 806d631b4dca..500233f41af0 100644 --- a/internal/generated/snippets/kms/apiv1/AutokeyClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/kms/apiv1/AutokeyClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/EkmClient/CreateEkmConnection/main.go b/internal/generated/snippets/kms/apiv1/EkmClient/CreateEkmConnection/main.go index 03f83449b99a..24d3c38eb491 100644 --- a/internal/generated/snippets/kms/apiv1/EkmClient/CreateEkmConnection/main.go +++ b/internal/generated/snippets/kms/apiv1/EkmClient/CreateEkmConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/EkmClient/GetEkmConfig/main.go b/internal/generated/snippets/kms/apiv1/EkmClient/GetEkmConfig/main.go index 900a841ee144..b0268dac858d 100644 --- a/internal/generated/snippets/kms/apiv1/EkmClient/GetEkmConfig/main.go +++ b/internal/generated/snippets/kms/apiv1/EkmClient/GetEkmConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/EkmClient/GetEkmConnection/main.go b/internal/generated/snippets/kms/apiv1/EkmClient/GetEkmConnection/main.go index f3d6982e2fdd..0956a216d079 100644 --- a/internal/generated/snippets/kms/apiv1/EkmClient/GetEkmConnection/main.go +++ b/internal/generated/snippets/kms/apiv1/EkmClient/GetEkmConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/EkmClient/GetIamPolicy/main.go b/internal/generated/snippets/kms/apiv1/EkmClient/GetIamPolicy/main.go index 815c3a5f566a..68202aa94cb8 100644 --- a/internal/generated/snippets/kms/apiv1/EkmClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/kms/apiv1/EkmClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/EkmClient/GetLocation/main.go b/internal/generated/snippets/kms/apiv1/EkmClient/GetLocation/main.go index cfe5f2ac77b8..07f823698aab 100644 --- a/internal/generated/snippets/kms/apiv1/EkmClient/GetLocation/main.go +++ b/internal/generated/snippets/kms/apiv1/EkmClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/EkmClient/GetOperation/main.go b/internal/generated/snippets/kms/apiv1/EkmClient/GetOperation/main.go index 5b1de6662958..953f4fe80c22 100644 --- a/internal/generated/snippets/kms/apiv1/EkmClient/GetOperation/main.go +++ b/internal/generated/snippets/kms/apiv1/EkmClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/EkmClient/ListEkmConnections/main.go b/internal/generated/snippets/kms/apiv1/EkmClient/ListEkmConnections/main.go index 84606e0411f4..8697111690e3 100644 --- a/internal/generated/snippets/kms/apiv1/EkmClient/ListEkmConnections/main.go +++ b/internal/generated/snippets/kms/apiv1/EkmClient/ListEkmConnections/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/EkmClient/ListLocations/main.go b/internal/generated/snippets/kms/apiv1/EkmClient/ListLocations/main.go index 903050b8b88b..52b5ecf6a2e2 100644 --- a/internal/generated/snippets/kms/apiv1/EkmClient/ListLocations/main.go +++ b/internal/generated/snippets/kms/apiv1/EkmClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/EkmClient/SetIamPolicy/main.go b/internal/generated/snippets/kms/apiv1/EkmClient/SetIamPolicy/main.go index d1e7a6b35044..709eb378064b 100644 --- a/internal/generated/snippets/kms/apiv1/EkmClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/kms/apiv1/EkmClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/EkmClient/TestIamPermissions/main.go b/internal/generated/snippets/kms/apiv1/EkmClient/TestIamPermissions/main.go index ec0751154a8b..5ab75c5a7ab2 100644 --- a/internal/generated/snippets/kms/apiv1/EkmClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/kms/apiv1/EkmClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/EkmClient/UpdateEkmConfig/main.go b/internal/generated/snippets/kms/apiv1/EkmClient/UpdateEkmConfig/main.go index df7c178c961d..a7ffd24276e3 100644 --- a/internal/generated/snippets/kms/apiv1/EkmClient/UpdateEkmConfig/main.go +++ b/internal/generated/snippets/kms/apiv1/EkmClient/UpdateEkmConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/EkmClient/UpdateEkmConnection/main.go b/internal/generated/snippets/kms/apiv1/EkmClient/UpdateEkmConnection/main.go index aad4505be68a..c80a9d445652 100644 --- a/internal/generated/snippets/kms/apiv1/EkmClient/UpdateEkmConnection/main.go +++ b/internal/generated/snippets/kms/apiv1/EkmClient/UpdateEkmConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/EkmClient/VerifyConnectivity/main.go b/internal/generated/snippets/kms/apiv1/EkmClient/VerifyConnectivity/main.go index ed8a6882aa24..3a03194ded5c 100644 --- a/internal/generated/snippets/kms/apiv1/EkmClient/VerifyConnectivity/main.go +++ b/internal/generated/snippets/kms/apiv1/EkmClient/VerifyConnectivity/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/AsymmetricDecrypt/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/AsymmetricDecrypt/main.go index b579781e3162..63dad4b789de 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/AsymmetricDecrypt/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/AsymmetricDecrypt/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/AsymmetricSign/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/AsymmetricSign/main.go index 0bc9c3459b13..861fcff18eeb 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/AsymmetricSign/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/AsymmetricSign/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/CreateCryptoKey/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/CreateCryptoKey/main.go index 79e098b18ae3..7e3a10448e2f 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/CreateCryptoKey/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/CreateCryptoKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/CreateCryptoKeyVersion/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/CreateCryptoKeyVersion/main.go index 2dd600c5277d..6b2e6d2fdaab 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/CreateCryptoKeyVersion/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/CreateCryptoKeyVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/CreateImportJob/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/CreateImportJob/main.go index 8f20c3016e6f..0af62d8ac87a 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/CreateImportJob/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/CreateImportJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/CreateKeyRing/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/CreateKeyRing/main.go index 97e4b831df00..38ca63e23868 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/CreateKeyRing/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/CreateKeyRing/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/Decrypt/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/Decrypt/main.go index 4e75e26f31f6..6085ad89669a 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/Decrypt/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/Decrypt/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/DestroyCryptoKeyVersion/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/DestroyCryptoKeyVersion/main.go index a6a040773b6e..5dd76331c18c 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/DestroyCryptoKeyVersion/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/DestroyCryptoKeyVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/Encrypt/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/Encrypt/main.go index 414038aed847..1838df9b0157 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/Encrypt/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/Encrypt/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/GenerateRandomBytes/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/GenerateRandomBytes/main.go index c76c0626dfee..753f4ecde326 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/GenerateRandomBytes/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/GenerateRandomBytes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetCryptoKey/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetCryptoKey/main.go index 3914820789dc..6b4a3c8805a2 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetCryptoKey/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetCryptoKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetCryptoKeyVersion/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetCryptoKeyVersion/main.go index a97fbbc40f30..8c45085357f1 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetCryptoKeyVersion/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetCryptoKeyVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetIamPolicy/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetIamPolicy/main.go index ecf11e77bd21..b2e636ca05d3 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetImportJob/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetImportJob/main.go index e719dc8c9a4b..ae9e95618f34 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetImportJob/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetImportJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetKeyRing/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetKeyRing/main.go index bad131018767..2607a6c0fb62 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetKeyRing/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetKeyRing/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetLocation/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetLocation/main.go index a045c7829e51..2dc5c6eb2ed0 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetLocation/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetOperation/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetOperation/main.go index 9d5386710f3b..b3d716ec1300 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetOperation/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetPublicKey/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetPublicKey/main.go index 6f02061d5297..8001df7e2a5d 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetPublicKey/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/GetPublicKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/ImportCryptoKeyVersion/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/ImportCryptoKeyVersion/main.go index 89eb7afc1718..875317d2c662 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/ImportCryptoKeyVersion/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/ImportCryptoKeyVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/ListCryptoKeyVersions/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/ListCryptoKeyVersions/main.go index db9517fba8bb..b1c29ba68a55 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/ListCryptoKeyVersions/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/ListCryptoKeyVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/ListCryptoKeys/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/ListCryptoKeys/main.go index b1922539fc56..99330cb4936d 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/ListCryptoKeys/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/ListCryptoKeys/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/ListImportJobs/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/ListImportJobs/main.go index 5936cb5f383d..926b8fef0867 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/ListImportJobs/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/ListImportJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/ListKeyRings/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/ListKeyRings/main.go index 2f0439c75add..925fe30738ff 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/ListKeyRings/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/ListKeyRings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/ListLocations/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/ListLocations/main.go index b317996a603f..130989d595ea 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/ListLocations/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/MacSign/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/MacSign/main.go index 6f0662fe94a6..d46de12747df 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/MacSign/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/MacSign/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/MacVerify/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/MacVerify/main.go index 5b06c6785322..ca45f5df6f63 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/MacVerify/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/MacVerify/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/RawDecrypt/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/RawDecrypt/main.go index 3762cd7a99be..3121c14f0608 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/RawDecrypt/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/RawDecrypt/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/RawEncrypt/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/RawEncrypt/main.go index 36f2bff64774..d29fccbf1492 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/RawEncrypt/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/RawEncrypt/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/RestoreCryptoKeyVersion/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/RestoreCryptoKeyVersion/main.go index 698ec69e04d0..938127d06abf 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/RestoreCryptoKeyVersion/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/RestoreCryptoKeyVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/SetIamPolicy/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/SetIamPolicy/main.go index 470886bd2368..08a780ecded2 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/TestIamPermissions/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/TestIamPermissions/main.go index cc56de70a375..9fc54581455e 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/UpdateCryptoKey/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/UpdateCryptoKey/main.go index 23fff2f599ec..127d8187464c 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/UpdateCryptoKey/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/UpdateCryptoKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/UpdateCryptoKeyPrimaryVersion/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/UpdateCryptoKeyPrimaryVersion/main.go index b4bd8e7f0ba5..4930ed11f347 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/UpdateCryptoKeyPrimaryVersion/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/UpdateCryptoKeyPrimaryVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/KeyManagementClient/UpdateCryptoKeyVersion/main.go b/internal/generated/snippets/kms/apiv1/KeyManagementClient/UpdateCryptoKeyVersion/main.go index 2a58d07ebccb..1713cdad609a 100644 --- a/internal/generated/snippets/kms/apiv1/KeyManagementClient/UpdateCryptoKeyVersion/main.go +++ b/internal/generated/snippets/kms/apiv1/KeyManagementClient/UpdateCryptoKeyVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/apiv1/snippet_metadata.google.cloud.kms.v1.json b/internal/generated/snippets/kms/apiv1/snippet_metadata.google.cloud.kms.v1.json index ccc8c6d6ac4b..e6e1036f80e6 100644 --- a/internal/generated/snippets/kms/apiv1/snippet_metadata.google.cloud.kms.v1.json +++ b/internal/generated/snippets/kms/apiv1/snippet_metadata.google.cloud.kms.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/kms/apiv1", - "version": "1.20.3", + "version": "1.20.4", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/kms/inventory/apiv1/KeyDashboardClient/ListCryptoKeys/main.go b/internal/generated/snippets/kms/inventory/apiv1/KeyDashboardClient/ListCryptoKeys/main.go index 7739e4eb4801..a30715441da3 100644 --- a/internal/generated/snippets/kms/inventory/apiv1/KeyDashboardClient/ListCryptoKeys/main.go +++ b/internal/generated/snippets/kms/inventory/apiv1/KeyDashboardClient/ListCryptoKeys/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/inventory/apiv1/KeyTrackingClient/GetProtectedResourcesSummary/main.go b/internal/generated/snippets/kms/inventory/apiv1/KeyTrackingClient/GetProtectedResourcesSummary/main.go index 86cf0670cf5d..48013263a17b 100644 --- a/internal/generated/snippets/kms/inventory/apiv1/KeyTrackingClient/GetProtectedResourcesSummary/main.go +++ b/internal/generated/snippets/kms/inventory/apiv1/KeyTrackingClient/GetProtectedResourcesSummary/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/inventory/apiv1/KeyTrackingClient/SearchProtectedResources/main.go b/internal/generated/snippets/kms/inventory/apiv1/KeyTrackingClient/SearchProtectedResources/main.go index 3f971414542d..0f20ea912296 100644 --- a/internal/generated/snippets/kms/inventory/apiv1/KeyTrackingClient/SearchProtectedResources/main.go +++ b/internal/generated/snippets/kms/inventory/apiv1/KeyTrackingClient/SearchProtectedResources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/kms/inventory/apiv1/snippet_metadata.google.cloud.kms.inventory.v1.json b/internal/generated/snippets/kms/inventory/apiv1/snippet_metadata.google.cloud.kms.inventory.v1.json index 01d519a3fbf0..7fc12e28f254 100644 --- a/internal/generated/snippets/kms/inventory/apiv1/snippet_metadata.google.cloud.kms.inventory.v1.json +++ b/internal/generated/snippets/kms/inventory/apiv1/snippet_metadata.google.cloud.kms.inventory.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/kms/inventory/apiv1", - "version": "1.20.3", + "version": "1.20.4", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/language/apiv1/Client/AnalyzeEntities/main.go b/internal/generated/snippets/language/apiv1/Client/AnalyzeEntities/main.go index 2e9cf3e9ff20..d1a11a93207c 100644 --- a/internal/generated/snippets/language/apiv1/Client/AnalyzeEntities/main.go +++ b/internal/generated/snippets/language/apiv1/Client/AnalyzeEntities/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/language/apiv1/Client/AnalyzeEntitySentiment/main.go b/internal/generated/snippets/language/apiv1/Client/AnalyzeEntitySentiment/main.go index 7d48b58210ad..796aaaf2cb83 100644 --- a/internal/generated/snippets/language/apiv1/Client/AnalyzeEntitySentiment/main.go +++ b/internal/generated/snippets/language/apiv1/Client/AnalyzeEntitySentiment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/language/apiv1/Client/AnalyzeSentiment/main.go b/internal/generated/snippets/language/apiv1/Client/AnalyzeSentiment/main.go index e7e0c92225df..4903b759aec6 100644 --- a/internal/generated/snippets/language/apiv1/Client/AnalyzeSentiment/main.go +++ b/internal/generated/snippets/language/apiv1/Client/AnalyzeSentiment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/language/apiv1/Client/AnalyzeSyntax/main.go b/internal/generated/snippets/language/apiv1/Client/AnalyzeSyntax/main.go index 48d473feeda7..4b5dc1ec5e8e 100644 --- a/internal/generated/snippets/language/apiv1/Client/AnalyzeSyntax/main.go +++ b/internal/generated/snippets/language/apiv1/Client/AnalyzeSyntax/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/language/apiv1/Client/AnnotateText/main.go b/internal/generated/snippets/language/apiv1/Client/AnnotateText/main.go index 754d2185767f..4c4c9caebcf0 100644 --- a/internal/generated/snippets/language/apiv1/Client/AnnotateText/main.go +++ b/internal/generated/snippets/language/apiv1/Client/AnnotateText/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/language/apiv1/Client/ClassifyText/main.go b/internal/generated/snippets/language/apiv1/Client/ClassifyText/main.go index ba2a2a0b1c41..e0cd0b98177d 100644 --- a/internal/generated/snippets/language/apiv1/Client/ClassifyText/main.go +++ b/internal/generated/snippets/language/apiv1/Client/ClassifyText/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/language/apiv1/Client/ModerateText/main.go b/internal/generated/snippets/language/apiv1/Client/ModerateText/main.go index a4669ca0acfb..bf34cffde3d7 100644 --- a/internal/generated/snippets/language/apiv1/Client/ModerateText/main.go +++ b/internal/generated/snippets/language/apiv1/Client/ModerateText/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/language/apiv1/snippet_metadata.google.cloud.language.v1.json b/internal/generated/snippets/language/apiv1/snippet_metadata.google.cloud.language.v1.json index cc485f416bd9..4e79ea3cd176 100644 --- a/internal/generated/snippets/language/apiv1/snippet_metadata.google.cloud.language.v1.json +++ b/internal/generated/snippets/language/apiv1/snippet_metadata.google.cloud.language.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/language/apiv1", - "version": "1.14.2", + "version": "1.14.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/language/apiv1beta2/Client/AnalyzeEntities/main.go b/internal/generated/snippets/language/apiv1beta2/Client/AnalyzeEntities/main.go index 3c5389ca0631..6f6800049e78 100644 --- a/internal/generated/snippets/language/apiv1beta2/Client/AnalyzeEntities/main.go +++ b/internal/generated/snippets/language/apiv1beta2/Client/AnalyzeEntities/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/language/apiv1beta2/Client/AnalyzeEntitySentiment/main.go b/internal/generated/snippets/language/apiv1beta2/Client/AnalyzeEntitySentiment/main.go index 1c1afad68eef..fbc332c503f5 100644 --- a/internal/generated/snippets/language/apiv1beta2/Client/AnalyzeEntitySentiment/main.go +++ b/internal/generated/snippets/language/apiv1beta2/Client/AnalyzeEntitySentiment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/language/apiv1beta2/Client/AnalyzeSentiment/main.go b/internal/generated/snippets/language/apiv1beta2/Client/AnalyzeSentiment/main.go index 806b5f32efa5..f2a6eab9dc7e 100644 --- a/internal/generated/snippets/language/apiv1beta2/Client/AnalyzeSentiment/main.go +++ b/internal/generated/snippets/language/apiv1beta2/Client/AnalyzeSentiment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/language/apiv1beta2/Client/AnalyzeSyntax/main.go b/internal/generated/snippets/language/apiv1beta2/Client/AnalyzeSyntax/main.go index 8f18e975df76..c615a18d4d98 100644 --- a/internal/generated/snippets/language/apiv1beta2/Client/AnalyzeSyntax/main.go +++ b/internal/generated/snippets/language/apiv1beta2/Client/AnalyzeSyntax/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/language/apiv1beta2/Client/AnnotateText/main.go b/internal/generated/snippets/language/apiv1beta2/Client/AnnotateText/main.go index 6660315157eb..0d8133ef362f 100644 --- a/internal/generated/snippets/language/apiv1beta2/Client/AnnotateText/main.go +++ b/internal/generated/snippets/language/apiv1beta2/Client/AnnotateText/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/language/apiv1beta2/Client/ClassifyText/main.go b/internal/generated/snippets/language/apiv1beta2/Client/ClassifyText/main.go index e5ecffe37dd2..01e7cce1d6c4 100644 --- a/internal/generated/snippets/language/apiv1beta2/Client/ClassifyText/main.go +++ b/internal/generated/snippets/language/apiv1beta2/Client/ClassifyText/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/language/apiv1beta2/Client/ModerateText/main.go b/internal/generated/snippets/language/apiv1beta2/Client/ModerateText/main.go index edc5b68867b5..6a0dbe6cfdfe 100644 --- a/internal/generated/snippets/language/apiv1beta2/Client/ModerateText/main.go +++ b/internal/generated/snippets/language/apiv1beta2/Client/ModerateText/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/language/apiv1beta2/snippet_metadata.google.cloud.language.v1beta2.json b/internal/generated/snippets/language/apiv1beta2/snippet_metadata.google.cloud.language.v1beta2.json index 963ce8cd76c8..ea72cf0da9f9 100644 --- a/internal/generated/snippets/language/apiv1beta2/snippet_metadata.google.cloud.language.v1beta2.json +++ b/internal/generated/snippets/language/apiv1beta2/snippet_metadata.google.cloud.language.v1beta2.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/language/apiv1beta2", - "version": "1.14.2", + "version": "1.14.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/language/apiv2/Client/AnalyzeEntities/main.go b/internal/generated/snippets/language/apiv2/Client/AnalyzeEntities/main.go index fe437993e244..4b9bbfd12f7c 100644 --- a/internal/generated/snippets/language/apiv2/Client/AnalyzeEntities/main.go +++ b/internal/generated/snippets/language/apiv2/Client/AnalyzeEntities/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/language/apiv2/Client/AnalyzeSentiment/main.go b/internal/generated/snippets/language/apiv2/Client/AnalyzeSentiment/main.go index 303e482696dc..9a2ec6418846 100644 --- a/internal/generated/snippets/language/apiv2/Client/AnalyzeSentiment/main.go +++ b/internal/generated/snippets/language/apiv2/Client/AnalyzeSentiment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/language/apiv2/Client/AnnotateText/main.go b/internal/generated/snippets/language/apiv2/Client/AnnotateText/main.go index 2e648e1f32b5..9ae117a6da1d 100644 --- a/internal/generated/snippets/language/apiv2/Client/AnnotateText/main.go +++ b/internal/generated/snippets/language/apiv2/Client/AnnotateText/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/language/apiv2/Client/ClassifyText/main.go b/internal/generated/snippets/language/apiv2/Client/ClassifyText/main.go index acd4d2f9b21e..9fc48b096a57 100644 --- a/internal/generated/snippets/language/apiv2/Client/ClassifyText/main.go +++ b/internal/generated/snippets/language/apiv2/Client/ClassifyText/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/language/apiv2/Client/ModerateText/main.go b/internal/generated/snippets/language/apiv2/Client/ModerateText/main.go index edd3c78cee2b..ea30afd601ee 100644 --- a/internal/generated/snippets/language/apiv2/Client/ModerateText/main.go +++ b/internal/generated/snippets/language/apiv2/Client/ModerateText/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/language/apiv2/snippet_metadata.google.cloud.language.v2.json b/internal/generated/snippets/language/apiv2/snippet_metadata.google.cloud.language.v2.json index c20648db0022..a59f17e793ec 100644 --- a/internal/generated/snippets/language/apiv2/snippet_metadata.google.cloud.language.v2.json +++ b/internal/generated/snippets/language/apiv2/snippet_metadata.google.cloud.language.v2.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/language/apiv2", - "version": "1.14.2", + "version": "1.14.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/lifesciences/apiv2beta/WorkflowsServiceV2BetaClient/CancelOperation/main.go b/internal/generated/snippets/lifesciences/apiv2beta/WorkflowsServiceV2BetaClient/CancelOperation/main.go index b8c8b1acd422..65a383249cde 100644 --- a/internal/generated/snippets/lifesciences/apiv2beta/WorkflowsServiceV2BetaClient/CancelOperation/main.go +++ b/internal/generated/snippets/lifesciences/apiv2beta/WorkflowsServiceV2BetaClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/lifesciences/apiv2beta/WorkflowsServiceV2BetaClient/GetLocation/main.go b/internal/generated/snippets/lifesciences/apiv2beta/WorkflowsServiceV2BetaClient/GetLocation/main.go index d7d827661b19..c8643f82fdc5 100644 --- a/internal/generated/snippets/lifesciences/apiv2beta/WorkflowsServiceV2BetaClient/GetLocation/main.go +++ b/internal/generated/snippets/lifesciences/apiv2beta/WorkflowsServiceV2BetaClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/lifesciences/apiv2beta/WorkflowsServiceV2BetaClient/GetOperation/main.go b/internal/generated/snippets/lifesciences/apiv2beta/WorkflowsServiceV2BetaClient/GetOperation/main.go index 79a032bdb9b3..87590ba0816f 100644 --- a/internal/generated/snippets/lifesciences/apiv2beta/WorkflowsServiceV2BetaClient/GetOperation/main.go +++ b/internal/generated/snippets/lifesciences/apiv2beta/WorkflowsServiceV2BetaClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/lifesciences/apiv2beta/WorkflowsServiceV2BetaClient/ListLocations/main.go b/internal/generated/snippets/lifesciences/apiv2beta/WorkflowsServiceV2BetaClient/ListLocations/main.go index c8b356b8f32a..72afc55f1dcd 100644 --- a/internal/generated/snippets/lifesciences/apiv2beta/WorkflowsServiceV2BetaClient/ListLocations/main.go +++ b/internal/generated/snippets/lifesciences/apiv2beta/WorkflowsServiceV2BetaClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/lifesciences/apiv2beta/WorkflowsServiceV2BetaClient/ListOperations/main.go b/internal/generated/snippets/lifesciences/apiv2beta/WorkflowsServiceV2BetaClient/ListOperations/main.go index bab74ac65149..069bf7a92a2c 100644 --- a/internal/generated/snippets/lifesciences/apiv2beta/WorkflowsServiceV2BetaClient/ListOperations/main.go +++ b/internal/generated/snippets/lifesciences/apiv2beta/WorkflowsServiceV2BetaClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/lifesciences/apiv2beta/WorkflowsServiceV2BetaClient/RunPipeline/main.go b/internal/generated/snippets/lifesciences/apiv2beta/WorkflowsServiceV2BetaClient/RunPipeline/main.go index 1384b0d4bfa7..d56f4c0fb9ca 100644 --- a/internal/generated/snippets/lifesciences/apiv2beta/WorkflowsServiceV2BetaClient/RunPipeline/main.go +++ b/internal/generated/snippets/lifesciences/apiv2beta/WorkflowsServiceV2BetaClient/RunPipeline/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/Client/CancelOperation/main.go b/internal/generated/snippets/logging/apiv2/Client/CancelOperation/main.go index 5233c731c55c..26b69e30e693 100644 --- a/internal/generated/snippets/logging/apiv2/Client/CancelOperation/main.go +++ b/internal/generated/snippets/logging/apiv2/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/Client/DeleteLog/main.go b/internal/generated/snippets/logging/apiv2/Client/DeleteLog/main.go index 521c5bf28d0c..a7ccd8e0afbe 100644 --- a/internal/generated/snippets/logging/apiv2/Client/DeleteLog/main.go +++ b/internal/generated/snippets/logging/apiv2/Client/DeleteLog/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/Client/GetOperation/main.go b/internal/generated/snippets/logging/apiv2/Client/GetOperation/main.go index f23155988eb1..678f44af6640 100644 --- a/internal/generated/snippets/logging/apiv2/Client/GetOperation/main.go +++ b/internal/generated/snippets/logging/apiv2/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/Client/ListLogEntries/main.go b/internal/generated/snippets/logging/apiv2/Client/ListLogEntries/main.go index 1597bf5696c6..8c9bf8ff56e6 100644 --- a/internal/generated/snippets/logging/apiv2/Client/ListLogEntries/main.go +++ b/internal/generated/snippets/logging/apiv2/Client/ListLogEntries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/Client/ListLogs/main.go b/internal/generated/snippets/logging/apiv2/Client/ListLogs/main.go index bfa52c784601..49c0a3623d4a 100644 --- a/internal/generated/snippets/logging/apiv2/Client/ListLogs/main.go +++ b/internal/generated/snippets/logging/apiv2/Client/ListLogs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/Client/ListMonitoredResourceDescriptors/main.go b/internal/generated/snippets/logging/apiv2/Client/ListMonitoredResourceDescriptors/main.go index fcb8b11bc5d2..36e8e1b0e350 100644 --- a/internal/generated/snippets/logging/apiv2/Client/ListMonitoredResourceDescriptors/main.go +++ b/internal/generated/snippets/logging/apiv2/Client/ListMonitoredResourceDescriptors/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/Client/ListOperations/main.go b/internal/generated/snippets/logging/apiv2/Client/ListOperations/main.go index 3abb9f3516c2..b89561f67cd7 100644 --- a/internal/generated/snippets/logging/apiv2/Client/ListOperations/main.go +++ b/internal/generated/snippets/logging/apiv2/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/Client/TailLogEntries/main.go b/internal/generated/snippets/logging/apiv2/Client/TailLogEntries/main.go index e40ac0f58d63..e31ab880d1f2 100644 --- a/internal/generated/snippets/logging/apiv2/Client/TailLogEntries/main.go +++ b/internal/generated/snippets/logging/apiv2/Client/TailLogEntries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/Client/WriteLogEntries/main.go b/internal/generated/snippets/logging/apiv2/Client/WriteLogEntries/main.go index d06b4ff432f3..895a808253ab 100644 --- a/internal/generated/snippets/logging/apiv2/Client/WriteLogEntries/main.go +++ b/internal/generated/snippets/logging/apiv2/Client/WriteLogEntries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/CancelOperation/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/CancelOperation/main.go index dc4a1ec0f4f9..e015f693ed55 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/CancelOperation/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/CopyLogEntries/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/CopyLogEntries/main.go index 71a69e8ed3a8..e28bcedaaf9a 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/CopyLogEntries/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/CopyLogEntries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/CreateBucket/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/CreateBucket/main.go index 88bdfe73fc72..4db8727dcf7f 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/CreateBucket/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/CreateBucket/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/CreateBucketAsync/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/CreateBucketAsync/main.go index f331d2756ab3..7fa274887b1c 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/CreateBucketAsync/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/CreateBucketAsync/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/CreateExclusion/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/CreateExclusion/main.go index a03514b498f6..c50a10dd27ea 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/CreateExclusion/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/CreateExclusion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/CreateLink/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/CreateLink/main.go index 038608a92417..79cc80e56d4c 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/CreateLink/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/CreateLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/CreateSink/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/CreateSink/main.go index fdab442e1dc5..adc58bf20c90 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/CreateSink/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/CreateSink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/CreateView/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/CreateView/main.go index ada2d416d653..ac26ef7659e3 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/CreateView/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/CreateView/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/DeleteBucket/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/DeleteBucket/main.go index 5eddc71872b2..42a141d622b7 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/DeleteBucket/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/DeleteBucket/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/DeleteExclusion/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/DeleteExclusion/main.go index 5bdec4ebb1cd..1a8cd8514555 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/DeleteExclusion/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/DeleteExclusion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/DeleteLink/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/DeleteLink/main.go index 79d496c46f7c..73fe07158b16 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/DeleteLink/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/DeleteLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/DeleteSink/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/DeleteSink/main.go index c6b65f451f46..5e51f5b9d0da 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/DeleteSink/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/DeleteSink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/DeleteView/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/DeleteView/main.go index 212b45c8aa44..508914dd345c 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/DeleteView/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/DeleteView/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/GetBucket/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/GetBucket/main.go index 69ac757ac772..74012e8b3e12 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/GetBucket/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/GetBucket/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/GetCmekSettings/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/GetCmekSettings/main.go index e4c5ee3501bf..a08bd8059b25 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/GetCmekSettings/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/GetCmekSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/GetExclusion/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/GetExclusion/main.go index 6a3ba9105355..49e2f3082942 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/GetExclusion/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/GetExclusion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/GetLink/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/GetLink/main.go index 0dfdd45e09f0..31fe63f20941 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/GetLink/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/GetLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/GetOperation/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/GetOperation/main.go index 97426010e561..098c507cb385 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/GetOperation/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/GetSettings/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/GetSettings/main.go index eb76cf25ac63..4078a78994f6 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/GetSettings/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/GetSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/GetSink/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/GetSink/main.go index 1ea126d1eff2..0671ac22964e 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/GetSink/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/GetSink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/GetView/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/GetView/main.go index 7cc0896e9f9b..52102d9ecc9c 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/GetView/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/GetView/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/ListBuckets/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/ListBuckets/main.go index f7b2714b48a7..fa4c16507853 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/ListBuckets/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/ListBuckets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/ListExclusions/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/ListExclusions/main.go index 164c63f8454d..0b569774e80a 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/ListExclusions/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/ListExclusions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/ListLinks/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/ListLinks/main.go index 739e7e8f76c9..655c76218c32 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/ListLinks/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/ListLinks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/ListOperations/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/ListOperations/main.go index 8be2dc031ce1..51655ef89bb6 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/ListOperations/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/ListSinks/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/ListSinks/main.go index 7659f19304ff..699341881181 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/ListSinks/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/ListSinks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/ListViews/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/ListViews/main.go index 4469d88e82dd..3a44d9385939 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/ListViews/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/ListViews/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/UndeleteBucket/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/UndeleteBucket/main.go index 46d949bdd5cd..14f9ca9dd522 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/UndeleteBucket/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/UndeleteBucket/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/UpdateBucket/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/UpdateBucket/main.go index c31bca5a482f..07e88e628757 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/UpdateBucket/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/UpdateBucket/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/UpdateBucketAsync/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/UpdateBucketAsync/main.go index 2c995f693ccc..6126bee6d9ad 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/UpdateBucketAsync/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/UpdateBucketAsync/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/UpdateCmekSettings/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/UpdateCmekSettings/main.go index facc6ef3dfd6..52a16af92ced 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/UpdateCmekSettings/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/UpdateCmekSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/UpdateExclusion/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/UpdateExclusion/main.go index bb58248e0811..c5489af8aab5 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/UpdateExclusion/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/UpdateExclusion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/UpdateSettings/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/UpdateSettings/main.go index 5850af917358..8085bb58c2f4 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/UpdateSettings/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/UpdateSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/UpdateSink/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/UpdateSink/main.go index 11eb2b64e41d..ba40f48a2c67 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/UpdateSink/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/UpdateSink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/ConfigClient/UpdateView/main.go b/internal/generated/snippets/logging/apiv2/ConfigClient/UpdateView/main.go index 333d2fa1682d..07b19bbc2e7b 100644 --- a/internal/generated/snippets/logging/apiv2/ConfigClient/UpdateView/main.go +++ b/internal/generated/snippets/logging/apiv2/ConfigClient/UpdateView/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/MetricsClient/CancelOperation/main.go b/internal/generated/snippets/logging/apiv2/MetricsClient/CancelOperation/main.go index c2d3b43fdac4..9afdb872cd0c 100644 --- a/internal/generated/snippets/logging/apiv2/MetricsClient/CancelOperation/main.go +++ b/internal/generated/snippets/logging/apiv2/MetricsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/MetricsClient/CreateLogMetric/main.go b/internal/generated/snippets/logging/apiv2/MetricsClient/CreateLogMetric/main.go index 952c89e63c9d..35b633706cfd 100644 --- a/internal/generated/snippets/logging/apiv2/MetricsClient/CreateLogMetric/main.go +++ b/internal/generated/snippets/logging/apiv2/MetricsClient/CreateLogMetric/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/MetricsClient/DeleteLogMetric/main.go b/internal/generated/snippets/logging/apiv2/MetricsClient/DeleteLogMetric/main.go index 9a0b3c392fec..2b69cf21b509 100644 --- a/internal/generated/snippets/logging/apiv2/MetricsClient/DeleteLogMetric/main.go +++ b/internal/generated/snippets/logging/apiv2/MetricsClient/DeleteLogMetric/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/MetricsClient/GetLogMetric/main.go b/internal/generated/snippets/logging/apiv2/MetricsClient/GetLogMetric/main.go index 41626fcd8479..d5f6bf5d2b33 100644 --- a/internal/generated/snippets/logging/apiv2/MetricsClient/GetLogMetric/main.go +++ b/internal/generated/snippets/logging/apiv2/MetricsClient/GetLogMetric/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/MetricsClient/GetOperation/main.go b/internal/generated/snippets/logging/apiv2/MetricsClient/GetOperation/main.go index b9cd5b0495a6..cd2e73d86191 100644 --- a/internal/generated/snippets/logging/apiv2/MetricsClient/GetOperation/main.go +++ b/internal/generated/snippets/logging/apiv2/MetricsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/MetricsClient/ListLogMetrics/main.go b/internal/generated/snippets/logging/apiv2/MetricsClient/ListLogMetrics/main.go index b3b00c12e55c..dbe60ab81d2b 100644 --- a/internal/generated/snippets/logging/apiv2/MetricsClient/ListLogMetrics/main.go +++ b/internal/generated/snippets/logging/apiv2/MetricsClient/ListLogMetrics/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/MetricsClient/ListOperations/main.go b/internal/generated/snippets/logging/apiv2/MetricsClient/ListOperations/main.go index 680d26d25920..96aaeed32853 100644 --- a/internal/generated/snippets/logging/apiv2/MetricsClient/ListOperations/main.go +++ b/internal/generated/snippets/logging/apiv2/MetricsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/MetricsClient/UpdateLogMetric/main.go b/internal/generated/snippets/logging/apiv2/MetricsClient/UpdateLogMetric/main.go index fb1abf522ca6..d3b18d8148eb 100644 --- a/internal/generated/snippets/logging/apiv2/MetricsClient/UpdateLogMetric/main.go +++ b/internal/generated/snippets/logging/apiv2/MetricsClient/UpdateLogMetric/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/logging/apiv2/snippet_metadata.google.logging.v2.json b/internal/generated/snippets/logging/apiv2/snippet_metadata.google.logging.v2.json index ecc6551e5638..1428a979487c 100644 --- a/internal/generated/snippets/logging/apiv2/snippet_metadata.google.logging.v2.json +++ b/internal/generated/snippets/logging/apiv2/snippet_metadata.google.logging.v2.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/logging/apiv2", - "version": "1.12.0", + "version": "1.13.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/longrunning/autogen/OperationsClient/CancelOperation/main.go b/internal/generated/snippets/longrunning/autogen/OperationsClient/CancelOperation/main.go index ae1fc6fd3700..43df82433018 100644 --- a/internal/generated/snippets/longrunning/autogen/OperationsClient/CancelOperation/main.go +++ b/internal/generated/snippets/longrunning/autogen/OperationsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/longrunning/autogen/OperationsClient/DeleteOperation/main.go b/internal/generated/snippets/longrunning/autogen/OperationsClient/DeleteOperation/main.go index cc6a25191621..a1d054097ed0 100644 --- a/internal/generated/snippets/longrunning/autogen/OperationsClient/DeleteOperation/main.go +++ b/internal/generated/snippets/longrunning/autogen/OperationsClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/longrunning/autogen/OperationsClient/GetOperation/main.go b/internal/generated/snippets/longrunning/autogen/OperationsClient/GetOperation/main.go index 7660b9f522ef..10716b866552 100644 --- a/internal/generated/snippets/longrunning/autogen/OperationsClient/GetOperation/main.go +++ b/internal/generated/snippets/longrunning/autogen/OperationsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/longrunning/autogen/OperationsClient/ListOperations/main.go b/internal/generated/snippets/longrunning/autogen/OperationsClient/ListOperations/main.go index 597c38e9a978..e901177e34c6 100644 --- a/internal/generated/snippets/longrunning/autogen/OperationsClient/ListOperations/main.go +++ b/internal/generated/snippets/longrunning/autogen/OperationsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/longrunning/autogen/OperationsClient/WaitOperation/main.go b/internal/generated/snippets/longrunning/autogen/OperationsClient/WaitOperation/main.go index 636c065094b3..2effabb3c8fa 100644 --- a/internal/generated/snippets/longrunning/autogen/OperationsClient/WaitOperation/main.go +++ b/internal/generated/snippets/longrunning/autogen/OperationsClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedidentities/apiv1/Client/AttachTrust/main.go b/internal/generated/snippets/managedidentities/apiv1/Client/AttachTrust/main.go index 1928f91d8afa..63811c45eec9 100644 --- a/internal/generated/snippets/managedidentities/apiv1/Client/AttachTrust/main.go +++ b/internal/generated/snippets/managedidentities/apiv1/Client/AttachTrust/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedidentities/apiv1/Client/CreateMicrosoftAdDomain/main.go b/internal/generated/snippets/managedidentities/apiv1/Client/CreateMicrosoftAdDomain/main.go index 5bf94a7ec6c2..e1375108bd50 100644 --- a/internal/generated/snippets/managedidentities/apiv1/Client/CreateMicrosoftAdDomain/main.go +++ b/internal/generated/snippets/managedidentities/apiv1/Client/CreateMicrosoftAdDomain/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedidentities/apiv1/Client/DeleteDomain/main.go b/internal/generated/snippets/managedidentities/apiv1/Client/DeleteDomain/main.go index 34ebcb865b1b..b7269d9496cc 100644 --- a/internal/generated/snippets/managedidentities/apiv1/Client/DeleteDomain/main.go +++ b/internal/generated/snippets/managedidentities/apiv1/Client/DeleteDomain/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedidentities/apiv1/Client/DetachTrust/main.go b/internal/generated/snippets/managedidentities/apiv1/Client/DetachTrust/main.go index 226b6cfd4695..dfb5f595de14 100644 --- a/internal/generated/snippets/managedidentities/apiv1/Client/DetachTrust/main.go +++ b/internal/generated/snippets/managedidentities/apiv1/Client/DetachTrust/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedidentities/apiv1/Client/GetDomain/main.go b/internal/generated/snippets/managedidentities/apiv1/Client/GetDomain/main.go index 7a94814a22ce..e79e247cdeb6 100644 --- a/internal/generated/snippets/managedidentities/apiv1/Client/GetDomain/main.go +++ b/internal/generated/snippets/managedidentities/apiv1/Client/GetDomain/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedidentities/apiv1/Client/ListDomains/main.go b/internal/generated/snippets/managedidentities/apiv1/Client/ListDomains/main.go index 9f430238e101..9baed8947624 100644 --- a/internal/generated/snippets/managedidentities/apiv1/Client/ListDomains/main.go +++ b/internal/generated/snippets/managedidentities/apiv1/Client/ListDomains/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedidentities/apiv1/Client/ReconfigureTrust/main.go b/internal/generated/snippets/managedidentities/apiv1/Client/ReconfigureTrust/main.go index a352b7e516e8..16146ae2a045 100644 --- a/internal/generated/snippets/managedidentities/apiv1/Client/ReconfigureTrust/main.go +++ b/internal/generated/snippets/managedidentities/apiv1/Client/ReconfigureTrust/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedidentities/apiv1/Client/ResetAdminPassword/main.go b/internal/generated/snippets/managedidentities/apiv1/Client/ResetAdminPassword/main.go index 3ebdcfd2ce68..148296291b53 100644 --- a/internal/generated/snippets/managedidentities/apiv1/Client/ResetAdminPassword/main.go +++ b/internal/generated/snippets/managedidentities/apiv1/Client/ResetAdminPassword/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedidentities/apiv1/Client/UpdateDomain/main.go b/internal/generated/snippets/managedidentities/apiv1/Client/UpdateDomain/main.go index ca40d75f2899..5a504d3b9a27 100644 --- a/internal/generated/snippets/managedidentities/apiv1/Client/UpdateDomain/main.go +++ b/internal/generated/snippets/managedidentities/apiv1/Client/UpdateDomain/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedidentities/apiv1/Client/ValidateTrust/main.go b/internal/generated/snippets/managedidentities/apiv1/Client/ValidateTrust/main.go index ab8aa4f880dd..5ea282832429 100644 --- a/internal/generated/snippets/managedidentities/apiv1/Client/ValidateTrust/main.go +++ b/internal/generated/snippets/managedidentities/apiv1/Client/ValidateTrust/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedkafka/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/managedkafka/apiv1/Client/CancelOperation/main.go index 8c63441699c2..ec05260ff01c 100644 --- a/internal/generated/snippets/managedkafka/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/managedkafka/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedkafka/apiv1/Client/CreateCluster/main.go b/internal/generated/snippets/managedkafka/apiv1/Client/CreateCluster/main.go index 75715a2f7941..e3fc57f98abf 100644 --- a/internal/generated/snippets/managedkafka/apiv1/Client/CreateCluster/main.go +++ b/internal/generated/snippets/managedkafka/apiv1/Client/CreateCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedkafka/apiv1/Client/CreateTopic/main.go b/internal/generated/snippets/managedkafka/apiv1/Client/CreateTopic/main.go index 9c15781741c1..20d0cd4eefb5 100644 --- a/internal/generated/snippets/managedkafka/apiv1/Client/CreateTopic/main.go +++ b/internal/generated/snippets/managedkafka/apiv1/Client/CreateTopic/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedkafka/apiv1/Client/DeleteCluster/main.go b/internal/generated/snippets/managedkafka/apiv1/Client/DeleteCluster/main.go index 981abdde9ec9..ba9872f0a872 100644 --- a/internal/generated/snippets/managedkafka/apiv1/Client/DeleteCluster/main.go +++ b/internal/generated/snippets/managedkafka/apiv1/Client/DeleteCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedkafka/apiv1/Client/DeleteConsumerGroup/main.go b/internal/generated/snippets/managedkafka/apiv1/Client/DeleteConsumerGroup/main.go index 75b13ea3c172..6938a3bbc58a 100644 --- a/internal/generated/snippets/managedkafka/apiv1/Client/DeleteConsumerGroup/main.go +++ b/internal/generated/snippets/managedkafka/apiv1/Client/DeleteConsumerGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedkafka/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/managedkafka/apiv1/Client/DeleteOperation/main.go index 1679cb3e6343..a3234de71dd0 100644 --- a/internal/generated/snippets/managedkafka/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/managedkafka/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedkafka/apiv1/Client/DeleteTopic/main.go b/internal/generated/snippets/managedkafka/apiv1/Client/DeleteTopic/main.go index c27853a15064..8bb95cf8bb1e 100644 --- a/internal/generated/snippets/managedkafka/apiv1/Client/DeleteTopic/main.go +++ b/internal/generated/snippets/managedkafka/apiv1/Client/DeleteTopic/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedkafka/apiv1/Client/GetCluster/main.go b/internal/generated/snippets/managedkafka/apiv1/Client/GetCluster/main.go index 66bf9bfc4b8e..16f849c166ae 100644 --- a/internal/generated/snippets/managedkafka/apiv1/Client/GetCluster/main.go +++ b/internal/generated/snippets/managedkafka/apiv1/Client/GetCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedkafka/apiv1/Client/GetConsumerGroup/main.go b/internal/generated/snippets/managedkafka/apiv1/Client/GetConsumerGroup/main.go index 9443b62d9d00..e80f21b89bba 100644 --- a/internal/generated/snippets/managedkafka/apiv1/Client/GetConsumerGroup/main.go +++ b/internal/generated/snippets/managedkafka/apiv1/Client/GetConsumerGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedkafka/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/managedkafka/apiv1/Client/GetLocation/main.go index 9122f1dd630c..b431094e7257 100644 --- a/internal/generated/snippets/managedkafka/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/managedkafka/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedkafka/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/managedkafka/apiv1/Client/GetOperation/main.go index be7db3a68da4..3d6011f30676 100644 --- a/internal/generated/snippets/managedkafka/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/managedkafka/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedkafka/apiv1/Client/GetTopic/main.go b/internal/generated/snippets/managedkafka/apiv1/Client/GetTopic/main.go index ca53056bb695..2650fdef0413 100644 --- a/internal/generated/snippets/managedkafka/apiv1/Client/GetTopic/main.go +++ b/internal/generated/snippets/managedkafka/apiv1/Client/GetTopic/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedkafka/apiv1/Client/ListClusters/main.go b/internal/generated/snippets/managedkafka/apiv1/Client/ListClusters/main.go index 47272c447fea..45289ff03f6d 100644 --- a/internal/generated/snippets/managedkafka/apiv1/Client/ListClusters/main.go +++ b/internal/generated/snippets/managedkafka/apiv1/Client/ListClusters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedkafka/apiv1/Client/ListConsumerGroups/main.go b/internal/generated/snippets/managedkafka/apiv1/Client/ListConsumerGroups/main.go index f691d90546f1..e4d5ebdd706d 100644 --- a/internal/generated/snippets/managedkafka/apiv1/Client/ListConsumerGroups/main.go +++ b/internal/generated/snippets/managedkafka/apiv1/Client/ListConsumerGroups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedkafka/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/managedkafka/apiv1/Client/ListLocations/main.go index a051f57eae61..8328467ca128 100644 --- a/internal/generated/snippets/managedkafka/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/managedkafka/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedkafka/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/managedkafka/apiv1/Client/ListOperations/main.go index 40ea0f6d00b6..14ace8128569 100644 --- a/internal/generated/snippets/managedkafka/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/managedkafka/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedkafka/apiv1/Client/ListTopics/main.go b/internal/generated/snippets/managedkafka/apiv1/Client/ListTopics/main.go index 5896c0c79ff0..bd74a9cfffee 100644 --- a/internal/generated/snippets/managedkafka/apiv1/Client/ListTopics/main.go +++ b/internal/generated/snippets/managedkafka/apiv1/Client/ListTopics/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedkafka/apiv1/Client/UpdateCluster/main.go b/internal/generated/snippets/managedkafka/apiv1/Client/UpdateCluster/main.go index 89a0fc9f5e55..7719feff5381 100644 --- a/internal/generated/snippets/managedkafka/apiv1/Client/UpdateCluster/main.go +++ b/internal/generated/snippets/managedkafka/apiv1/Client/UpdateCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedkafka/apiv1/Client/UpdateConsumerGroup/main.go b/internal/generated/snippets/managedkafka/apiv1/Client/UpdateConsumerGroup/main.go index 43b8dd7f33bc..4274045e01a0 100644 --- a/internal/generated/snippets/managedkafka/apiv1/Client/UpdateConsumerGroup/main.go +++ b/internal/generated/snippets/managedkafka/apiv1/Client/UpdateConsumerGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedkafka/apiv1/Client/UpdateTopic/main.go b/internal/generated/snippets/managedkafka/apiv1/Client/UpdateTopic/main.go index 23d58974da78..215b2ff00d5e 100644 --- a/internal/generated/snippets/managedkafka/apiv1/Client/UpdateTopic/main.go +++ b/internal/generated/snippets/managedkafka/apiv1/Client/UpdateTopic/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/managedkafka/apiv1/snippet_metadata.google.cloud.managedkafka.v1.json b/internal/generated/snippets/managedkafka/apiv1/snippet_metadata.google.cloud.managedkafka.v1.json index c1c002531f0e..51fb3449a5d5 100644 --- a/internal/generated/snippets/managedkafka/apiv1/snippet_metadata.google.cloud.managedkafka.v1.json +++ b/internal/generated/snippets/managedkafka/apiv1/snippet_metadata.google.cloud.managedkafka.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/managedkafka/apiv1", - "version": "0.3.0", + "version": "0.3.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/maps/addressvalidation/apiv1/Client/ProvideValidationFeedback/main.go b/internal/generated/snippets/maps/addressvalidation/apiv1/Client/ProvideValidationFeedback/main.go index a11d26ea4d02..cd003973ef9b 100644 --- a/internal/generated/snippets/maps/addressvalidation/apiv1/Client/ProvideValidationFeedback/main.go +++ b/internal/generated/snippets/maps/addressvalidation/apiv1/Client/ProvideValidationFeedback/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/addressvalidation/apiv1/Client/ValidateAddress/main.go b/internal/generated/snippets/maps/addressvalidation/apiv1/Client/ValidateAddress/main.go index 0e5d600a5e36..141162571d3c 100644 --- a/internal/generated/snippets/maps/addressvalidation/apiv1/Client/ValidateAddress/main.go +++ b/internal/generated/snippets/maps/addressvalidation/apiv1/Client/ValidateAddress/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/addressvalidation/apiv1/snippet_metadata.google.maps.addressvalidation.v1.json b/internal/generated/snippets/maps/addressvalidation/apiv1/snippet_metadata.google.maps.addressvalidation.v1.json index 34e614e24290..c394a23dd244 100644 --- a/internal/generated/snippets/maps/addressvalidation/apiv1/snippet_metadata.google.maps.addressvalidation.v1.json +++ b/internal/generated/snippets/maps/addressvalidation/apiv1/snippet_metadata.google.maps.addressvalidation.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/maps/addressvalidation/apiv1", - "version": "1.17.0", + "version": "1.17.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/maps/areainsights/apiv1/Client/ComputeInsights/main.go b/internal/generated/snippets/maps/areainsights/apiv1/Client/ComputeInsights/main.go index 1beddfd16bbc..3c3b52b73322 100644 --- a/internal/generated/snippets/maps/areainsights/apiv1/Client/ComputeInsights/main.go +++ b/internal/generated/snippets/maps/areainsights/apiv1/Client/ComputeInsights/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/areainsights/apiv1/snippet_metadata.google.maps.areainsights.v1.json b/internal/generated/snippets/maps/areainsights/apiv1/snippet_metadata.google.maps.areainsights.v1.json index 5d59aa3f0389..15a59aff8234 100644 --- a/internal/generated/snippets/maps/areainsights/apiv1/snippet_metadata.google.maps.areainsights.v1.json +++ b/internal/generated/snippets/maps/areainsights/apiv1/snippet_metadata.google.maps.areainsights.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/maps/areainsights/apiv1", - "version": "1.17.0", + "version": "1.17.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/maps/fleetengine/apiv1/TripClient/CreateTrip/main.go b/internal/generated/snippets/maps/fleetengine/apiv1/TripClient/CreateTrip/main.go index 1620cc5cfdad..38c78b02f177 100644 --- a/internal/generated/snippets/maps/fleetengine/apiv1/TripClient/CreateTrip/main.go +++ b/internal/generated/snippets/maps/fleetengine/apiv1/TripClient/CreateTrip/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/fleetengine/apiv1/TripClient/GetTrip/main.go b/internal/generated/snippets/maps/fleetengine/apiv1/TripClient/GetTrip/main.go index d3fb1041a00f..3b1d620c5e26 100644 --- a/internal/generated/snippets/maps/fleetengine/apiv1/TripClient/GetTrip/main.go +++ b/internal/generated/snippets/maps/fleetengine/apiv1/TripClient/GetTrip/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/fleetengine/apiv1/TripClient/ReportBillableTrip/main.go b/internal/generated/snippets/maps/fleetengine/apiv1/TripClient/ReportBillableTrip/main.go index bb0aa15c1beb..3990ac336845 100644 --- a/internal/generated/snippets/maps/fleetengine/apiv1/TripClient/ReportBillableTrip/main.go +++ b/internal/generated/snippets/maps/fleetengine/apiv1/TripClient/ReportBillableTrip/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/fleetengine/apiv1/TripClient/SearchTrips/main.go b/internal/generated/snippets/maps/fleetengine/apiv1/TripClient/SearchTrips/main.go index 7b83dbe83a90..8e729488e197 100644 --- a/internal/generated/snippets/maps/fleetengine/apiv1/TripClient/SearchTrips/main.go +++ b/internal/generated/snippets/maps/fleetengine/apiv1/TripClient/SearchTrips/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/fleetengine/apiv1/TripClient/UpdateTrip/main.go b/internal/generated/snippets/maps/fleetengine/apiv1/TripClient/UpdateTrip/main.go index db494c15f2b1..89a6e15ed2e1 100644 --- a/internal/generated/snippets/maps/fleetengine/apiv1/TripClient/UpdateTrip/main.go +++ b/internal/generated/snippets/maps/fleetengine/apiv1/TripClient/UpdateTrip/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/fleetengine/apiv1/VehicleClient/CreateVehicle/main.go b/internal/generated/snippets/maps/fleetengine/apiv1/VehicleClient/CreateVehicle/main.go index 127b619cc457..08f1ba8e7712 100644 --- a/internal/generated/snippets/maps/fleetengine/apiv1/VehicleClient/CreateVehicle/main.go +++ b/internal/generated/snippets/maps/fleetengine/apiv1/VehicleClient/CreateVehicle/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/fleetengine/apiv1/VehicleClient/GetVehicle/main.go b/internal/generated/snippets/maps/fleetengine/apiv1/VehicleClient/GetVehicle/main.go index 7bc3cad949d7..51cbb860a276 100644 --- a/internal/generated/snippets/maps/fleetengine/apiv1/VehicleClient/GetVehicle/main.go +++ b/internal/generated/snippets/maps/fleetengine/apiv1/VehicleClient/GetVehicle/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/fleetengine/apiv1/VehicleClient/ListVehicles/main.go b/internal/generated/snippets/maps/fleetengine/apiv1/VehicleClient/ListVehicles/main.go index 278aae38de66..197adaf3c188 100644 --- a/internal/generated/snippets/maps/fleetengine/apiv1/VehicleClient/ListVehicles/main.go +++ b/internal/generated/snippets/maps/fleetengine/apiv1/VehicleClient/ListVehicles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/fleetengine/apiv1/VehicleClient/SearchVehicles/main.go b/internal/generated/snippets/maps/fleetengine/apiv1/VehicleClient/SearchVehicles/main.go index f6fe2901e101..5fd88da2c79c 100644 --- a/internal/generated/snippets/maps/fleetengine/apiv1/VehicleClient/SearchVehicles/main.go +++ b/internal/generated/snippets/maps/fleetengine/apiv1/VehicleClient/SearchVehicles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/fleetengine/apiv1/VehicleClient/UpdateVehicle/main.go b/internal/generated/snippets/maps/fleetengine/apiv1/VehicleClient/UpdateVehicle/main.go index 3ff82dc501c4..4df56f0bc2f7 100644 --- a/internal/generated/snippets/maps/fleetengine/apiv1/VehicleClient/UpdateVehicle/main.go +++ b/internal/generated/snippets/maps/fleetengine/apiv1/VehicleClient/UpdateVehicle/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/fleetengine/apiv1/VehicleClient/UpdateVehicleAttributes/main.go b/internal/generated/snippets/maps/fleetengine/apiv1/VehicleClient/UpdateVehicleAttributes/main.go index c33c7ad60d23..730a8b6e84c6 100644 --- a/internal/generated/snippets/maps/fleetengine/apiv1/VehicleClient/UpdateVehicleAttributes/main.go +++ b/internal/generated/snippets/maps/fleetengine/apiv1/VehicleClient/UpdateVehicleAttributes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/fleetengine/apiv1/snippet_metadata.maps.fleetengine.v1.json b/internal/generated/snippets/maps/fleetengine/apiv1/snippet_metadata.maps.fleetengine.v1.json index 7106d6ae1e60..13f4f37953bd 100644 --- a/internal/generated/snippets/maps/fleetengine/apiv1/snippet_metadata.maps.fleetengine.v1.json +++ b/internal/generated/snippets/maps/fleetengine/apiv1/snippet_metadata.maps.fleetengine.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/maps/fleetengine/apiv1", - "version": "1.17.0", + "version": "1.17.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/BatchCreateTasks/main.go b/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/BatchCreateTasks/main.go index f8b9c1e05f2d..82320234fe00 100644 --- a/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/BatchCreateTasks/main.go +++ b/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/BatchCreateTasks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/CreateDeliveryVehicle/main.go b/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/CreateDeliveryVehicle/main.go index ee2e5aa49407..1db63ed1da47 100644 --- a/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/CreateDeliveryVehicle/main.go +++ b/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/CreateDeliveryVehicle/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/CreateTask/main.go b/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/CreateTask/main.go index 7f1a4f441138..99fedd4b11a3 100644 --- a/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/CreateTask/main.go +++ b/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/CreateTask/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/GetDeliveryVehicle/main.go b/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/GetDeliveryVehicle/main.go index 67243aecdbde..74b5f0d693d1 100644 --- a/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/GetDeliveryVehicle/main.go +++ b/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/GetDeliveryVehicle/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/GetTask/main.go b/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/GetTask/main.go index e1a744bfc115..9f2d28cc7eb0 100644 --- a/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/GetTask/main.go +++ b/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/GetTask/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/GetTaskTrackingInfo/main.go b/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/GetTaskTrackingInfo/main.go index 537587650dec..9d461a0a4cd2 100644 --- a/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/GetTaskTrackingInfo/main.go +++ b/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/GetTaskTrackingInfo/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/ListDeliveryVehicles/main.go b/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/ListDeliveryVehicles/main.go index 9778c56841bc..47b2462669cd 100644 --- a/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/ListDeliveryVehicles/main.go +++ b/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/ListDeliveryVehicles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/ListTasks/main.go b/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/ListTasks/main.go index b0c651adefb1..2c5e7deb60b7 100644 --- a/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/ListTasks/main.go +++ b/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/ListTasks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/UpdateDeliveryVehicle/main.go b/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/UpdateDeliveryVehicle/main.go index 94bf3c43a0fa..8f4dbccefd12 100644 --- a/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/UpdateDeliveryVehicle/main.go +++ b/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/UpdateDeliveryVehicle/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/UpdateTask/main.go b/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/UpdateTask/main.go index 597a1792c95f..12d50a8881bd 100644 --- a/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/UpdateTask/main.go +++ b/internal/generated/snippets/maps/fleetengine/delivery/apiv1/Client/UpdateTask/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/fleetengine/delivery/apiv1/snippet_metadata.maps.fleetengine.delivery.v1.json b/internal/generated/snippets/maps/fleetengine/delivery/apiv1/snippet_metadata.maps.fleetengine.delivery.v1.json index e392e163e56a..60d9e8850b50 100644 --- a/internal/generated/snippets/maps/fleetengine/delivery/apiv1/snippet_metadata.maps.fleetengine.delivery.v1.json +++ b/internal/generated/snippets/maps/fleetengine/delivery/apiv1/snippet_metadata.maps.fleetengine.delivery.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/maps/fleetengine/delivery/apiv1", - "version": "1.17.0", + "version": "1.17.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/maps/places/apiv1/Client/AutocompletePlaces/main.go b/internal/generated/snippets/maps/places/apiv1/Client/AutocompletePlaces/main.go index b610c6c788dd..40878eff68f0 100644 --- a/internal/generated/snippets/maps/places/apiv1/Client/AutocompletePlaces/main.go +++ b/internal/generated/snippets/maps/places/apiv1/Client/AutocompletePlaces/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/places/apiv1/Client/GetPhotoMedia/main.go b/internal/generated/snippets/maps/places/apiv1/Client/GetPhotoMedia/main.go index 0a6fc5852a34..1b839b11ffbb 100644 --- a/internal/generated/snippets/maps/places/apiv1/Client/GetPhotoMedia/main.go +++ b/internal/generated/snippets/maps/places/apiv1/Client/GetPhotoMedia/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/places/apiv1/Client/GetPlace/main.go b/internal/generated/snippets/maps/places/apiv1/Client/GetPlace/main.go index d972d4f8dbef..7df978331de5 100644 --- a/internal/generated/snippets/maps/places/apiv1/Client/GetPlace/main.go +++ b/internal/generated/snippets/maps/places/apiv1/Client/GetPlace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/places/apiv1/Client/SearchNearby/main.go b/internal/generated/snippets/maps/places/apiv1/Client/SearchNearby/main.go index b18c67702a06..2cf294cebc41 100644 --- a/internal/generated/snippets/maps/places/apiv1/Client/SearchNearby/main.go +++ b/internal/generated/snippets/maps/places/apiv1/Client/SearchNearby/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/places/apiv1/Client/SearchText/main.go b/internal/generated/snippets/maps/places/apiv1/Client/SearchText/main.go index 95b1812356f2..6071ac0d35cd 100644 --- a/internal/generated/snippets/maps/places/apiv1/Client/SearchText/main.go +++ b/internal/generated/snippets/maps/places/apiv1/Client/SearchText/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/places/apiv1/snippet_metadata.google.maps.places.v1.json b/internal/generated/snippets/maps/places/apiv1/snippet_metadata.google.maps.places.v1.json index 06af1aedcb21..ac864df03280 100644 --- a/internal/generated/snippets/maps/places/apiv1/snippet_metadata.google.maps.places.v1.json +++ b/internal/generated/snippets/maps/places/apiv1/snippet_metadata.google.maps.places.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/maps/places/apiv1", - "version": "1.17.0", + "version": "1.17.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/maps/routeoptimization/apiv1/Client/BatchOptimizeTours/main.go b/internal/generated/snippets/maps/routeoptimization/apiv1/Client/BatchOptimizeTours/main.go index aa21ccbf78f2..a5133ab164e7 100644 --- a/internal/generated/snippets/maps/routeoptimization/apiv1/Client/BatchOptimizeTours/main.go +++ b/internal/generated/snippets/maps/routeoptimization/apiv1/Client/BatchOptimizeTours/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/routeoptimization/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/maps/routeoptimization/apiv1/Client/GetOperation/main.go index 2d4e2413dc20..1698aee6967e 100644 --- a/internal/generated/snippets/maps/routeoptimization/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/maps/routeoptimization/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/routeoptimization/apiv1/Client/OptimizeTours/main.go b/internal/generated/snippets/maps/routeoptimization/apiv1/Client/OptimizeTours/main.go index 50b93a7cc21b..459d211d67a4 100644 --- a/internal/generated/snippets/maps/routeoptimization/apiv1/Client/OptimizeTours/main.go +++ b/internal/generated/snippets/maps/routeoptimization/apiv1/Client/OptimizeTours/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/routeoptimization/apiv1/snippet_metadata.google.maps.routeoptimization.v1.json b/internal/generated/snippets/maps/routeoptimization/apiv1/snippet_metadata.google.maps.routeoptimization.v1.json index 939e97fd1c18..5faa581f439f 100644 --- a/internal/generated/snippets/maps/routeoptimization/apiv1/snippet_metadata.google.maps.routeoptimization.v1.json +++ b/internal/generated/snippets/maps/routeoptimization/apiv1/snippet_metadata.google.maps.routeoptimization.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/maps/routeoptimization/apiv1", - "version": "1.17.0", + "version": "1.17.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/maps/routing/apiv2/RoutesClient/ComputeRoutes/main.go b/internal/generated/snippets/maps/routing/apiv2/RoutesClient/ComputeRoutes/main.go index 152f52ef309d..1bb433c2ef57 100644 --- a/internal/generated/snippets/maps/routing/apiv2/RoutesClient/ComputeRoutes/main.go +++ b/internal/generated/snippets/maps/routing/apiv2/RoutesClient/ComputeRoutes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/routing/apiv2/snippet_metadata.google.maps.routing.v2.json b/internal/generated/snippets/maps/routing/apiv2/snippet_metadata.google.maps.routing.v2.json index 34ce68f7d323..2a4f021a5837 100644 --- a/internal/generated/snippets/maps/routing/apiv2/snippet_metadata.google.maps.routing.v2.json +++ b/internal/generated/snippets/maps/routing/apiv2/snippet_metadata.google.maps.routing.v2.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/maps/routing/apiv2", - "version": "1.17.0", + "version": "1.17.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/maps/solar/apiv1/Client/FindClosestBuildingInsights/main.go b/internal/generated/snippets/maps/solar/apiv1/Client/FindClosestBuildingInsights/main.go index f8bdbb257bf0..21094706f7b4 100644 --- a/internal/generated/snippets/maps/solar/apiv1/Client/FindClosestBuildingInsights/main.go +++ b/internal/generated/snippets/maps/solar/apiv1/Client/FindClosestBuildingInsights/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/solar/apiv1/Client/GetDataLayers/main.go b/internal/generated/snippets/maps/solar/apiv1/Client/GetDataLayers/main.go index d938d06496d6..43428fb27815 100644 --- a/internal/generated/snippets/maps/solar/apiv1/Client/GetDataLayers/main.go +++ b/internal/generated/snippets/maps/solar/apiv1/Client/GetDataLayers/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/solar/apiv1/Client/GetGeoTiff/main.go b/internal/generated/snippets/maps/solar/apiv1/Client/GetGeoTiff/main.go index 5edf26d20fb4..aba1121d1da2 100644 --- a/internal/generated/snippets/maps/solar/apiv1/Client/GetGeoTiff/main.go +++ b/internal/generated/snippets/maps/solar/apiv1/Client/GetGeoTiff/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/maps/solar/apiv1/snippet_metadata.google.maps.solar.v1.json b/internal/generated/snippets/maps/solar/apiv1/snippet_metadata.google.maps.solar.v1.json index cc8cd8caf8d7..39274d9faf21 100644 --- a/internal/generated/snippets/maps/solar/apiv1/snippet_metadata.google.maps.solar.v1.json +++ b/internal/generated/snippets/maps/solar/apiv1/snippet_metadata.google.maps.solar.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/maps/solar/apiv1", - "version": "1.17.0", + "version": "1.17.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/mediatranslation/apiv1beta1/SpeechTranslationClient/StreamingTranslateSpeech/main.go b/internal/generated/snippets/mediatranslation/apiv1beta1/SpeechTranslationClient/StreamingTranslateSpeech/main.go index 131471300631..4a050eba2a38 100644 --- a/internal/generated/snippets/mediatranslation/apiv1beta1/SpeechTranslationClient/StreamingTranslateSpeech/main.go +++ b/internal/generated/snippets/mediatranslation/apiv1beta1/SpeechTranslationClient/StreamingTranslateSpeech/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/ApplyParameters/main.go b/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/ApplyParameters/main.go index b84d5e8ca38d..4235be096a3e 100644 --- a/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/ApplyParameters/main.go +++ b/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/ApplyParameters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/CancelOperation/main.go b/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/CancelOperation/main.go index 7b0ad1f541cd..9a34ffeaae86 100644 --- a/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/CancelOperation/main.go +++ b/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/CreateInstance/main.go b/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/CreateInstance/main.go index a2c452196f5f..6366609d72b7 100644 --- a/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/CreateInstance/main.go +++ b/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/CreateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/DeleteInstance/main.go b/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/DeleteInstance/main.go index eadd9aa654d6..d6d7b361d077 100644 --- a/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/DeleteInstance/main.go +++ b/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/DeleteInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/DeleteOperation/main.go b/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/DeleteOperation/main.go index 6950dd6c3bdd..9ae54320bd0f 100644 --- a/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/DeleteOperation/main.go +++ b/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/GetInstance/main.go b/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/GetInstance/main.go index 71e1d99b00d2..2324bde0db16 100644 --- a/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/GetInstance/main.go +++ b/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/GetInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/GetLocation/main.go b/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/GetLocation/main.go index c7817ab4d5a6..fcfce5e4f7b3 100644 --- a/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/GetLocation/main.go +++ b/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/GetOperation/main.go b/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/GetOperation/main.go index ca72c3988316..c75547bb2181 100644 --- a/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/GetOperation/main.go +++ b/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/ListInstances/main.go b/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/ListInstances/main.go index 949cd43053c8..8d18af43c966 100644 --- a/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/ListInstances/main.go +++ b/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/ListInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/ListLocations/main.go b/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/ListLocations/main.go index d517ec2f2d76..6cb575a91c9f 100644 --- a/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/ListLocations/main.go +++ b/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/ListOperations/main.go b/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/ListOperations/main.go index 5c72c9c03425..3f05129486b3 100644 --- a/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/ListOperations/main.go +++ b/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/RescheduleMaintenance/main.go b/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/RescheduleMaintenance/main.go index c4caeeb75be4..e0346f7a4282 100644 --- a/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/RescheduleMaintenance/main.go +++ b/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/RescheduleMaintenance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/UpdateInstance/main.go b/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/UpdateInstance/main.go index 74a0316f7a5d..96a2b2821e21 100644 --- a/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/UpdateInstance/main.go +++ b/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/UpdateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/UpdateParameters/main.go b/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/UpdateParameters/main.go index 43d0c8d121fa..5bc5de431440 100644 --- a/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/UpdateParameters/main.go +++ b/internal/generated/snippets/memcache/apiv1/CloudMemcacheClient/UpdateParameters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/ApplyParameters/main.go b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/ApplyParameters/main.go index 7cd70347b5a3..9dc672d84f2b 100644 --- a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/ApplyParameters/main.go +++ b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/ApplyParameters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/ApplySoftwareUpdate/main.go b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/ApplySoftwareUpdate/main.go index f5c382062cf7..58eed43100cf 100644 --- a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/ApplySoftwareUpdate/main.go +++ b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/ApplySoftwareUpdate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/CancelOperation/main.go b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/CancelOperation/main.go index b8640d55820c..fc612ef242ce 100644 --- a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/CancelOperation/main.go +++ b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/CreateInstance/main.go b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/CreateInstance/main.go index 13888ed59fd3..53c25f24d9cb 100644 --- a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/CreateInstance/main.go +++ b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/CreateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/DeleteInstance/main.go b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/DeleteInstance/main.go index f541e3814b7d..2ca9e779b275 100644 --- a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/DeleteInstance/main.go +++ b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/DeleteInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/DeleteOperation/main.go b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/DeleteOperation/main.go index c504257898d1..696d8d5e9e48 100644 --- a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/DeleteOperation/main.go +++ b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/GetInstance/main.go b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/GetInstance/main.go index fdf9f3b191e7..a97ff1a7cabc 100644 --- a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/GetInstance/main.go +++ b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/GetInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/GetLocation/main.go b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/GetLocation/main.go index 1e78b4f64c39..c80f1b41451c 100644 --- a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/GetLocation/main.go +++ b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/GetOperation/main.go b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/GetOperation/main.go index ebfe8b3488ab..d83b11a5fe66 100644 --- a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/GetOperation/main.go +++ b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/ListInstances/main.go b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/ListInstances/main.go index 3f27ee7dc405..19957fb57569 100644 --- a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/ListInstances/main.go +++ b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/ListInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/ListLocations/main.go b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/ListLocations/main.go index 017070dafd5e..cbebd3e56957 100644 --- a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/ListLocations/main.go +++ b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/ListOperations/main.go b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/ListOperations/main.go index 6a6a8dbb2e2f..6e4522a82a2c 100644 --- a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/ListOperations/main.go +++ b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/RescheduleMaintenance/main.go b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/RescheduleMaintenance/main.go index 0dc653779bff..7f7eb4ffe04e 100644 --- a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/RescheduleMaintenance/main.go +++ b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/RescheduleMaintenance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/UpdateInstance/main.go b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/UpdateInstance/main.go index ddeba64929ee..87c6a584f9e1 100644 --- a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/UpdateInstance/main.go +++ b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/UpdateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/UpdateParameters/main.go b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/UpdateParameters/main.go index 2ade6eb3243e..e5c7d3e674bd 100644 --- a/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/UpdateParameters/main.go +++ b/internal/generated/snippets/memcache/apiv1beta2/CloudMemcacheClient/UpdateParameters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memorystore/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/memorystore/apiv1/Client/CancelOperation/main.go index 3ab87c8f8725..edcbc4c04aa4 100644 --- a/internal/generated/snippets/memorystore/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/memorystore/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memorystore/apiv1/Client/CreateInstance/main.go b/internal/generated/snippets/memorystore/apiv1/Client/CreateInstance/main.go index c3bf950b9005..ca162bd39baf 100644 --- a/internal/generated/snippets/memorystore/apiv1/Client/CreateInstance/main.go +++ b/internal/generated/snippets/memorystore/apiv1/Client/CreateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memorystore/apiv1/Client/DeleteInstance/main.go b/internal/generated/snippets/memorystore/apiv1/Client/DeleteInstance/main.go index d981522104fe..a5892ffccc95 100644 --- a/internal/generated/snippets/memorystore/apiv1/Client/DeleteInstance/main.go +++ b/internal/generated/snippets/memorystore/apiv1/Client/DeleteInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memorystore/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/memorystore/apiv1/Client/DeleteOperation/main.go index bf99bd8236d2..0579d0f68f0d 100644 --- a/internal/generated/snippets/memorystore/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/memorystore/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memorystore/apiv1/Client/GetCertificateAuthority/main.go b/internal/generated/snippets/memorystore/apiv1/Client/GetCertificateAuthority/main.go index 987717ba8009..e2c96b96ea64 100644 --- a/internal/generated/snippets/memorystore/apiv1/Client/GetCertificateAuthority/main.go +++ b/internal/generated/snippets/memorystore/apiv1/Client/GetCertificateAuthority/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memorystore/apiv1/Client/GetInstance/main.go b/internal/generated/snippets/memorystore/apiv1/Client/GetInstance/main.go index f6de8e1f70b3..9e6cbd2432fd 100644 --- a/internal/generated/snippets/memorystore/apiv1/Client/GetInstance/main.go +++ b/internal/generated/snippets/memorystore/apiv1/Client/GetInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memorystore/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/memorystore/apiv1/Client/GetLocation/main.go index b894df788572..fe1870bce85d 100644 --- a/internal/generated/snippets/memorystore/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/memorystore/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memorystore/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/memorystore/apiv1/Client/GetOperation/main.go index 6c67387fac76..000b3020d143 100644 --- a/internal/generated/snippets/memorystore/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/memorystore/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memorystore/apiv1/Client/ListInstances/main.go b/internal/generated/snippets/memorystore/apiv1/Client/ListInstances/main.go index 57e8dabedec4..3b490016a169 100644 --- a/internal/generated/snippets/memorystore/apiv1/Client/ListInstances/main.go +++ b/internal/generated/snippets/memorystore/apiv1/Client/ListInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memorystore/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/memorystore/apiv1/Client/ListLocations/main.go index 1404a6d97964..9d2f8cf2d1a0 100644 --- a/internal/generated/snippets/memorystore/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/memorystore/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memorystore/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/memorystore/apiv1/Client/ListOperations/main.go index 14072eb8ab3b..cadd3a20ac67 100644 --- a/internal/generated/snippets/memorystore/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/memorystore/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memorystore/apiv1/Client/UpdateInstance/main.go b/internal/generated/snippets/memorystore/apiv1/Client/UpdateInstance/main.go index ba1afd343f02..d7c076454407 100644 --- a/internal/generated/snippets/memorystore/apiv1/Client/UpdateInstance/main.go +++ b/internal/generated/snippets/memorystore/apiv1/Client/UpdateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memorystore/apiv1/snippet_metadata.google.cloud.memorystore.v1.json b/internal/generated/snippets/memorystore/apiv1/snippet_metadata.google.cloud.memorystore.v1.json index d7ebc091e120..14ff0154b218 100644 --- a/internal/generated/snippets/memorystore/apiv1/snippet_metadata.google.cloud.memorystore.v1.json +++ b/internal/generated/snippets/memorystore/apiv1/snippet_metadata.google.cloud.memorystore.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/memorystore/apiv1", - "version": "0.1.0", + "version": "0.1.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/memorystore/apiv1beta/Client/CancelOperation/main.go b/internal/generated/snippets/memorystore/apiv1beta/Client/CancelOperation/main.go index 26893599af45..ff4f9243d711 100644 --- a/internal/generated/snippets/memorystore/apiv1beta/Client/CancelOperation/main.go +++ b/internal/generated/snippets/memorystore/apiv1beta/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memorystore/apiv1beta/Client/CreateInstance/main.go b/internal/generated/snippets/memorystore/apiv1beta/Client/CreateInstance/main.go index 3a36771dcf6b..34878acf3752 100644 --- a/internal/generated/snippets/memorystore/apiv1beta/Client/CreateInstance/main.go +++ b/internal/generated/snippets/memorystore/apiv1beta/Client/CreateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memorystore/apiv1beta/Client/DeleteInstance/main.go b/internal/generated/snippets/memorystore/apiv1beta/Client/DeleteInstance/main.go index 1a2185551351..60230d9af7cf 100644 --- a/internal/generated/snippets/memorystore/apiv1beta/Client/DeleteInstance/main.go +++ b/internal/generated/snippets/memorystore/apiv1beta/Client/DeleteInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memorystore/apiv1beta/Client/DeleteOperation/main.go b/internal/generated/snippets/memorystore/apiv1beta/Client/DeleteOperation/main.go index c719d93bfd87..3b4072b3d7d0 100644 --- a/internal/generated/snippets/memorystore/apiv1beta/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/memorystore/apiv1beta/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memorystore/apiv1beta/Client/GetCertificateAuthority/main.go b/internal/generated/snippets/memorystore/apiv1beta/Client/GetCertificateAuthority/main.go index a7c0dfcc8934..991f6d1918f1 100644 --- a/internal/generated/snippets/memorystore/apiv1beta/Client/GetCertificateAuthority/main.go +++ b/internal/generated/snippets/memorystore/apiv1beta/Client/GetCertificateAuthority/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memorystore/apiv1beta/Client/GetInstance/main.go b/internal/generated/snippets/memorystore/apiv1beta/Client/GetInstance/main.go index ec2166d614be..ccfc9e2c9e81 100644 --- a/internal/generated/snippets/memorystore/apiv1beta/Client/GetInstance/main.go +++ b/internal/generated/snippets/memorystore/apiv1beta/Client/GetInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memorystore/apiv1beta/Client/GetLocation/main.go b/internal/generated/snippets/memorystore/apiv1beta/Client/GetLocation/main.go index 146b7f1e357c..782b175937b0 100644 --- a/internal/generated/snippets/memorystore/apiv1beta/Client/GetLocation/main.go +++ b/internal/generated/snippets/memorystore/apiv1beta/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memorystore/apiv1beta/Client/GetOperation/main.go b/internal/generated/snippets/memorystore/apiv1beta/Client/GetOperation/main.go index 600a431cce7a..811283851a28 100644 --- a/internal/generated/snippets/memorystore/apiv1beta/Client/GetOperation/main.go +++ b/internal/generated/snippets/memorystore/apiv1beta/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memorystore/apiv1beta/Client/ListInstances/main.go b/internal/generated/snippets/memorystore/apiv1beta/Client/ListInstances/main.go index 4fba0274068a..84502822902d 100644 --- a/internal/generated/snippets/memorystore/apiv1beta/Client/ListInstances/main.go +++ b/internal/generated/snippets/memorystore/apiv1beta/Client/ListInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memorystore/apiv1beta/Client/ListLocations/main.go b/internal/generated/snippets/memorystore/apiv1beta/Client/ListLocations/main.go index 1a87dc0a3a5b..155e84326265 100644 --- a/internal/generated/snippets/memorystore/apiv1beta/Client/ListLocations/main.go +++ b/internal/generated/snippets/memorystore/apiv1beta/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memorystore/apiv1beta/Client/ListOperations/main.go b/internal/generated/snippets/memorystore/apiv1beta/Client/ListOperations/main.go index 2001a0618927..5b906ca2ee39 100644 --- a/internal/generated/snippets/memorystore/apiv1beta/Client/ListOperations/main.go +++ b/internal/generated/snippets/memorystore/apiv1beta/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memorystore/apiv1beta/Client/UpdateInstance/main.go b/internal/generated/snippets/memorystore/apiv1beta/Client/UpdateInstance/main.go index f18b2175d46c..be7b70be1286 100644 --- a/internal/generated/snippets/memorystore/apiv1beta/Client/UpdateInstance/main.go +++ b/internal/generated/snippets/memorystore/apiv1beta/Client/UpdateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/memorystore/apiv1beta/snippet_metadata.google.cloud.memorystore.v1beta.json b/internal/generated/snippets/memorystore/apiv1beta/snippet_metadata.google.cloud.memorystore.v1beta.json index e618b9f2e7b9..b40a929c69db 100644 --- a/internal/generated/snippets/memorystore/apiv1beta/snippet_metadata.google.cloud.memorystore.v1beta.json +++ b/internal/generated/snippets/memorystore/apiv1beta/snippet_metadata.google.cloud.memorystore.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/memorystore/apiv1beta", - "version": "0.1.0", + "version": "0.1.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/AlterMetadataResourceLocation/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/AlterMetadataResourceLocation/main.go index 73b156dbbc62..3fefe828b444 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/AlterMetadataResourceLocation/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/AlterMetadataResourceLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/CancelOperation/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/CancelOperation/main.go index 8a6dda771ce8..de5d4adc53b8 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/CancelOperation/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/CreateBackup/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/CreateBackup/main.go index 9458b4f5762e..62a313b14127 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/CreateBackup/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/CreateBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/CreateMetadataImport/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/CreateMetadataImport/main.go index 1cc745e05a10..b32ec94d850d 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/CreateMetadataImport/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/CreateMetadataImport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/CreateService/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/CreateService/main.go index 8005cc90666d..e80f90156127 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/CreateService/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/CreateService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/DeleteBackup/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/DeleteBackup/main.go index 5fec60d5a8a1..ebaf17ec08b7 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/DeleteBackup/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/DeleteBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/DeleteOperation/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/DeleteOperation/main.go index 1f17ce77c3c9..d29a9d2b11e3 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/DeleteOperation/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/DeleteService/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/DeleteService/main.go index a4017c7eef70..a3da1895485d 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/DeleteService/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/DeleteService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/ExportMetadata/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/ExportMetadata/main.go index e57b99d40e33..8e84cc2f43e1 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/ExportMetadata/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/ExportMetadata/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/GetBackup/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/GetBackup/main.go index 8f3c7a60c9e3..5adafd205f9d 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/GetBackup/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/GetBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/GetIamPolicy/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/GetIamPolicy/main.go index e44885e5ea0a..a680e6a572f7 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/GetLocation/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/GetLocation/main.go index 1c2c02010a09..cb8bacc4f486 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/GetLocation/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/GetMetadataImport/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/GetMetadataImport/main.go index 8965bb686392..93bac87e8a2c 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/GetMetadataImport/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/GetMetadataImport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/GetOperation/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/GetOperation/main.go index bf4c301420f9..f872d3696d2c 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/GetOperation/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/GetService/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/GetService/main.go index b5582d1b4a04..5f9e5abd9e35 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/GetService/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/GetService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/ListBackups/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/ListBackups/main.go index 05e85e7caf58..5e168461eb3c 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/ListBackups/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/ListBackups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/ListLocations/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/ListLocations/main.go index d4ccdcf65383..e19b8d099055 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/ListLocations/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/ListMetadataImports/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/ListMetadataImports/main.go index e87de22c6144..8ff4a35d2488 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/ListMetadataImports/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/ListMetadataImports/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/ListOperations/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/ListOperations/main.go index b51b6e9eb311..21e00bf0787d 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/ListOperations/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/ListServices/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/ListServices/main.go index cc00e10b3189..40ef56afffaa 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/ListServices/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/ListServices/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/MoveTableToDatabase/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/MoveTableToDatabase/main.go index 21fca154c6db..8a74bfd2cad6 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/MoveTableToDatabase/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/MoveTableToDatabase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/QueryMetadata/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/QueryMetadata/main.go index 7237f66ffa64..3aafb2d069ec 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/QueryMetadata/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/QueryMetadata/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/RestoreService/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/RestoreService/main.go index b09daf2779d5..a328d6fc1181 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/RestoreService/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/RestoreService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/SetIamPolicy/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/SetIamPolicy/main.go index b2b7977c71a8..d6885731b7a7 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/TestIamPermissions/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/TestIamPermissions/main.go index 4f122bb7f1c1..d2cafed41c47 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/UpdateMetadataImport/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/UpdateMetadataImport/main.go index 14e4d4cbb996..65128a3a682e 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/UpdateMetadataImport/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/UpdateMetadataImport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/UpdateService/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/UpdateService/main.go index 530c4646e882..acdb00cf3819 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/UpdateService/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreClient/UpdateService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/CancelOperation/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/CancelOperation/main.go index 7a3447c23b8b..055afb05fe46 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/CancelOperation/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/CreateFederation/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/CreateFederation/main.go index 826995fd9197..96bef934222c 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/CreateFederation/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/CreateFederation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/DeleteFederation/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/DeleteFederation/main.go index f4144774dcdd..a620f3167baf 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/DeleteFederation/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/DeleteFederation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/DeleteOperation/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/DeleteOperation/main.go index fa3cdba86262..1f345c6eb310 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/DeleteOperation/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/GetFederation/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/GetFederation/main.go index b29e7c5c936d..38679eb7e7db 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/GetFederation/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/GetFederation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/GetIamPolicy/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/GetIamPolicy/main.go index b88f3661de77..7547e4df4db4 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/GetLocation/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/GetLocation/main.go index 6af7ccfd2c33..692f79629b9b 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/GetLocation/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/GetOperation/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/GetOperation/main.go index 4460a2d12f06..7daabe544584 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/GetOperation/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/ListFederations/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/ListFederations/main.go index e3169a694404..f6023deb0ff5 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/ListFederations/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/ListFederations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/ListLocations/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/ListLocations/main.go index a5b5d4c6fd06..17aa45c5db30 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/ListLocations/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/ListOperations/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/ListOperations/main.go index a614e4ea535a..041deb76c879 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/ListOperations/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/SetIamPolicy/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/SetIamPolicy/main.go index fc9f27cc991a..5c9ec2d2e45f 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/TestIamPermissions/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/TestIamPermissions/main.go index e512ff2ef6be..d79db48536a9 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/UpdateFederation/main.go b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/UpdateFederation/main.go index 0151e399fcec..ce62b26cebac 100644 --- a/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/UpdateFederation/main.go +++ b/internal/generated/snippets/metastore/apiv1/DataprocMetastoreFederationClient/UpdateFederation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/AlterMetadataResourceLocation/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/AlterMetadataResourceLocation/main.go index 45cd1e0177ff..ee28a8cfc16e 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/AlterMetadataResourceLocation/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/AlterMetadataResourceLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/CancelOperation/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/CancelOperation/main.go index 8bf23c813d78..3fed63fb9a63 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/CancelOperation/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/CreateBackup/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/CreateBackup/main.go index d38b52c15fd7..2b92e8484cb3 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/CreateBackup/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/CreateBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/CreateMetadataImport/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/CreateMetadataImport/main.go index f28a72ac276f..be3013f021a8 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/CreateMetadataImport/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/CreateMetadataImport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/CreateService/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/CreateService/main.go index 89f84518ed2f..2ee06be2a477 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/CreateService/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/CreateService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/DeleteBackup/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/DeleteBackup/main.go index fda20600e7f2..8e7f7ed8c243 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/DeleteBackup/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/DeleteBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/DeleteOperation/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/DeleteOperation/main.go index 4f06c5be7bad..7c97e4a0027d 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/DeleteOperation/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/DeleteService/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/DeleteService/main.go index 307778ec238b..1c39ed1a3096 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/DeleteService/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/DeleteService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/ExportMetadata/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/ExportMetadata/main.go index 816b76821764..1501c8303ef9 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/ExportMetadata/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/ExportMetadata/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/GetBackup/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/GetBackup/main.go index e85011024ff8..4a5d6d070464 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/GetBackup/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/GetBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/GetIamPolicy/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/GetIamPolicy/main.go index 7c7071e519fd..9cad42caa980 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/GetLocation/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/GetLocation/main.go index 1154b61b2b15..0827db22134f 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/GetLocation/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/GetMetadataImport/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/GetMetadataImport/main.go index 2f5c36222d50..1be939d9a1c2 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/GetMetadataImport/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/GetMetadataImport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/GetOperation/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/GetOperation/main.go index 3985d4e6810f..2d74eebda9df 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/GetOperation/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/GetService/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/GetService/main.go index 35f042c33f2c..998b8585d577 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/GetService/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/GetService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/ListBackups/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/ListBackups/main.go index 573d595ca120..cf0f2904545b 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/ListBackups/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/ListBackups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/ListLocations/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/ListLocations/main.go index 365f0d23d9e5..70b00ada8572 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/ListLocations/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/ListMetadataImports/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/ListMetadataImports/main.go index fd780154930c..953e3f36be15 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/ListMetadataImports/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/ListMetadataImports/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/ListOperations/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/ListOperations/main.go index 47cf48b57765..b3e3cdda876c 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/ListOperations/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/ListServices/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/ListServices/main.go index 59a1ac660592..ad2c8ffa405a 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/ListServices/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/ListServices/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/MoveTableToDatabase/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/MoveTableToDatabase/main.go index 05249135ad3d..99923928df63 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/MoveTableToDatabase/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/MoveTableToDatabase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/QueryMetadata/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/QueryMetadata/main.go index d1560b6def77..d024e0aebe0e 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/QueryMetadata/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/QueryMetadata/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/RemoveIamPolicy/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/RemoveIamPolicy/main.go index 076a82e18d5a..91230e3cafcf 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/RemoveIamPolicy/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/RemoveIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/RestoreService/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/RestoreService/main.go index fa7bff159728..9b7ef2032afe 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/RestoreService/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/RestoreService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/SetIamPolicy/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/SetIamPolicy/main.go index 7230f2bed926..2186a9b49744 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/TestIamPermissions/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/TestIamPermissions/main.go index 18f03c7f73de..588c41da1678 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/UpdateMetadataImport/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/UpdateMetadataImport/main.go index 5bfe015aa314..a731ae76af38 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/UpdateMetadataImport/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/UpdateMetadataImport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/UpdateService/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/UpdateService/main.go index 687bef8308ea..0f3823a6b035 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/UpdateService/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreClient/UpdateService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/CancelOperation/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/CancelOperation/main.go index 6555fd0ee075..145d1416bf21 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/CancelOperation/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/CreateFederation/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/CreateFederation/main.go index 4da99c11d5aa..6402f4cd6bba 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/CreateFederation/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/CreateFederation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/DeleteFederation/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/DeleteFederation/main.go index 49260c795f7c..f54b99e379af 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/DeleteFederation/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/DeleteFederation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/DeleteOperation/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/DeleteOperation/main.go index 2c0fec98e207..e1f537800796 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/DeleteOperation/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/GetFederation/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/GetFederation/main.go index 5651d9b73b48..0329377415ed 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/GetFederation/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/GetFederation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/GetIamPolicy/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/GetIamPolicy/main.go index 5d97c6265d86..4d2b05b61890 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/GetLocation/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/GetLocation/main.go index 9d0a475a519f..4c673c523a9a 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/GetLocation/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/GetOperation/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/GetOperation/main.go index 607f3f580c32..fce990e8f681 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/GetOperation/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/ListFederations/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/ListFederations/main.go index d6ce55fb75ce..527b1c627641 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/ListFederations/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/ListFederations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/ListLocations/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/ListLocations/main.go index 88a3537aeb46..6c85d6dad344 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/ListLocations/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/ListOperations/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/ListOperations/main.go index 7d48e112605d..edeb106f72dc 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/ListOperations/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/SetIamPolicy/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/SetIamPolicy/main.go index f1256dc21896..0e0f60ff18fe 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/TestIamPermissions/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/TestIamPermissions/main.go index 5d87f3070280..51c54e9ac76d 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/UpdateFederation/main.go b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/UpdateFederation/main.go index b3b9044c0048..587bbf285729 100644 --- a/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/UpdateFederation/main.go +++ b/internal/generated/snippets/metastore/apiv1alpha/DataprocMetastoreFederationClient/UpdateFederation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/AlterMetadataResourceLocation/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/AlterMetadataResourceLocation/main.go index 82f1478835c9..9438e136f95a 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/AlterMetadataResourceLocation/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/AlterMetadataResourceLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/CancelOperation/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/CancelOperation/main.go index 58a4b2b25011..dfcbdc3bdab7 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/CancelOperation/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/CreateBackup/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/CreateBackup/main.go index 5e02e51fdcda..742e52812810 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/CreateBackup/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/CreateBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/CreateMetadataImport/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/CreateMetadataImport/main.go index f87e4feaa2a3..36a3370b35b8 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/CreateMetadataImport/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/CreateMetadataImport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/CreateService/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/CreateService/main.go index e05e543b957e..5bc59e9a9328 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/CreateService/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/CreateService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/DeleteBackup/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/DeleteBackup/main.go index 0a05677ed072..462318295c7d 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/DeleteBackup/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/DeleteBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/DeleteOperation/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/DeleteOperation/main.go index 59b173c1d3e7..3aaa011440cb 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/DeleteOperation/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/DeleteService/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/DeleteService/main.go index 7265933c43cf..fcb996091df5 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/DeleteService/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/DeleteService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/ExportMetadata/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/ExportMetadata/main.go index 2d9b78d5cbe2..92eb5b8bec3c 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/ExportMetadata/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/ExportMetadata/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/GetBackup/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/GetBackup/main.go index aeb7d4cca39d..12b82d3b191d 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/GetBackup/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/GetBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/GetIamPolicy/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/GetIamPolicy/main.go index 3d5bdcc955e0..45cd442bec33 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/GetLocation/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/GetLocation/main.go index cea01e007571..ea4746c2322d 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/GetLocation/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/GetMetadataImport/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/GetMetadataImport/main.go index 5f290c33e100..52f8ef8f50f2 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/GetMetadataImport/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/GetMetadataImport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/GetOperation/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/GetOperation/main.go index ae7ea6b811d5..e125c3299796 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/GetOperation/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/GetService/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/GetService/main.go index ea209adc5890..c55ed990ef47 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/GetService/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/GetService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/ListBackups/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/ListBackups/main.go index 6c1a1df58669..50330b090264 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/ListBackups/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/ListBackups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/ListLocations/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/ListLocations/main.go index 8150b7fb1c7a..8cfc7ecb4a14 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/ListLocations/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/ListMetadataImports/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/ListMetadataImports/main.go index aab797a69b98..cda61740ff29 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/ListMetadataImports/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/ListMetadataImports/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/ListOperations/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/ListOperations/main.go index f5d080a0dbd7..9cc4890bb01c 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/ListOperations/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/ListServices/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/ListServices/main.go index a14211528259..802d3fd24ae1 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/ListServices/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/ListServices/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/MoveTableToDatabase/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/MoveTableToDatabase/main.go index 8eaf822957c9..2935a6ca1a13 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/MoveTableToDatabase/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/MoveTableToDatabase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/QueryMetadata/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/QueryMetadata/main.go index 0e4091887574..4a6d4689d2b6 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/QueryMetadata/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/QueryMetadata/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/RemoveIamPolicy/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/RemoveIamPolicy/main.go index b7eb875e0547..19fa6ec855cf 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/RemoveIamPolicy/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/RemoveIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/RestoreService/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/RestoreService/main.go index 930296acc2da..7bee4e6886ad 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/RestoreService/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/RestoreService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/SetIamPolicy/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/SetIamPolicy/main.go index 1032aac2c0eb..b4e306e44613 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/TestIamPermissions/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/TestIamPermissions/main.go index 66d1abe93504..25b1ff31b440 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/UpdateMetadataImport/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/UpdateMetadataImport/main.go index abd05e1f6e6a..bd58604ac8fe 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/UpdateMetadataImport/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/UpdateMetadataImport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/UpdateService/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/UpdateService/main.go index 98f89b61812e..e8d56cd4085a 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/UpdateService/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreClient/UpdateService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/CancelOperation/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/CancelOperation/main.go index 204c81a4f002..a26666a98139 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/CancelOperation/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/CreateFederation/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/CreateFederation/main.go index f46d3773fe99..f82a8162cf9d 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/CreateFederation/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/CreateFederation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/DeleteFederation/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/DeleteFederation/main.go index d6e81519a73c..e53733e1e0a2 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/DeleteFederation/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/DeleteFederation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/DeleteOperation/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/DeleteOperation/main.go index aa56f7a00623..5bb75602830c 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/DeleteOperation/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/GetFederation/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/GetFederation/main.go index bcfebb7fdd99..2e06d9d7f9ce 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/GetFederation/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/GetFederation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/GetIamPolicy/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/GetIamPolicy/main.go index 56d8da032ae4..e1e55b52da83 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/GetLocation/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/GetLocation/main.go index 1427a35c04b8..ee5ae6471c86 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/GetLocation/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/GetOperation/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/GetOperation/main.go index 24665b857954..9c016a7aec4b 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/GetOperation/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/ListFederations/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/ListFederations/main.go index cff1abe1a00b..8a96243df4ac 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/ListFederations/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/ListFederations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/ListLocations/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/ListLocations/main.go index 9093a723ab77..d0ea78d303da 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/ListLocations/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/ListOperations/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/ListOperations/main.go index c22caf854f50..277d6f6ccd38 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/ListOperations/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/SetIamPolicy/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/SetIamPolicy/main.go index 947778fe9f55..684af72ea29c 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/TestIamPermissions/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/TestIamPermissions/main.go index df3429403994..05f7d51126e6 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/UpdateFederation/main.go b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/UpdateFederation/main.go index d60bd34d9ed2..8648b8eed074 100644 --- a/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/UpdateFederation/main.go +++ b/internal/generated/snippets/metastore/apiv1beta/DataprocMetastoreFederationClient/UpdateFederation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/AddAssetsToGroup/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/AddAssetsToGroup/main.go index 21664a96f597..8298da11116d 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/AddAssetsToGroup/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/AddAssetsToGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/AggregateAssetsValues/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/AggregateAssetsValues/main.go index 459c85a0d819..56454b5c7165 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/AggregateAssetsValues/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/AggregateAssetsValues/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/BatchDeleteAssets/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/BatchDeleteAssets/main.go index 58523098e786..96c05ad96aa7 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/BatchDeleteAssets/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/BatchDeleteAssets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/BatchUpdateAssets/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/BatchUpdateAssets/main.go index 55bcfaccb97c..4f134c26c61d 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/BatchUpdateAssets/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/BatchUpdateAssets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/CancelOperation/main.go index 73feb64bd197..30e7eb3be31b 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/CreateGroup/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/CreateGroup/main.go index a0a8145677da..3968408a1c1d 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/CreateGroup/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/CreateGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/CreateImportDataFile/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/CreateImportDataFile/main.go index cd66fe41d8c1..2b8cb845e5f7 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/CreateImportDataFile/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/CreateImportDataFile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/CreateImportJob/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/CreateImportJob/main.go index 26ae70c0e321..da0b201bd098 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/CreateImportJob/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/CreateImportJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/CreatePreferenceSet/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/CreatePreferenceSet/main.go index ccb231f3c70c..52b10a7ca5ba 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/CreatePreferenceSet/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/CreatePreferenceSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/CreateReport/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/CreateReport/main.go index 72a31e92d5eb..2bec50ca1b84 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/CreateReport/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/CreateReport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/CreateReportConfig/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/CreateReportConfig/main.go index 15108a081f75..95d545d86547 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/CreateReportConfig/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/CreateReportConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/CreateSource/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/CreateSource/main.go index 3850d417f71c..c0206a9004fc 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/CreateSource/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/CreateSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteAsset/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteAsset/main.go index 5e695d50cc3f..42424e815e47 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteAsset/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteAsset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteGroup/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteGroup/main.go index f396a7d39020..f3f34a5713bb 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteGroup/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteImportDataFile/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteImportDataFile/main.go index 9ccaa14a888b..8cfaa928a7f7 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteImportDataFile/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteImportDataFile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteImportJob/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteImportJob/main.go index 459cf0e81ae9..0bf3d355470a 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteImportJob/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteImportJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteOperation/main.go index fc12d114e00b..038be66b3722 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/DeletePreferenceSet/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/DeletePreferenceSet/main.go index e06a366bd37f..a967448a3a6f 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/DeletePreferenceSet/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/DeletePreferenceSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteReport/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteReport/main.go index 9332c58781af..2d039d76e6be 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteReport/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteReport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteReportConfig/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteReportConfig/main.go index 1e874bc2bf58..c741df384b23 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteReportConfig/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteReportConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteSource/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteSource/main.go index d73672aee0b9..87a8103e8b0e 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteSource/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/DeleteSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/GetAsset/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/GetAsset/main.go index 7fa116571bf4..76c9d7f79447 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/GetAsset/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/GetAsset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/GetErrorFrame/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/GetErrorFrame/main.go index adae36921d75..03f09d896a2a 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/GetErrorFrame/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/GetErrorFrame/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/GetGroup/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/GetGroup/main.go index 7f7f003dbcf5..409b932b2cc4 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/GetGroup/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/GetGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/GetImportDataFile/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/GetImportDataFile/main.go index 911550fc685b..7bac15f31f90 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/GetImportDataFile/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/GetImportDataFile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/GetImportJob/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/GetImportJob/main.go index 355a5cae2eb7..e0de4d201ddd 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/GetImportJob/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/GetImportJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/GetLocation/main.go index 0d0fda886d01..2ffa58b20677 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/GetOperation/main.go index 7d8d4f922868..b661f4689d32 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/GetPreferenceSet/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/GetPreferenceSet/main.go index 57f1f3a996e1..eb2533acad3e 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/GetPreferenceSet/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/GetPreferenceSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/GetReport/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/GetReport/main.go index c809e378967f..994c1858f7fe 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/GetReport/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/GetReport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/GetReportConfig/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/GetReportConfig/main.go index 26bd82596a8a..630738764ba7 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/GetReportConfig/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/GetReportConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/GetSettings/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/GetSettings/main.go index 8d1a47620e52..7e9bf4ffa716 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/GetSettings/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/GetSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/GetSource/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/GetSource/main.go index fa0250035477..0c3b8a28d6f0 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/GetSource/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/GetSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/ListAssets/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/ListAssets/main.go index 16b531e89717..9c27634652b2 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/ListAssets/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/ListAssets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/ListErrorFrames/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/ListErrorFrames/main.go index a409a5879c6d..aa3991418bf6 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/ListErrorFrames/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/ListErrorFrames/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/ListGroups/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/ListGroups/main.go index 6e9cb5833d6a..b95161de8c0f 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/ListGroups/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/ListGroups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/ListImportDataFiles/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/ListImportDataFiles/main.go index 86d13c99a287..306376c37b20 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/ListImportDataFiles/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/ListImportDataFiles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/ListImportJobs/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/ListImportJobs/main.go index f46d9cbdcf6c..8a9f972b3466 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/ListImportJobs/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/ListImportJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/ListLocations/main.go index f840694d717d..64c32e5991c4 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/ListOperations/main.go index db332d66052b..1f40ac3d11fc 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/ListPreferenceSets/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/ListPreferenceSets/main.go index 15e2bfbdac1f..e84febc54e4b 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/ListPreferenceSets/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/ListPreferenceSets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/ListReportConfigs/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/ListReportConfigs/main.go index 17c3ce305a74..e40daee669d0 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/ListReportConfigs/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/ListReportConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/ListReports/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/ListReports/main.go index a0bb24f7a6fd..7bdc0c96e4e6 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/ListReports/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/ListReports/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/ListSources/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/ListSources/main.go index 809e0a1a6618..bc61859fe86c 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/ListSources/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/ListSources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/RemoveAssetsFromGroup/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/RemoveAssetsFromGroup/main.go index e6fb1b4a324c..8b7e755f5dfe 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/RemoveAssetsFromGroup/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/RemoveAssetsFromGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/ReportAssetFrames/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/ReportAssetFrames/main.go index 291b2d268d18..e20c4d9641a7 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/ReportAssetFrames/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/ReportAssetFrames/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/RunImportJob/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/RunImportJob/main.go index 468903c76350..23a0231bb042 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/RunImportJob/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/RunImportJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/UpdateAsset/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/UpdateAsset/main.go index c0cb6553c415..81c22578dba7 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/UpdateAsset/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/UpdateAsset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/UpdateGroup/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/UpdateGroup/main.go index 3c8b450d5dad..30dd82129cb7 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/UpdateGroup/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/UpdateGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/UpdateImportJob/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/UpdateImportJob/main.go index 1e6c23686a97..4e8027f04f86 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/UpdateImportJob/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/UpdateImportJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/UpdatePreferenceSet/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/UpdatePreferenceSet/main.go index 1f5d5a48cf06..2dc1c6dee200 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/UpdatePreferenceSet/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/UpdatePreferenceSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/UpdateSettings/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/UpdateSettings/main.go index 284538de5b9d..5278f490b785 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/UpdateSettings/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/UpdateSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/UpdateSource/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/UpdateSource/main.go index 651b68818fcd..55d0e72e3c62 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/UpdateSource/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/UpdateSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/Client/ValidateImportJob/main.go b/internal/generated/snippets/migrationcenter/apiv1/Client/ValidateImportJob/main.go index 24df6f635540..ab711c9a8f96 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/Client/ValidateImportJob/main.go +++ b/internal/generated/snippets/migrationcenter/apiv1/Client/ValidateImportJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/migrationcenter/apiv1/snippet_metadata.google.cloud.migrationcenter.v1.json b/internal/generated/snippets/migrationcenter/apiv1/snippet_metadata.google.cloud.migrationcenter.v1.json index f2ffef456caa..66cf85ed7435 100644 --- a/internal/generated/snippets/migrationcenter/apiv1/snippet_metadata.google.cloud.migrationcenter.v1.json +++ b/internal/generated/snippets/migrationcenter/apiv1/snippet_metadata.google.cloud.migrationcenter.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/migrationcenter/apiv1", - "version": "1.1.2", + "version": "1.1.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/monitoring/apiv3/v2/AlertPolicyClient/CreateAlertPolicy/main.go b/internal/generated/snippets/monitoring/apiv3/v2/AlertPolicyClient/CreateAlertPolicy/main.go index 6d646d7b4c1d..946cc3c7728a 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/AlertPolicyClient/CreateAlertPolicy/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/AlertPolicyClient/CreateAlertPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/AlertPolicyClient/DeleteAlertPolicy/main.go b/internal/generated/snippets/monitoring/apiv3/v2/AlertPolicyClient/DeleteAlertPolicy/main.go index 92eb5ebd3908..ee9caf608b1e 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/AlertPolicyClient/DeleteAlertPolicy/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/AlertPolicyClient/DeleteAlertPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/AlertPolicyClient/GetAlertPolicy/main.go b/internal/generated/snippets/monitoring/apiv3/v2/AlertPolicyClient/GetAlertPolicy/main.go index 2a1b897e84b0..183bb11f7297 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/AlertPolicyClient/GetAlertPolicy/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/AlertPolicyClient/GetAlertPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/AlertPolicyClient/ListAlertPolicies/main.go b/internal/generated/snippets/monitoring/apiv3/v2/AlertPolicyClient/ListAlertPolicies/main.go index f93908ce404a..699d36c768d0 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/AlertPolicyClient/ListAlertPolicies/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/AlertPolicyClient/ListAlertPolicies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/AlertPolicyClient/UpdateAlertPolicy/main.go b/internal/generated/snippets/monitoring/apiv3/v2/AlertPolicyClient/UpdateAlertPolicy/main.go index b5fbb1eb3dcb..91beb8dc8fa9 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/AlertPolicyClient/UpdateAlertPolicy/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/AlertPolicyClient/UpdateAlertPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/GroupClient/CreateGroup/main.go b/internal/generated/snippets/monitoring/apiv3/v2/GroupClient/CreateGroup/main.go index e5a5342436c1..dd39371c513e 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/GroupClient/CreateGroup/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/GroupClient/CreateGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/GroupClient/DeleteGroup/main.go b/internal/generated/snippets/monitoring/apiv3/v2/GroupClient/DeleteGroup/main.go index e49b42b58fc1..f367c0f4bc84 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/GroupClient/DeleteGroup/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/GroupClient/DeleteGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/GroupClient/GetGroup/main.go b/internal/generated/snippets/monitoring/apiv3/v2/GroupClient/GetGroup/main.go index d5f15e6efe0e..8d13561671a1 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/GroupClient/GetGroup/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/GroupClient/GetGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/GroupClient/ListGroupMembers/main.go b/internal/generated/snippets/monitoring/apiv3/v2/GroupClient/ListGroupMembers/main.go index ef7dfa532061..cd53043f2ffb 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/GroupClient/ListGroupMembers/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/GroupClient/ListGroupMembers/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/GroupClient/ListGroups/main.go b/internal/generated/snippets/monitoring/apiv3/v2/GroupClient/ListGroups/main.go index 74c9a682b270..23eee4101173 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/GroupClient/ListGroups/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/GroupClient/ListGroups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/GroupClient/UpdateGroup/main.go b/internal/generated/snippets/monitoring/apiv3/v2/GroupClient/UpdateGroup/main.go index 9fde75629d95..f9b940d1fdbb 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/GroupClient/UpdateGroup/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/GroupClient/UpdateGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/CreateMetricDescriptor/main.go b/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/CreateMetricDescriptor/main.go index 506f59f61ccc..bcf4400dbe12 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/CreateMetricDescriptor/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/CreateMetricDescriptor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/CreateServiceTimeSeries/main.go b/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/CreateServiceTimeSeries/main.go index ca6cc32b0879..94c9e099c2e8 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/CreateServiceTimeSeries/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/CreateServiceTimeSeries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/CreateTimeSeries/main.go b/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/CreateTimeSeries/main.go index d8e198d97eee..dfe8b9b0395f 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/CreateTimeSeries/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/CreateTimeSeries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/DeleteMetricDescriptor/main.go b/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/DeleteMetricDescriptor/main.go index cb8806988117..b0bb6c439074 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/DeleteMetricDescriptor/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/DeleteMetricDescriptor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/GetMetricDescriptor/main.go b/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/GetMetricDescriptor/main.go index 0d1e642428a3..37347b419191 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/GetMetricDescriptor/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/GetMetricDescriptor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/GetMonitoredResourceDescriptor/main.go b/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/GetMonitoredResourceDescriptor/main.go index 2ce1ac7d3b0f..af0741a9bbc5 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/GetMonitoredResourceDescriptor/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/GetMonitoredResourceDescriptor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/ListMetricDescriptors/main.go b/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/ListMetricDescriptors/main.go index 1f9232ce69f6..34121b6d8e53 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/ListMetricDescriptors/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/ListMetricDescriptors/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/ListMonitoredResourceDescriptors/main.go b/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/ListMonitoredResourceDescriptors/main.go index c58836f78ce1..4d83c017fd19 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/ListMonitoredResourceDescriptors/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/ListMonitoredResourceDescriptors/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/ListTimeSeries/main.go b/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/ListTimeSeries/main.go index 2904d3a88664..38b27e45a37f 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/ListTimeSeries/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/MetricClient/ListTimeSeries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/CreateNotificationChannel/main.go b/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/CreateNotificationChannel/main.go index d5a8cc93e982..9c77a5734f46 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/CreateNotificationChannel/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/CreateNotificationChannel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/DeleteNotificationChannel/main.go b/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/DeleteNotificationChannel/main.go index 7bc13502e421..8cb2e0f0d90b 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/DeleteNotificationChannel/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/DeleteNotificationChannel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/GetNotificationChannel/main.go b/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/GetNotificationChannel/main.go index c23df793a969..2ff93a9c86fd 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/GetNotificationChannel/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/GetNotificationChannel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/GetNotificationChannelDescriptor/main.go b/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/GetNotificationChannelDescriptor/main.go index 012cd23c776e..b2750fb6a98b 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/GetNotificationChannelDescriptor/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/GetNotificationChannelDescriptor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/GetNotificationChannelVerificationCode/main.go b/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/GetNotificationChannelVerificationCode/main.go index e63d25b29c19..3c1cc09bcd00 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/GetNotificationChannelVerificationCode/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/GetNotificationChannelVerificationCode/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/ListNotificationChannelDescriptors/main.go b/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/ListNotificationChannelDescriptors/main.go index f269d83cf91e..7728939eac95 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/ListNotificationChannelDescriptors/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/ListNotificationChannelDescriptors/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/ListNotificationChannels/main.go b/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/ListNotificationChannels/main.go index 62054caa551b..71d64734ca50 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/ListNotificationChannels/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/ListNotificationChannels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/SendNotificationChannelVerificationCode/main.go b/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/SendNotificationChannelVerificationCode/main.go index f3e8451204fb..620c921e34b3 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/SendNotificationChannelVerificationCode/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/SendNotificationChannelVerificationCode/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/UpdateNotificationChannel/main.go b/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/UpdateNotificationChannel/main.go index db0b90d93f6d..0d75bcb8d1fe 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/UpdateNotificationChannel/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/UpdateNotificationChannel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/VerifyNotificationChannel/main.go b/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/VerifyNotificationChannel/main.go index c2d957e2f017..0b9cfd974268 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/VerifyNotificationChannel/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/NotificationChannelClient/VerifyNotificationChannel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/QueryClient/QueryTimeSeries/main.go b/internal/generated/snippets/monitoring/apiv3/v2/QueryClient/QueryTimeSeries/main.go index ae95c8cbbad6..58457183828c 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/QueryClient/QueryTimeSeries/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/QueryClient/QueryTimeSeries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/CreateService/main.go b/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/CreateService/main.go index 23b5e3216893..9d34aec8f16c 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/CreateService/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/CreateService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/CreateServiceLevelObjective/main.go b/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/CreateServiceLevelObjective/main.go index 6bc21895053e..e8e1c45cb4df 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/CreateServiceLevelObjective/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/CreateServiceLevelObjective/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/DeleteService/main.go b/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/DeleteService/main.go index 0cbea08ec1ce..161d86f18f5b 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/DeleteService/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/DeleteService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/DeleteServiceLevelObjective/main.go b/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/DeleteServiceLevelObjective/main.go index 17f76fbe3114..9b92e88d0fa5 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/DeleteServiceLevelObjective/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/DeleteServiceLevelObjective/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/GetService/main.go b/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/GetService/main.go index 56705f0bc02e..1f55d91b7ef9 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/GetService/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/GetService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/GetServiceLevelObjective/main.go b/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/GetServiceLevelObjective/main.go index 4dc2181445c9..9f0beedacded 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/GetServiceLevelObjective/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/GetServiceLevelObjective/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/ListServiceLevelObjectives/main.go b/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/ListServiceLevelObjectives/main.go index ad08633152a6..354dc8043721 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/ListServiceLevelObjectives/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/ListServiceLevelObjectives/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/ListServices/main.go b/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/ListServices/main.go index 956a778d1e26..f369e63683a3 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/ListServices/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/ListServices/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/UpdateService/main.go b/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/UpdateService/main.go index 83759d429d71..8eaf5f2857ab 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/UpdateService/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/UpdateService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/UpdateServiceLevelObjective/main.go b/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/UpdateServiceLevelObjective/main.go index 5b7e5a6c058f..15ae228063a3 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/UpdateServiceLevelObjective/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/ServiceMonitoringClient/UpdateServiceLevelObjective/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/SnoozeClient/CreateSnooze/main.go b/internal/generated/snippets/monitoring/apiv3/v2/SnoozeClient/CreateSnooze/main.go index ad5eb39e5fe0..3d7360711341 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/SnoozeClient/CreateSnooze/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/SnoozeClient/CreateSnooze/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/SnoozeClient/GetSnooze/main.go b/internal/generated/snippets/monitoring/apiv3/v2/SnoozeClient/GetSnooze/main.go index 0da63bbd1218..c768ead7c405 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/SnoozeClient/GetSnooze/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/SnoozeClient/GetSnooze/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/SnoozeClient/ListSnoozes/main.go b/internal/generated/snippets/monitoring/apiv3/v2/SnoozeClient/ListSnoozes/main.go index 5ed055fa35aa..3cf7a595af0a 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/SnoozeClient/ListSnoozes/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/SnoozeClient/ListSnoozes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/SnoozeClient/UpdateSnooze/main.go b/internal/generated/snippets/monitoring/apiv3/v2/SnoozeClient/UpdateSnooze/main.go index f953de7ad513..21a0f4cec15b 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/SnoozeClient/UpdateSnooze/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/SnoozeClient/UpdateSnooze/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/UptimeCheckClient/CreateUptimeCheckConfig/main.go b/internal/generated/snippets/monitoring/apiv3/v2/UptimeCheckClient/CreateUptimeCheckConfig/main.go index 43fbf6c21a0f..b8ca45696bc6 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/UptimeCheckClient/CreateUptimeCheckConfig/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/UptimeCheckClient/CreateUptimeCheckConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/UptimeCheckClient/DeleteUptimeCheckConfig/main.go b/internal/generated/snippets/monitoring/apiv3/v2/UptimeCheckClient/DeleteUptimeCheckConfig/main.go index c01ddeac96b7..75cac6e746f0 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/UptimeCheckClient/DeleteUptimeCheckConfig/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/UptimeCheckClient/DeleteUptimeCheckConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/UptimeCheckClient/GetUptimeCheckConfig/main.go b/internal/generated/snippets/monitoring/apiv3/v2/UptimeCheckClient/GetUptimeCheckConfig/main.go index 61fb55871e5e..e6d08d6ed4b1 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/UptimeCheckClient/GetUptimeCheckConfig/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/UptimeCheckClient/GetUptimeCheckConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/UptimeCheckClient/ListUptimeCheckConfigs/main.go b/internal/generated/snippets/monitoring/apiv3/v2/UptimeCheckClient/ListUptimeCheckConfigs/main.go index d780ab6aefa7..6e362f00ad2f 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/UptimeCheckClient/ListUptimeCheckConfigs/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/UptimeCheckClient/ListUptimeCheckConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/UptimeCheckClient/ListUptimeCheckIps/main.go b/internal/generated/snippets/monitoring/apiv3/v2/UptimeCheckClient/ListUptimeCheckIps/main.go index 1c712639bf67..f9e63a05ceb9 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/UptimeCheckClient/ListUptimeCheckIps/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/UptimeCheckClient/ListUptimeCheckIps/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/UptimeCheckClient/UpdateUptimeCheckConfig/main.go b/internal/generated/snippets/monitoring/apiv3/v2/UptimeCheckClient/UpdateUptimeCheckConfig/main.go index f781d6586fb3..580b41ad4817 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/UptimeCheckClient/UpdateUptimeCheckConfig/main.go +++ b/internal/generated/snippets/monitoring/apiv3/v2/UptimeCheckClient/UpdateUptimeCheckConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/apiv3/v2/snippet_metadata.google.monitoring.v3.json b/internal/generated/snippets/monitoring/apiv3/v2/snippet_metadata.google.monitoring.v3.json index 59d51723e8b5..013987d339e7 100644 --- a/internal/generated/snippets/monitoring/apiv3/v2/snippet_metadata.google.monitoring.v3.json +++ b/internal/generated/snippets/monitoring/apiv3/v2/snippet_metadata.google.monitoring.v3.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/monitoring/apiv3/v2", - "version": "1.22.0", + "version": "1.22.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/monitoring/dashboard/apiv1/DashboardsClient/CreateDashboard/main.go b/internal/generated/snippets/monitoring/dashboard/apiv1/DashboardsClient/CreateDashboard/main.go index 4e9f2ba40608..42f0317ef800 100644 --- a/internal/generated/snippets/monitoring/dashboard/apiv1/DashboardsClient/CreateDashboard/main.go +++ b/internal/generated/snippets/monitoring/dashboard/apiv1/DashboardsClient/CreateDashboard/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/dashboard/apiv1/DashboardsClient/DeleteDashboard/main.go b/internal/generated/snippets/monitoring/dashboard/apiv1/DashboardsClient/DeleteDashboard/main.go index 94415741f7d8..154606090455 100644 --- a/internal/generated/snippets/monitoring/dashboard/apiv1/DashboardsClient/DeleteDashboard/main.go +++ b/internal/generated/snippets/monitoring/dashboard/apiv1/DashboardsClient/DeleteDashboard/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/dashboard/apiv1/DashboardsClient/GetDashboard/main.go b/internal/generated/snippets/monitoring/dashboard/apiv1/DashboardsClient/GetDashboard/main.go index b3bf56d335ee..d490bf111f19 100644 --- a/internal/generated/snippets/monitoring/dashboard/apiv1/DashboardsClient/GetDashboard/main.go +++ b/internal/generated/snippets/monitoring/dashboard/apiv1/DashboardsClient/GetDashboard/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/dashboard/apiv1/DashboardsClient/ListDashboards/main.go b/internal/generated/snippets/monitoring/dashboard/apiv1/DashboardsClient/ListDashboards/main.go index 3854625f086a..56ba729ae7af 100644 --- a/internal/generated/snippets/monitoring/dashboard/apiv1/DashboardsClient/ListDashboards/main.go +++ b/internal/generated/snippets/monitoring/dashboard/apiv1/DashboardsClient/ListDashboards/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/dashboard/apiv1/DashboardsClient/UpdateDashboard/main.go b/internal/generated/snippets/monitoring/dashboard/apiv1/DashboardsClient/UpdateDashboard/main.go index debbd1374c3b..ef4ecb46413e 100644 --- a/internal/generated/snippets/monitoring/dashboard/apiv1/DashboardsClient/UpdateDashboard/main.go +++ b/internal/generated/snippets/monitoring/dashboard/apiv1/DashboardsClient/UpdateDashboard/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/dashboard/apiv1/snippet_metadata.google.monitoring.dashboard.v1.json b/internal/generated/snippets/monitoring/dashboard/apiv1/snippet_metadata.google.monitoring.dashboard.v1.json index 305e48062df4..c95c910d95c0 100644 --- a/internal/generated/snippets/monitoring/dashboard/apiv1/snippet_metadata.google.monitoring.dashboard.v1.json +++ b/internal/generated/snippets/monitoring/dashboard/apiv1/snippet_metadata.google.monitoring.dashboard.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/monitoring/dashboard/apiv1", - "version": "1.22.0", + "version": "1.22.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/monitoring/metricsscope/apiv1/MetricsScopesClient/CreateMonitoredProject/main.go b/internal/generated/snippets/monitoring/metricsscope/apiv1/MetricsScopesClient/CreateMonitoredProject/main.go index 1b97b176f8ce..50700685c648 100644 --- a/internal/generated/snippets/monitoring/metricsscope/apiv1/MetricsScopesClient/CreateMonitoredProject/main.go +++ b/internal/generated/snippets/monitoring/metricsscope/apiv1/MetricsScopesClient/CreateMonitoredProject/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/metricsscope/apiv1/MetricsScopesClient/DeleteMonitoredProject/main.go b/internal/generated/snippets/monitoring/metricsscope/apiv1/MetricsScopesClient/DeleteMonitoredProject/main.go index e4372122c4c1..f895f095e908 100644 --- a/internal/generated/snippets/monitoring/metricsscope/apiv1/MetricsScopesClient/DeleteMonitoredProject/main.go +++ b/internal/generated/snippets/monitoring/metricsscope/apiv1/MetricsScopesClient/DeleteMonitoredProject/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/metricsscope/apiv1/MetricsScopesClient/GetMetricsScope/main.go b/internal/generated/snippets/monitoring/metricsscope/apiv1/MetricsScopesClient/GetMetricsScope/main.go index bf6789bf11ac..5b7cbbfd8acd 100644 --- a/internal/generated/snippets/monitoring/metricsscope/apiv1/MetricsScopesClient/GetMetricsScope/main.go +++ b/internal/generated/snippets/monitoring/metricsscope/apiv1/MetricsScopesClient/GetMetricsScope/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/metricsscope/apiv1/MetricsScopesClient/ListMetricsScopesByMonitoredProject/main.go b/internal/generated/snippets/monitoring/metricsscope/apiv1/MetricsScopesClient/ListMetricsScopesByMonitoredProject/main.go index aada47c37ba7..297a417f60ce 100644 --- a/internal/generated/snippets/monitoring/metricsscope/apiv1/MetricsScopesClient/ListMetricsScopesByMonitoredProject/main.go +++ b/internal/generated/snippets/monitoring/metricsscope/apiv1/MetricsScopesClient/ListMetricsScopesByMonitoredProject/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/monitoring/metricsscope/apiv1/snippet_metadata.google.monitoring.metricsscope.v1.json b/internal/generated/snippets/monitoring/metricsscope/apiv1/snippet_metadata.google.monitoring.metricsscope.v1.json index 36bf8e163b26..e5d4ebb3e042 100644 --- a/internal/generated/snippets/monitoring/metricsscope/apiv1/snippet_metadata.google.monitoring.metricsscope.v1.json +++ b/internal/generated/snippets/monitoring/metricsscope/apiv1/snippet_metadata.google.monitoring.metricsscope.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/monitoring/metricsscope/apiv1", - "version": "1.22.0", + "version": "1.22.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/netapp/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/netapp/apiv1/Client/CancelOperation/main.go index 7c215518c770..30be8fb632a9 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/CreateActiveDirectory/main.go b/internal/generated/snippets/netapp/apiv1/Client/CreateActiveDirectory/main.go index 709b7e4ac648..a0416cc58756 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/CreateActiveDirectory/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/CreateActiveDirectory/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/CreateBackup/main.go b/internal/generated/snippets/netapp/apiv1/Client/CreateBackup/main.go index ecc58cd6675c..8fa6ee2fa9f1 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/CreateBackup/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/CreateBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/CreateBackupPolicy/main.go b/internal/generated/snippets/netapp/apiv1/Client/CreateBackupPolicy/main.go index f49d7df25d7a..903beb6653bb 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/CreateBackupPolicy/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/CreateBackupPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/CreateBackupVault/main.go b/internal/generated/snippets/netapp/apiv1/Client/CreateBackupVault/main.go index d4e6c22d22f3..768f717627c9 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/CreateBackupVault/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/CreateBackupVault/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/CreateKmsConfig/main.go b/internal/generated/snippets/netapp/apiv1/Client/CreateKmsConfig/main.go index 3f7e1222e0b6..a0e8c40879b3 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/CreateKmsConfig/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/CreateKmsConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/CreateReplication/main.go b/internal/generated/snippets/netapp/apiv1/Client/CreateReplication/main.go index e73524ceaf25..2504eefc494f 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/CreateReplication/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/CreateReplication/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/CreateSnapshot/main.go b/internal/generated/snippets/netapp/apiv1/Client/CreateSnapshot/main.go index 2f079e48a111..9f8baf68635f 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/CreateSnapshot/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/CreateSnapshot/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/CreateStoragePool/main.go b/internal/generated/snippets/netapp/apiv1/Client/CreateStoragePool/main.go index 3a4012162a8d..a600ee45f002 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/CreateStoragePool/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/CreateStoragePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/CreateVolume/main.go b/internal/generated/snippets/netapp/apiv1/Client/CreateVolume/main.go index e94fac2d3eea..5b24e7dff1b9 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/CreateVolume/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/CreateVolume/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/DeleteActiveDirectory/main.go b/internal/generated/snippets/netapp/apiv1/Client/DeleteActiveDirectory/main.go index 6a99e1edb71c..5750d85e37af 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/DeleteActiveDirectory/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/DeleteActiveDirectory/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/DeleteBackup/main.go b/internal/generated/snippets/netapp/apiv1/Client/DeleteBackup/main.go index d8a075bbb2f4..0c06082e16c9 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/DeleteBackup/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/DeleteBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/DeleteBackupPolicy/main.go b/internal/generated/snippets/netapp/apiv1/Client/DeleteBackupPolicy/main.go index e25c22344cfb..f3f73ca95c7a 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/DeleteBackupPolicy/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/DeleteBackupPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/DeleteBackupVault/main.go b/internal/generated/snippets/netapp/apiv1/Client/DeleteBackupVault/main.go index 65f04f72c485..e807983c8abf 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/DeleteBackupVault/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/DeleteBackupVault/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/DeleteKmsConfig/main.go b/internal/generated/snippets/netapp/apiv1/Client/DeleteKmsConfig/main.go index d4ecd0ee2edf..188cfdd05c76 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/DeleteKmsConfig/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/DeleteKmsConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/netapp/apiv1/Client/DeleteOperation/main.go index af7e8089d594..222fd1f79971 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/DeleteReplication/main.go b/internal/generated/snippets/netapp/apiv1/Client/DeleteReplication/main.go index eb66276eaeb1..ddc881308a96 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/DeleteReplication/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/DeleteReplication/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/DeleteSnapshot/main.go b/internal/generated/snippets/netapp/apiv1/Client/DeleteSnapshot/main.go index ee976f5502bc..47162c26619b 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/DeleteSnapshot/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/DeleteSnapshot/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/DeleteStoragePool/main.go b/internal/generated/snippets/netapp/apiv1/Client/DeleteStoragePool/main.go index 45c608eac0a9..a0f66ee7e8ee 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/DeleteStoragePool/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/DeleteStoragePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/DeleteVolume/main.go b/internal/generated/snippets/netapp/apiv1/Client/DeleteVolume/main.go index 44e9ba48ac60..621e47c49997 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/DeleteVolume/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/DeleteVolume/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/EncryptVolumes/main.go b/internal/generated/snippets/netapp/apiv1/Client/EncryptVolumes/main.go index 26790d1ac03d..bc1a93e363f9 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/EncryptVolumes/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/EncryptVolumes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/EstablishPeering/main.go b/internal/generated/snippets/netapp/apiv1/Client/EstablishPeering/main.go index 29428ae67813..d948fc90288a 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/EstablishPeering/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/EstablishPeering/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/GetActiveDirectory/main.go b/internal/generated/snippets/netapp/apiv1/Client/GetActiveDirectory/main.go index 447c9375cddd..d99285751482 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/GetActiveDirectory/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/GetActiveDirectory/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/GetBackup/main.go b/internal/generated/snippets/netapp/apiv1/Client/GetBackup/main.go index c5c45602c8b0..376265269bf6 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/GetBackup/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/GetBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/GetBackupPolicy/main.go b/internal/generated/snippets/netapp/apiv1/Client/GetBackupPolicy/main.go index d33f317fd528..e7d79570fab2 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/GetBackupPolicy/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/GetBackupPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/GetBackupVault/main.go b/internal/generated/snippets/netapp/apiv1/Client/GetBackupVault/main.go index 2a451ea23d4c..d7ba1a1d6170 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/GetBackupVault/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/GetBackupVault/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/GetKmsConfig/main.go b/internal/generated/snippets/netapp/apiv1/Client/GetKmsConfig/main.go index 92f22f35d55d..402c68b8a8ff 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/GetKmsConfig/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/GetKmsConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/netapp/apiv1/Client/GetLocation/main.go index ed68a70623c6..9c869e20d21c 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/netapp/apiv1/Client/GetOperation/main.go index 8c471d5f4626..7e4c85a66a48 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/GetReplication/main.go b/internal/generated/snippets/netapp/apiv1/Client/GetReplication/main.go index 441dfe45cd7c..8ea0a8c21705 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/GetReplication/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/GetReplication/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/GetSnapshot/main.go b/internal/generated/snippets/netapp/apiv1/Client/GetSnapshot/main.go index 2cbfc0118c39..7e3af1f97215 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/GetSnapshot/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/GetSnapshot/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/GetStoragePool/main.go b/internal/generated/snippets/netapp/apiv1/Client/GetStoragePool/main.go index 515dc2508d5b..f58b10805354 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/GetStoragePool/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/GetStoragePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/GetVolume/main.go b/internal/generated/snippets/netapp/apiv1/Client/GetVolume/main.go index 0d82910d3c2e..de7a88ad4b78 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/GetVolume/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/GetVolume/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/ListActiveDirectories/main.go b/internal/generated/snippets/netapp/apiv1/Client/ListActiveDirectories/main.go index d9d09ebe2569..ffc51f8d4c24 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/ListActiveDirectories/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/ListActiveDirectories/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/ListBackupPolicies/main.go b/internal/generated/snippets/netapp/apiv1/Client/ListBackupPolicies/main.go index d2cd04c786dc..da7e29662847 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/ListBackupPolicies/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/ListBackupPolicies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/ListBackupVaults/main.go b/internal/generated/snippets/netapp/apiv1/Client/ListBackupVaults/main.go index 7e2a654234a1..47efc40477ba 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/ListBackupVaults/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/ListBackupVaults/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/ListBackups/main.go b/internal/generated/snippets/netapp/apiv1/Client/ListBackups/main.go index 121c13f575a5..e6b09dd088d1 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/ListBackups/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/ListBackups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/ListKmsConfigs/main.go b/internal/generated/snippets/netapp/apiv1/Client/ListKmsConfigs/main.go index acfe13698215..144f91c72757 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/ListKmsConfigs/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/ListKmsConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/netapp/apiv1/Client/ListLocations/main.go index 32fc0b0795dc..a62dcc3fe231 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/netapp/apiv1/Client/ListOperations/main.go index 976546ee196b..b2ba0ee14455 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/ListReplications/main.go b/internal/generated/snippets/netapp/apiv1/Client/ListReplications/main.go index 95f69350e2ec..6d8bd2fafad9 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/ListReplications/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/ListReplications/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/ListSnapshots/main.go b/internal/generated/snippets/netapp/apiv1/Client/ListSnapshots/main.go index c311e05f1b73..bde088976297 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/ListSnapshots/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/ListSnapshots/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/ListStoragePools/main.go b/internal/generated/snippets/netapp/apiv1/Client/ListStoragePools/main.go index daae01454888..c9b33b44fe6b 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/ListStoragePools/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/ListStoragePools/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/ListVolumes/main.go b/internal/generated/snippets/netapp/apiv1/Client/ListVolumes/main.go index b90d57e6896f..e83631cf4bae 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/ListVolumes/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/ListVolumes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/ResumeReplication/main.go b/internal/generated/snippets/netapp/apiv1/Client/ResumeReplication/main.go index 9e59c7bebd9f..05e4eebd9b55 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/ResumeReplication/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/ResumeReplication/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/ReverseReplicationDirection/main.go b/internal/generated/snippets/netapp/apiv1/Client/ReverseReplicationDirection/main.go index 771c8319db19..1ebd12bc84fc 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/ReverseReplicationDirection/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/ReverseReplicationDirection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/RevertVolume/main.go b/internal/generated/snippets/netapp/apiv1/Client/RevertVolume/main.go index 192a02137075..23e67ee4b05a 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/RevertVolume/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/RevertVolume/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/StopReplication/main.go b/internal/generated/snippets/netapp/apiv1/Client/StopReplication/main.go index 484ec31e868e..96b227e89fce 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/StopReplication/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/StopReplication/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/SwitchActiveReplicaZone/main.go b/internal/generated/snippets/netapp/apiv1/Client/SwitchActiveReplicaZone/main.go index 715c4e3cbc5f..55d86e0d827f 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/SwitchActiveReplicaZone/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/SwitchActiveReplicaZone/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/SyncReplication/main.go b/internal/generated/snippets/netapp/apiv1/Client/SyncReplication/main.go index 47d56739ffaf..7a1fd9d98d1f 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/SyncReplication/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/SyncReplication/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/UpdateActiveDirectory/main.go b/internal/generated/snippets/netapp/apiv1/Client/UpdateActiveDirectory/main.go index c866fe8c696c..aaf24565ba7b 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/UpdateActiveDirectory/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/UpdateActiveDirectory/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/UpdateBackup/main.go b/internal/generated/snippets/netapp/apiv1/Client/UpdateBackup/main.go index 240e79253e8b..dd103ab33b18 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/UpdateBackup/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/UpdateBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/UpdateBackupPolicy/main.go b/internal/generated/snippets/netapp/apiv1/Client/UpdateBackupPolicy/main.go index a31599a85b07..c65bc9ddbede 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/UpdateBackupPolicy/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/UpdateBackupPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/UpdateBackupVault/main.go b/internal/generated/snippets/netapp/apiv1/Client/UpdateBackupVault/main.go index 1aef1ec6debb..bcda269c7312 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/UpdateBackupVault/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/UpdateBackupVault/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/UpdateKmsConfig/main.go b/internal/generated/snippets/netapp/apiv1/Client/UpdateKmsConfig/main.go index 25a71edc491c..f64f9180d8fe 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/UpdateKmsConfig/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/UpdateKmsConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/UpdateReplication/main.go b/internal/generated/snippets/netapp/apiv1/Client/UpdateReplication/main.go index 0d04e3150cf2..bcab12478348 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/UpdateReplication/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/UpdateReplication/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/UpdateSnapshot/main.go b/internal/generated/snippets/netapp/apiv1/Client/UpdateSnapshot/main.go index 50e3989e9d30..e1a700290aab 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/UpdateSnapshot/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/UpdateSnapshot/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/UpdateStoragePool/main.go b/internal/generated/snippets/netapp/apiv1/Client/UpdateStoragePool/main.go index ffdda51d7522..9c7f15c914b3 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/UpdateStoragePool/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/UpdateStoragePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/UpdateVolume/main.go b/internal/generated/snippets/netapp/apiv1/Client/UpdateVolume/main.go index df02821cc5ce..3deaf4cbe34e 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/UpdateVolume/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/UpdateVolume/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/Client/VerifyKmsConfig/main.go b/internal/generated/snippets/netapp/apiv1/Client/VerifyKmsConfig/main.go index be891f355764..22b7f239a458 100644 --- a/internal/generated/snippets/netapp/apiv1/Client/VerifyKmsConfig/main.go +++ b/internal/generated/snippets/netapp/apiv1/Client/VerifyKmsConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/netapp/apiv1/snippet_metadata.google.cloud.netapp.v1.json b/internal/generated/snippets/netapp/apiv1/snippet_metadata.google.cloud.netapp.v1.json index 95f9ce4b764d..885ccafd32db 100644 --- a/internal/generated/snippets/netapp/apiv1/snippet_metadata.google.cloud.netapp.v1.json +++ b/internal/generated/snippets/netapp/apiv1/snippet_metadata.google.cloud.netapp.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/netapp/apiv1", - "version": "1.5.0", + "version": "1.5.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/AcceptHubSpoke/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/AcceptHubSpoke/main.go index 186e5ab6e15c..fe937bf48f4e 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/AcceptHubSpoke/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/AcceptHubSpoke/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/CancelOperation/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/CancelOperation/main.go index c770852ad45e..9cb7122a6e42 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/CancelOperation/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/CreateHub/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/CreateHub/main.go index 6a8c0480e367..ba851fbe1086 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/CreateHub/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/CreateHub/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/CreateSpoke/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/CreateSpoke/main.go index 067b5b17432c..528240131a1b 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/CreateSpoke/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/CreateSpoke/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/DeleteHub/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/DeleteHub/main.go index 8e69536250da..5eaafd1c27b6 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/DeleteHub/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/DeleteHub/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/DeleteOperation/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/DeleteOperation/main.go index 50f5836813b2..fe6ba9a04782 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/DeleteOperation/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/DeleteSpoke/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/DeleteSpoke/main.go index 62145afaa034..560a377529b7 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/DeleteSpoke/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/DeleteSpoke/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetGroup/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetGroup/main.go index f361c3cb26b9..cf7fe02b556c 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetGroup/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetHub/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetHub/main.go index 2772dd5c507e..2d96dac2cb17 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetHub/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetHub/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetIamPolicy/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetIamPolicy/main.go index 237c02f8a1f1..8db5be4b75e8 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetLocation/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetLocation/main.go index f5d4d740f277..0d21afd53c6c 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetLocation/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetOperation/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetOperation/main.go index a085cd6a7dc0..5a0cda8a41c7 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetOperation/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetRoute/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetRoute/main.go index f645d5c91039..f8b4ac3d13c1 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetRoute/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetRoute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetRouteTable/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetRouteTable/main.go index 27f03b94f063..47404367b0fe 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetRouteTable/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetRouteTable/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetSpoke/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetSpoke/main.go index bf68c069961e..acd35e633b49 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetSpoke/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/GetSpoke/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListGroups/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListGroups/main.go index c4f2c3a7c206..f581afbb7243 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListGroups/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListGroups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListHubSpokes/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListHubSpokes/main.go index 749a10e2d7ad..c199a94b6eb1 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListHubSpokes/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListHubSpokes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListHubs/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListHubs/main.go index cd51375ca8a6..fd8ccb237b24 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListHubs/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListHubs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListLocations/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListLocations/main.go index f4a30926b049..456aa11ca2c5 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListLocations/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListOperations/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListOperations/main.go index 6c0b0f4ebb1e..77a5bd456f0d 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListOperations/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListRouteTables/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListRouteTables/main.go index 029314983ca0..f8a119b5119a 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListRouteTables/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListRouteTables/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListRoutes/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListRoutes/main.go index f196d2c37279..2496e67c0e44 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListRoutes/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListRoutes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListSpokes/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListSpokes/main.go index e0d7071c2b5e..b73f08609f13 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListSpokes/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/ListSpokes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/QueryHubStatus/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/QueryHubStatus/main.go index 232455e8d70e..cf583de69a30 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/QueryHubStatus/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/QueryHubStatus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/RejectHubSpoke/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/RejectHubSpoke/main.go index 6278bac61b01..6c2eccc58c46 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/RejectHubSpoke/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/RejectHubSpoke/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/SetIamPolicy/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/SetIamPolicy/main.go index ee7162c2885f..6afa11cfd321 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/TestIamPermissions/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/TestIamPermissions/main.go index fae60cca2037..443f3bccaa47 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/UpdateGroup/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/UpdateGroup/main.go index baee8cb7e3ef..53ada5b8814b 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/UpdateGroup/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/UpdateGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/UpdateHub/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/UpdateHub/main.go index 41f4f5ff8be6..1d41a72a50ea 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/UpdateHub/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/UpdateHub/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/UpdateSpoke/main.go b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/UpdateSpoke/main.go index d4172f44935f..081841de03ee 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/HubClient/UpdateSpoke/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/HubClient/UpdateSpoke/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/CancelOperation/main.go b/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/CancelOperation/main.go index 69a2bae0a273..05b484e0b4dd 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/CancelOperation/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/CreatePolicyBasedRoute/main.go b/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/CreatePolicyBasedRoute/main.go index 1e2d2f599687..8a155c814788 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/CreatePolicyBasedRoute/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/CreatePolicyBasedRoute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/DeleteOperation/main.go b/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/DeleteOperation/main.go index b01fc9ebaf84..918f4cd266d7 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/DeleteOperation/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/DeletePolicyBasedRoute/main.go b/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/DeletePolicyBasedRoute/main.go index 74bfbd4428b1..34e55e338e23 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/DeletePolicyBasedRoute/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/DeletePolicyBasedRoute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/GetIamPolicy/main.go b/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/GetIamPolicy/main.go index df8b5aa963f9..940b28cce357 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/GetLocation/main.go b/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/GetLocation/main.go index f0fd842cdd11..b7ee46f71c99 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/GetLocation/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/GetOperation/main.go b/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/GetOperation/main.go index 7136c68760f0..885ec9b88eda 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/GetOperation/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/GetPolicyBasedRoute/main.go b/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/GetPolicyBasedRoute/main.go index 1929d614aceb..975bee6de992 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/GetPolicyBasedRoute/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/GetPolicyBasedRoute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/ListLocations/main.go b/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/ListLocations/main.go index 0c9c364c2153..97ecfa8c2684 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/ListLocations/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/ListOperations/main.go b/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/ListOperations/main.go index 34a2c14239a3..3c2f74627d9e 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/ListOperations/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/ListPolicyBasedRoutes/main.go b/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/ListPolicyBasedRoutes/main.go index 21e1f357c54b..af56c659e366 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/ListPolicyBasedRoutes/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/ListPolicyBasedRoutes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/SetIamPolicy/main.go b/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/SetIamPolicy/main.go index 9151c6c08dc2..6eafb7de9767 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/TestIamPermissions/main.go b/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/TestIamPermissions/main.go index 960657f5ad67..7c47890449f1 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1/PolicyBasedRoutingClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/CreateHub/main.go b/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/CreateHub/main.go index 1831811f7ac6..8c4c5366be50 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/CreateHub/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/CreateHub/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/CreateSpoke/main.go b/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/CreateSpoke/main.go index d0c52e3bfd50..e76ebedb0964 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/CreateSpoke/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/CreateSpoke/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/DeleteHub/main.go b/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/DeleteHub/main.go index a74becaa6e7e..c0eb8996adb8 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/DeleteHub/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/DeleteHub/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/DeleteSpoke/main.go b/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/DeleteSpoke/main.go index a105e2f7d050..cd37a5d7340e 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/DeleteSpoke/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/DeleteSpoke/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/GetHub/main.go b/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/GetHub/main.go index a887048ad8ca..b85ea8a70db1 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/GetHub/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/GetHub/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/GetSpoke/main.go b/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/GetSpoke/main.go index f33571d98823..6512eae6e799 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/GetSpoke/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/GetSpoke/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/ListHubs/main.go b/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/ListHubs/main.go index 5b628af64898..428b6a5abf0a 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/ListHubs/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/ListHubs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/ListSpokes/main.go b/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/ListSpokes/main.go index 6320e0b6559f..0b2dfddafd41 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/ListSpokes/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/ListSpokes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/UpdateHub/main.go b/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/UpdateHub/main.go index fef10993e983..d95b5fe97135 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/UpdateHub/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/UpdateHub/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/UpdateSpoke/main.go b/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/UpdateSpoke/main.go index d1dd5cba7f69..3bf84be10adb 100644 --- a/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/UpdateSpoke/main.go +++ b/internal/generated/snippets/networkconnectivity/apiv1alpha1/HubClient/UpdateSpoke/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/CancelOperation/main.go b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/CancelOperation/main.go index 129672d5f1c7..696767b77f6e 100644 --- a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/CancelOperation/main.go +++ b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/CreateConnectivityTest/main.go b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/CreateConnectivityTest/main.go index b1a59968bf0d..f9b76091b533 100644 --- a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/CreateConnectivityTest/main.go +++ b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/CreateConnectivityTest/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/DeleteConnectivityTest/main.go b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/DeleteConnectivityTest/main.go index 1a86b4d61407..7f06b383f551 100644 --- a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/DeleteConnectivityTest/main.go +++ b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/DeleteConnectivityTest/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/DeleteOperation/main.go b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/DeleteOperation/main.go index fbbab8ca2656..06bc85f81723 100644 --- a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/DeleteOperation/main.go +++ b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/GetConnectivityTest/main.go b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/GetConnectivityTest/main.go index ff74c47cf250..a3697df0b8a2 100644 --- a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/GetConnectivityTest/main.go +++ b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/GetConnectivityTest/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/GetIamPolicy/main.go b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/GetIamPolicy/main.go index ff9e7627639c..0f410fcff1a5 100644 --- a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/GetLocation/main.go b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/GetLocation/main.go index 345e582f31a1..c41a5c4a61e4 100644 --- a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/GetLocation/main.go +++ b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/GetOperation/main.go b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/GetOperation/main.go index 6cb4bd56659b..300f43e79d33 100644 --- a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/GetOperation/main.go +++ b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/ListConnectivityTests/main.go b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/ListConnectivityTests/main.go index d039407f8920..c035f096e4f9 100644 --- a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/ListConnectivityTests/main.go +++ b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/ListConnectivityTests/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/ListLocations/main.go b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/ListLocations/main.go index e335218d582c..046fba397732 100644 --- a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/ListLocations/main.go +++ b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/ListOperations/main.go b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/ListOperations/main.go index c4eb26baa2ef..fc04b66761b5 100644 --- a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/ListOperations/main.go +++ b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/RerunConnectivityTest/main.go b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/RerunConnectivityTest/main.go index 60d6e6f32244..7662e6e27a90 100644 --- a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/RerunConnectivityTest/main.go +++ b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/RerunConnectivityTest/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/SetIamPolicy/main.go b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/SetIamPolicy/main.go index 2305d6d3fb07..898094c3a163 100644 --- a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/TestIamPermissions/main.go b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/TestIamPermissions/main.go index 7c244e80bbdb..4f273c46ed63 100644 --- a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/UpdateConnectivityTest/main.go b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/UpdateConnectivityTest/main.go index 4ba53bfb210e..b7862b786681 100644 --- a/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/UpdateConnectivityTest/main.go +++ b/internal/generated/snippets/networkmanagement/apiv1/ReachabilityClient/UpdateConnectivityTest/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkmanagement/apiv1/snippet_metadata.google.cloud.networkmanagement.v1.json b/internal/generated/snippets/networkmanagement/apiv1/snippet_metadata.google.cloud.networkmanagement.v1.json index c798f4276221..5f2aae37d61b 100644 --- a/internal/generated/snippets/networkmanagement/apiv1/snippet_metadata.google.cloud.networkmanagement.v1.json +++ b/internal/generated/snippets/networkmanagement/apiv1/snippet_metadata.google.cloud.networkmanagement.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/networkmanagement/apiv1", - "version": "1.17.0", + "version": "1.17.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/networksecurity/apiv1beta1/Client/CancelOperation/main.go b/internal/generated/snippets/networksecurity/apiv1beta1/Client/CancelOperation/main.go index a78a4a8ca974..fdd45baa876f 100644 --- a/internal/generated/snippets/networksecurity/apiv1beta1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/networksecurity/apiv1beta1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networksecurity/apiv1beta1/Client/CreateAuthorizationPolicy/main.go b/internal/generated/snippets/networksecurity/apiv1beta1/Client/CreateAuthorizationPolicy/main.go index 583fa21d6591..5c607b98cd81 100644 --- a/internal/generated/snippets/networksecurity/apiv1beta1/Client/CreateAuthorizationPolicy/main.go +++ b/internal/generated/snippets/networksecurity/apiv1beta1/Client/CreateAuthorizationPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networksecurity/apiv1beta1/Client/CreateClientTlsPolicy/main.go b/internal/generated/snippets/networksecurity/apiv1beta1/Client/CreateClientTlsPolicy/main.go index 354d43aae50a..8b74060cc928 100644 --- a/internal/generated/snippets/networksecurity/apiv1beta1/Client/CreateClientTlsPolicy/main.go +++ b/internal/generated/snippets/networksecurity/apiv1beta1/Client/CreateClientTlsPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networksecurity/apiv1beta1/Client/CreateServerTlsPolicy/main.go b/internal/generated/snippets/networksecurity/apiv1beta1/Client/CreateServerTlsPolicy/main.go index 4031c5e1e58d..18a9d7610169 100644 --- a/internal/generated/snippets/networksecurity/apiv1beta1/Client/CreateServerTlsPolicy/main.go +++ b/internal/generated/snippets/networksecurity/apiv1beta1/Client/CreateServerTlsPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networksecurity/apiv1beta1/Client/DeleteAuthorizationPolicy/main.go b/internal/generated/snippets/networksecurity/apiv1beta1/Client/DeleteAuthorizationPolicy/main.go index c9ab0316d450..577c68b840bd 100644 --- a/internal/generated/snippets/networksecurity/apiv1beta1/Client/DeleteAuthorizationPolicy/main.go +++ b/internal/generated/snippets/networksecurity/apiv1beta1/Client/DeleteAuthorizationPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networksecurity/apiv1beta1/Client/DeleteClientTlsPolicy/main.go b/internal/generated/snippets/networksecurity/apiv1beta1/Client/DeleteClientTlsPolicy/main.go index f6bc3882d3e5..9921ce8fd4d8 100644 --- a/internal/generated/snippets/networksecurity/apiv1beta1/Client/DeleteClientTlsPolicy/main.go +++ b/internal/generated/snippets/networksecurity/apiv1beta1/Client/DeleteClientTlsPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networksecurity/apiv1beta1/Client/DeleteOperation/main.go b/internal/generated/snippets/networksecurity/apiv1beta1/Client/DeleteOperation/main.go index 9059981d159d..44d2b702cd5d 100644 --- a/internal/generated/snippets/networksecurity/apiv1beta1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/networksecurity/apiv1beta1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networksecurity/apiv1beta1/Client/DeleteServerTlsPolicy/main.go b/internal/generated/snippets/networksecurity/apiv1beta1/Client/DeleteServerTlsPolicy/main.go index 090720315215..ece0232134d2 100644 --- a/internal/generated/snippets/networksecurity/apiv1beta1/Client/DeleteServerTlsPolicy/main.go +++ b/internal/generated/snippets/networksecurity/apiv1beta1/Client/DeleteServerTlsPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networksecurity/apiv1beta1/Client/GetAuthorizationPolicy/main.go b/internal/generated/snippets/networksecurity/apiv1beta1/Client/GetAuthorizationPolicy/main.go index 611f18f0e7d0..7204ea5b31a9 100644 --- a/internal/generated/snippets/networksecurity/apiv1beta1/Client/GetAuthorizationPolicy/main.go +++ b/internal/generated/snippets/networksecurity/apiv1beta1/Client/GetAuthorizationPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networksecurity/apiv1beta1/Client/GetClientTlsPolicy/main.go b/internal/generated/snippets/networksecurity/apiv1beta1/Client/GetClientTlsPolicy/main.go index e525c02db89a..56b598453e1d 100644 --- a/internal/generated/snippets/networksecurity/apiv1beta1/Client/GetClientTlsPolicy/main.go +++ b/internal/generated/snippets/networksecurity/apiv1beta1/Client/GetClientTlsPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networksecurity/apiv1beta1/Client/GetIamPolicy/main.go b/internal/generated/snippets/networksecurity/apiv1beta1/Client/GetIamPolicy/main.go index 10f7acb7964d..fe42a7dc5703 100644 --- a/internal/generated/snippets/networksecurity/apiv1beta1/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/networksecurity/apiv1beta1/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networksecurity/apiv1beta1/Client/GetLocation/main.go b/internal/generated/snippets/networksecurity/apiv1beta1/Client/GetLocation/main.go index 4f7206488751..b5144fd65cd1 100644 --- a/internal/generated/snippets/networksecurity/apiv1beta1/Client/GetLocation/main.go +++ b/internal/generated/snippets/networksecurity/apiv1beta1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networksecurity/apiv1beta1/Client/GetOperation/main.go b/internal/generated/snippets/networksecurity/apiv1beta1/Client/GetOperation/main.go index e7391e3dd26e..cb4f1391f407 100644 --- a/internal/generated/snippets/networksecurity/apiv1beta1/Client/GetOperation/main.go +++ b/internal/generated/snippets/networksecurity/apiv1beta1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networksecurity/apiv1beta1/Client/GetServerTlsPolicy/main.go b/internal/generated/snippets/networksecurity/apiv1beta1/Client/GetServerTlsPolicy/main.go index 10d4064c04c4..150590b7cee7 100644 --- a/internal/generated/snippets/networksecurity/apiv1beta1/Client/GetServerTlsPolicy/main.go +++ b/internal/generated/snippets/networksecurity/apiv1beta1/Client/GetServerTlsPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networksecurity/apiv1beta1/Client/ListAuthorizationPolicies/main.go b/internal/generated/snippets/networksecurity/apiv1beta1/Client/ListAuthorizationPolicies/main.go index 6343d301b6e0..f657c396f02e 100644 --- a/internal/generated/snippets/networksecurity/apiv1beta1/Client/ListAuthorizationPolicies/main.go +++ b/internal/generated/snippets/networksecurity/apiv1beta1/Client/ListAuthorizationPolicies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networksecurity/apiv1beta1/Client/ListClientTlsPolicies/main.go b/internal/generated/snippets/networksecurity/apiv1beta1/Client/ListClientTlsPolicies/main.go index 7f25044ee0b3..8535658e2176 100644 --- a/internal/generated/snippets/networksecurity/apiv1beta1/Client/ListClientTlsPolicies/main.go +++ b/internal/generated/snippets/networksecurity/apiv1beta1/Client/ListClientTlsPolicies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networksecurity/apiv1beta1/Client/ListLocations/main.go b/internal/generated/snippets/networksecurity/apiv1beta1/Client/ListLocations/main.go index 47f70cc9dc9c..854943c2b3f5 100644 --- a/internal/generated/snippets/networksecurity/apiv1beta1/Client/ListLocations/main.go +++ b/internal/generated/snippets/networksecurity/apiv1beta1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networksecurity/apiv1beta1/Client/ListOperations/main.go b/internal/generated/snippets/networksecurity/apiv1beta1/Client/ListOperations/main.go index beee8adfbdfe..7530ed05219c 100644 --- a/internal/generated/snippets/networksecurity/apiv1beta1/Client/ListOperations/main.go +++ b/internal/generated/snippets/networksecurity/apiv1beta1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networksecurity/apiv1beta1/Client/ListServerTlsPolicies/main.go b/internal/generated/snippets/networksecurity/apiv1beta1/Client/ListServerTlsPolicies/main.go index a2c8a6af69d9..84ce8e9c09c3 100644 --- a/internal/generated/snippets/networksecurity/apiv1beta1/Client/ListServerTlsPolicies/main.go +++ b/internal/generated/snippets/networksecurity/apiv1beta1/Client/ListServerTlsPolicies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networksecurity/apiv1beta1/Client/SetIamPolicy/main.go b/internal/generated/snippets/networksecurity/apiv1beta1/Client/SetIamPolicy/main.go index 338fc9202932..0155a373911d 100644 --- a/internal/generated/snippets/networksecurity/apiv1beta1/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/networksecurity/apiv1beta1/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networksecurity/apiv1beta1/Client/TestIamPermissions/main.go b/internal/generated/snippets/networksecurity/apiv1beta1/Client/TestIamPermissions/main.go index 6cbb8c0d077b..dd0e7a184660 100644 --- a/internal/generated/snippets/networksecurity/apiv1beta1/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/networksecurity/apiv1beta1/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networksecurity/apiv1beta1/Client/UpdateAuthorizationPolicy/main.go b/internal/generated/snippets/networksecurity/apiv1beta1/Client/UpdateAuthorizationPolicy/main.go index 10005718b34c..822a0fe6ebc8 100644 --- a/internal/generated/snippets/networksecurity/apiv1beta1/Client/UpdateAuthorizationPolicy/main.go +++ b/internal/generated/snippets/networksecurity/apiv1beta1/Client/UpdateAuthorizationPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networksecurity/apiv1beta1/Client/UpdateClientTlsPolicy/main.go b/internal/generated/snippets/networksecurity/apiv1beta1/Client/UpdateClientTlsPolicy/main.go index 08764e5f3400..b902eabda387 100644 --- a/internal/generated/snippets/networksecurity/apiv1beta1/Client/UpdateClientTlsPolicy/main.go +++ b/internal/generated/snippets/networksecurity/apiv1beta1/Client/UpdateClientTlsPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networksecurity/apiv1beta1/Client/UpdateServerTlsPolicy/main.go b/internal/generated/snippets/networksecurity/apiv1beta1/Client/UpdateServerTlsPolicy/main.go index 50db42c1ded0..ee3b5950f570 100644 --- a/internal/generated/snippets/networksecurity/apiv1beta1/Client/UpdateServerTlsPolicy/main.go +++ b/internal/generated/snippets/networksecurity/apiv1beta1/Client/UpdateServerTlsPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/networkservices/apiv1/Client/CancelOperation/main.go index 8679fd030bb7..5933be5bd9c7 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/CreateEndpointPolicy/main.go b/internal/generated/snippets/networkservices/apiv1/Client/CreateEndpointPolicy/main.go index d5bb0156d910..a44829b1079d 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/CreateEndpointPolicy/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/CreateEndpointPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/CreateGateway/main.go b/internal/generated/snippets/networkservices/apiv1/Client/CreateGateway/main.go index 8b3afc4db870..629fafdf0a20 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/CreateGateway/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/CreateGateway/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/CreateGrpcRoute/main.go b/internal/generated/snippets/networkservices/apiv1/Client/CreateGrpcRoute/main.go index 7ef16714acd7..91a2b72c6420 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/CreateGrpcRoute/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/CreateGrpcRoute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/CreateHttpRoute/main.go b/internal/generated/snippets/networkservices/apiv1/Client/CreateHttpRoute/main.go index 627a375259de..8dec8e8ceabb 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/CreateHttpRoute/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/CreateHttpRoute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/CreateMesh/main.go b/internal/generated/snippets/networkservices/apiv1/Client/CreateMesh/main.go index 65602a71da32..d26db2091aa4 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/CreateMesh/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/CreateMesh/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/CreateServiceBinding/main.go b/internal/generated/snippets/networkservices/apiv1/Client/CreateServiceBinding/main.go index 3093891cd8c8..baeb50acb887 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/CreateServiceBinding/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/CreateServiceBinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/CreateTcpRoute/main.go b/internal/generated/snippets/networkservices/apiv1/Client/CreateTcpRoute/main.go index eecd402ee742..89cbe5c3826f 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/CreateTcpRoute/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/CreateTcpRoute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/CreateTlsRoute/main.go b/internal/generated/snippets/networkservices/apiv1/Client/CreateTlsRoute/main.go index 71ae7f523b4f..da5bd79ae117 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/CreateTlsRoute/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/CreateTlsRoute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/DeleteEndpointPolicy/main.go b/internal/generated/snippets/networkservices/apiv1/Client/DeleteEndpointPolicy/main.go index 237ce096e21d..8d376f504427 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/DeleteEndpointPolicy/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/DeleteEndpointPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/DeleteGateway/main.go b/internal/generated/snippets/networkservices/apiv1/Client/DeleteGateway/main.go index db02b39c3150..4388ecf1cf7f 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/DeleteGateway/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/DeleteGateway/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/DeleteGrpcRoute/main.go b/internal/generated/snippets/networkservices/apiv1/Client/DeleteGrpcRoute/main.go index 1fd1941f5509..3efcd5a711c9 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/DeleteGrpcRoute/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/DeleteGrpcRoute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/DeleteHttpRoute/main.go b/internal/generated/snippets/networkservices/apiv1/Client/DeleteHttpRoute/main.go index 444d0865a1bb..26eb7832e008 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/DeleteHttpRoute/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/DeleteHttpRoute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/DeleteMesh/main.go b/internal/generated/snippets/networkservices/apiv1/Client/DeleteMesh/main.go index 75e29263339d..27d246119bcb 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/DeleteMesh/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/DeleteMesh/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/networkservices/apiv1/Client/DeleteOperation/main.go index d97aa857d6c3..bcc812e95257 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/DeleteServiceBinding/main.go b/internal/generated/snippets/networkservices/apiv1/Client/DeleteServiceBinding/main.go index 13eace2c3c4f..1dccf31d90bc 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/DeleteServiceBinding/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/DeleteServiceBinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/DeleteTcpRoute/main.go b/internal/generated/snippets/networkservices/apiv1/Client/DeleteTcpRoute/main.go index 1608fb3eaff7..bbe42499088f 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/DeleteTcpRoute/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/DeleteTcpRoute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/DeleteTlsRoute/main.go b/internal/generated/snippets/networkservices/apiv1/Client/DeleteTlsRoute/main.go index f87a48d8a76d..f546fc8287ed 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/DeleteTlsRoute/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/DeleteTlsRoute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/GetEndpointPolicy/main.go b/internal/generated/snippets/networkservices/apiv1/Client/GetEndpointPolicy/main.go index 25a930053232..98e89aba4781 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/GetEndpointPolicy/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/GetEndpointPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/GetGateway/main.go b/internal/generated/snippets/networkservices/apiv1/Client/GetGateway/main.go index a9f21e2ef9f9..025419196c83 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/GetGateway/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/GetGateway/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/GetGrpcRoute/main.go b/internal/generated/snippets/networkservices/apiv1/Client/GetGrpcRoute/main.go index fcab3c99b4e4..58ebd84e0e51 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/GetGrpcRoute/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/GetGrpcRoute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/GetHttpRoute/main.go b/internal/generated/snippets/networkservices/apiv1/Client/GetHttpRoute/main.go index a8caa4b85242..2c68d0889791 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/GetHttpRoute/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/GetHttpRoute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/GetIamPolicy/main.go b/internal/generated/snippets/networkservices/apiv1/Client/GetIamPolicy/main.go index d6b7362b40a3..cf13a02a8f38 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/networkservices/apiv1/Client/GetLocation/main.go index b44f141bb397..4da9a237602a 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/GetMesh/main.go b/internal/generated/snippets/networkservices/apiv1/Client/GetMesh/main.go index c07b33ed9bc8..128d2ea11f10 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/GetMesh/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/GetMesh/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/networkservices/apiv1/Client/GetOperation/main.go index 44293fe6e7f8..aca0ddd475b9 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/GetServiceBinding/main.go b/internal/generated/snippets/networkservices/apiv1/Client/GetServiceBinding/main.go index 2b3b1332e276..fe8000f50c4e 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/GetServiceBinding/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/GetServiceBinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/GetTcpRoute/main.go b/internal/generated/snippets/networkservices/apiv1/Client/GetTcpRoute/main.go index 84543cfca408..a525f193f4a2 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/GetTcpRoute/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/GetTcpRoute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/GetTlsRoute/main.go b/internal/generated/snippets/networkservices/apiv1/Client/GetTlsRoute/main.go index f338ef16c278..43fae925e73c 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/GetTlsRoute/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/GetTlsRoute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/ListEndpointPolicies/main.go b/internal/generated/snippets/networkservices/apiv1/Client/ListEndpointPolicies/main.go index 28aee94b215d..111ff57c4c16 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/ListEndpointPolicies/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/ListEndpointPolicies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/ListGateways/main.go b/internal/generated/snippets/networkservices/apiv1/Client/ListGateways/main.go index 8768403ca525..4bb119b89dd5 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/ListGateways/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/ListGateways/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/ListGrpcRoutes/main.go b/internal/generated/snippets/networkservices/apiv1/Client/ListGrpcRoutes/main.go index 16a2e64b0f69..1473c7aaffc0 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/ListGrpcRoutes/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/ListGrpcRoutes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/ListHttpRoutes/main.go b/internal/generated/snippets/networkservices/apiv1/Client/ListHttpRoutes/main.go index 239d2d29628c..10238178d751 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/ListHttpRoutes/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/ListHttpRoutes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/networkservices/apiv1/Client/ListLocations/main.go index 78e5c11efee0..34808f0a1858 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/ListMeshes/main.go b/internal/generated/snippets/networkservices/apiv1/Client/ListMeshes/main.go index 18f8ad8a9406..d693186ad095 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/ListMeshes/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/ListMeshes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/networkservices/apiv1/Client/ListOperations/main.go index 9a002e46c361..fd0d0090225e 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/ListServiceBindings/main.go b/internal/generated/snippets/networkservices/apiv1/Client/ListServiceBindings/main.go index 84e0b388b5fa..0a96bd23d512 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/ListServiceBindings/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/ListServiceBindings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/ListTcpRoutes/main.go b/internal/generated/snippets/networkservices/apiv1/Client/ListTcpRoutes/main.go index 4f398d29088e..65786bdcd30e 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/ListTcpRoutes/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/ListTcpRoutes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/ListTlsRoutes/main.go b/internal/generated/snippets/networkservices/apiv1/Client/ListTlsRoutes/main.go index 0f18b9d22954..081d8ca0b34d 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/ListTlsRoutes/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/ListTlsRoutes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/SetIamPolicy/main.go b/internal/generated/snippets/networkservices/apiv1/Client/SetIamPolicy/main.go index 15453240006e..0eff9b502a51 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/TestIamPermissions/main.go b/internal/generated/snippets/networkservices/apiv1/Client/TestIamPermissions/main.go index 9a0ba80a073c..4118f0864b6b 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/UpdateEndpointPolicy/main.go b/internal/generated/snippets/networkservices/apiv1/Client/UpdateEndpointPolicy/main.go index a2bcf977bd6d..843b5e07b736 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/UpdateEndpointPolicy/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/UpdateEndpointPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/UpdateGateway/main.go b/internal/generated/snippets/networkservices/apiv1/Client/UpdateGateway/main.go index 2f57135f44e4..a305d5bc18a6 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/UpdateGateway/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/UpdateGateway/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/UpdateGrpcRoute/main.go b/internal/generated/snippets/networkservices/apiv1/Client/UpdateGrpcRoute/main.go index bc63d5d6aafa..96cf41b529dd 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/UpdateGrpcRoute/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/UpdateGrpcRoute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/UpdateHttpRoute/main.go b/internal/generated/snippets/networkservices/apiv1/Client/UpdateHttpRoute/main.go index e93185b5081b..91cce4f6ba3a 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/UpdateHttpRoute/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/UpdateHttpRoute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/UpdateMesh/main.go b/internal/generated/snippets/networkservices/apiv1/Client/UpdateMesh/main.go index e3a319d14d97..130e0d6268f5 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/UpdateMesh/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/UpdateMesh/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/UpdateTcpRoute/main.go b/internal/generated/snippets/networkservices/apiv1/Client/UpdateTcpRoute/main.go index 104dd923130f..3fb2bef14a8b 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/UpdateTcpRoute/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/UpdateTcpRoute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/Client/UpdateTlsRoute/main.go b/internal/generated/snippets/networkservices/apiv1/Client/UpdateTlsRoute/main.go index afb9af9d548f..c0fbc20dba1c 100644 --- a/internal/generated/snippets/networkservices/apiv1/Client/UpdateTlsRoute/main.go +++ b/internal/generated/snippets/networkservices/apiv1/Client/UpdateTlsRoute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/DepClient/CancelOperation/main.go b/internal/generated/snippets/networkservices/apiv1/DepClient/CancelOperation/main.go index d4276a62dee8..ec31036f5155 100644 --- a/internal/generated/snippets/networkservices/apiv1/DepClient/CancelOperation/main.go +++ b/internal/generated/snippets/networkservices/apiv1/DepClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/DepClient/CreateLbRouteExtension/main.go b/internal/generated/snippets/networkservices/apiv1/DepClient/CreateLbRouteExtension/main.go index afcdd92c6067..0b7af113ba6e 100644 --- a/internal/generated/snippets/networkservices/apiv1/DepClient/CreateLbRouteExtension/main.go +++ b/internal/generated/snippets/networkservices/apiv1/DepClient/CreateLbRouteExtension/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/DepClient/CreateLbTrafficExtension/main.go b/internal/generated/snippets/networkservices/apiv1/DepClient/CreateLbTrafficExtension/main.go index 48dc2969f017..0beea9f18320 100644 --- a/internal/generated/snippets/networkservices/apiv1/DepClient/CreateLbTrafficExtension/main.go +++ b/internal/generated/snippets/networkservices/apiv1/DepClient/CreateLbTrafficExtension/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/DepClient/DeleteLbRouteExtension/main.go b/internal/generated/snippets/networkservices/apiv1/DepClient/DeleteLbRouteExtension/main.go index d7224a98aa9a..ed6b27965c42 100644 --- a/internal/generated/snippets/networkservices/apiv1/DepClient/DeleteLbRouteExtension/main.go +++ b/internal/generated/snippets/networkservices/apiv1/DepClient/DeleteLbRouteExtension/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/DepClient/DeleteLbTrafficExtension/main.go b/internal/generated/snippets/networkservices/apiv1/DepClient/DeleteLbTrafficExtension/main.go index 433b58b4cf0b..86518bb585e1 100644 --- a/internal/generated/snippets/networkservices/apiv1/DepClient/DeleteLbTrafficExtension/main.go +++ b/internal/generated/snippets/networkservices/apiv1/DepClient/DeleteLbTrafficExtension/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/DepClient/DeleteOperation/main.go b/internal/generated/snippets/networkservices/apiv1/DepClient/DeleteOperation/main.go index 34cfa3c3f37e..8374bac4ed1a 100644 --- a/internal/generated/snippets/networkservices/apiv1/DepClient/DeleteOperation/main.go +++ b/internal/generated/snippets/networkservices/apiv1/DepClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/DepClient/GetIamPolicy/main.go b/internal/generated/snippets/networkservices/apiv1/DepClient/GetIamPolicy/main.go index 9dca522e397d..573ada1343fb 100644 --- a/internal/generated/snippets/networkservices/apiv1/DepClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/networkservices/apiv1/DepClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/DepClient/GetLbRouteExtension/main.go b/internal/generated/snippets/networkservices/apiv1/DepClient/GetLbRouteExtension/main.go index 852ed468a882..505a53d9a47c 100644 --- a/internal/generated/snippets/networkservices/apiv1/DepClient/GetLbRouteExtension/main.go +++ b/internal/generated/snippets/networkservices/apiv1/DepClient/GetLbRouteExtension/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/DepClient/GetLbTrafficExtension/main.go b/internal/generated/snippets/networkservices/apiv1/DepClient/GetLbTrafficExtension/main.go index 268606c1c13e..ec35b7d3c5fe 100644 --- a/internal/generated/snippets/networkservices/apiv1/DepClient/GetLbTrafficExtension/main.go +++ b/internal/generated/snippets/networkservices/apiv1/DepClient/GetLbTrafficExtension/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/DepClient/GetLocation/main.go b/internal/generated/snippets/networkservices/apiv1/DepClient/GetLocation/main.go index 1948cca8d40f..9bde9a131f53 100644 --- a/internal/generated/snippets/networkservices/apiv1/DepClient/GetLocation/main.go +++ b/internal/generated/snippets/networkservices/apiv1/DepClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/DepClient/GetOperation/main.go b/internal/generated/snippets/networkservices/apiv1/DepClient/GetOperation/main.go index 599b7c2a8598..f7e7eabb6431 100644 --- a/internal/generated/snippets/networkservices/apiv1/DepClient/GetOperation/main.go +++ b/internal/generated/snippets/networkservices/apiv1/DepClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/DepClient/ListLbRouteExtensions/main.go b/internal/generated/snippets/networkservices/apiv1/DepClient/ListLbRouteExtensions/main.go index 0ca288d58027..f4687a718e8c 100644 --- a/internal/generated/snippets/networkservices/apiv1/DepClient/ListLbRouteExtensions/main.go +++ b/internal/generated/snippets/networkservices/apiv1/DepClient/ListLbRouteExtensions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/DepClient/ListLbTrafficExtensions/main.go b/internal/generated/snippets/networkservices/apiv1/DepClient/ListLbTrafficExtensions/main.go index 9e69ea037ab5..2f1f4cf32589 100644 --- a/internal/generated/snippets/networkservices/apiv1/DepClient/ListLbTrafficExtensions/main.go +++ b/internal/generated/snippets/networkservices/apiv1/DepClient/ListLbTrafficExtensions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/DepClient/ListLocations/main.go b/internal/generated/snippets/networkservices/apiv1/DepClient/ListLocations/main.go index 6d8f72f22e5b..88d153da2c81 100644 --- a/internal/generated/snippets/networkservices/apiv1/DepClient/ListLocations/main.go +++ b/internal/generated/snippets/networkservices/apiv1/DepClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/DepClient/ListOperations/main.go b/internal/generated/snippets/networkservices/apiv1/DepClient/ListOperations/main.go index 3f519aa486d0..0a37657250a1 100644 --- a/internal/generated/snippets/networkservices/apiv1/DepClient/ListOperations/main.go +++ b/internal/generated/snippets/networkservices/apiv1/DepClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/DepClient/SetIamPolicy/main.go b/internal/generated/snippets/networkservices/apiv1/DepClient/SetIamPolicy/main.go index 1c8c7468adc8..e8c1faad0e36 100644 --- a/internal/generated/snippets/networkservices/apiv1/DepClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/networkservices/apiv1/DepClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/DepClient/TestIamPermissions/main.go b/internal/generated/snippets/networkservices/apiv1/DepClient/TestIamPermissions/main.go index e481aa56ba1a..7eefcb779237 100644 --- a/internal/generated/snippets/networkservices/apiv1/DepClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/networkservices/apiv1/DepClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/DepClient/UpdateLbRouteExtension/main.go b/internal/generated/snippets/networkservices/apiv1/DepClient/UpdateLbRouteExtension/main.go index 226e4359607e..d3bd6e925d9a 100644 --- a/internal/generated/snippets/networkservices/apiv1/DepClient/UpdateLbRouteExtension/main.go +++ b/internal/generated/snippets/networkservices/apiv1/DepClient/UpdateLbRouteExtension/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/DepClient/UpdateLbTrafficExtension/main.go b/internal/generated/snippets/networkservices/apiv1/DepClient/UpdateLbTrafficExtension/main.go index 615d26769c3e..cd591a36319c 100644 --- a/internal/generated/snippets/networkservices/apiv1/DepClient/UpdateLbTrafficExtension/main.go +++ b/internal/generated/snippets/networkservices/apiv1/DepClient/UpdateLbTrafficExtension/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/networkservices/apiv1/snippet_metadata.google.cloud.networkservices.v1.json b/internal/generated/snippets/networkservices/apiv1/snippet_metadata.google.cloud.networkservices.v1.json index d9d9c2b57eeb..3e461f77f075 100644 --- a/internal/generated/snippets/networkservices/apiv1/snippet_metadata.google.cloud.networkservices.v1.json +++ b/internal/generated/snippets/networkservices/apiv1/snippet_metadata.google.cloud.networkservices.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/networkservices/apiv1", - "version": "0.2.2", + "version": "0.2.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/CancelOperation/main.go b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/CancelOperation/main.go index d32dc58fdd89..3f478c5dc7b1 100644 --- a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/CancelOperation/main.go +++ b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/CreateRuntime/main.go b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/CreateRuntime/main.go index 6dced5e8b94a..b92d8cec0ceb 100644 --- a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/CreateRuntime/main.go +++ b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/CreateRuntime/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/DeleteOperation/main.go b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/DeleteOperation/main.go index 5b876a3b0fe3..f5ed31136a73 100644 --- a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/DeleteOperation/main.go +++ b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/DeleteRuntime/main.go b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/DeleteRuntime/main.go index 1805d2090bff..afd84a663008 100644 --- a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/DeleteRuntime/main.go +++ b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/DeleteRuntime/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/DiagnoseRuntime/main.go b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/DiagnoseRuntime/main.go index d357332cb320..1d3c39c5ba5f 100644 --- a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/DiagnoseRuntime/main.go +++ b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/DiagnoseRuntime/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/GetIamPolicy/main.go b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/GetIamPolicy/main.go index 5f4a9673f831..8012c1c42ca2 100644 --- a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/GetLocation/main.go b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/GetLocation/main.go index 849651c02c9c..15a354ac14f2 100644 --- a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/GetLocation/main.go +++ b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/GetOperation/main.go b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/GetOperation/main.go index aa3f929e8f21..7ead5f8a14fb 100644 --- a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/GetOperation/main.go +++ b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/GetRuntime/main.go b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/GetRuntime/main.go index a0f0b0246628..9f1914db1b74 100644 --- a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/GetRuntime/main.go +++ b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/GetRuntime/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/ListLocations/main.go b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/ListLocations/main.go index dc497934c543..f3f94003b179 100644 --- a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/ListLocations/main.go +++ b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/ListOperations/main.go b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/ListOperations/main.go index 3c85ba2cb198..5f10c07ea021 100644 --- a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/ListOperations/main.go +++ b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/ListRuntimes/main.go b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/ListRuntimes/main.go index 411cdf02eed6..cbcd13838c92 100644 --- a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/ListRuntimes/main.go +++ b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/ListRuntimes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/RefreshRuntimeTokenInternal/main.go b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/RefreshRuntimeTokenInternal/main.go index 5604383c4969..e81ff58a5f7a 100644 --- a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/RefreshRuntimeTokenInternal/main.go +++ b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/RefreshRuntimeTokenInternal/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/ReportRuntimeEvent/main.go b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/ReportRuntimeEvent/main.go index 870423e0a435..2cd6309f0b97 100644 --- a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/ReportRuntimeEvent/main.go +++ b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/ReportRuntimeEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/ResetRuntime/main.go b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/ResetRuntime/main.go index 43a96342fcdf..d734d1868f1d 100644 --- a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/ResetRuntime/main.go +++ b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/ResetRuntime/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/SetIamPolicy/main.go b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/SetIamPolicy/main.go index 673a58ad92e6..c38f861226db 100644 --- a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/StartRuntime/main.go b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/StartRuntime/main.go index 33da99fc72d5..f4fbe78b4495 100644 --- a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/StartRuntime/main.go +++ b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/StartRuntime/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/StopRuntime/main.go b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/StopRuntime/main.go index f2650fce1f05..d97f0bbd20d1 100644 --- a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/StopRuntime/main.go +++ b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/StopRuntime/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/SwitchRuntime/main.go b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/SwitchRuntime/main.go index a5fa11be62a9..b0cf89882d62 100644 --- a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/SwitchRuntime/main.go +++ b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/SwitchRuntime/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/TestIamPermissions/main.go b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/TestIamPermissions/main.go index 612c6b0c5e46..d59037f9caea 100644 --- a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/UpdateRuntime/main.go b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/UpdateRuntime/main.go index 55a24e402eb5..8fce211dd9ac 100644 --- a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/UpdateRuntime/main.go +++ b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/UpdateRuntime/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/UpgradeRuntime/main.go b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/UpgradeRuntime/main.go index ff106882d037..46a6a6f026b9 100644 --- a/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/UpgradeRuntime/main.go +++ b/internal/generated/snippets/notebooks/apiv1/ManagedNotebookClient/UpgradeRuntime/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/CancelOperation/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/CancelOperation/main.go index a6ba1315ac3a..822f6bd82072 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/CancelOperation/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/CreateEnvironment/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/CreateEnvironment/main.go index c899fe6befb0..826c1f986afd 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/CreateEnvironment/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/CreateEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/CreateExecution/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/CreateExecution/main.go index e5e7ba89df9b..7536bd231da5 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/CreateExecution/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/CreateExecution/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/CreateInstance/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/CreateInstance/main.go index e618d42970c8..281347e36924 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/CreateInstance/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/CreateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/CreateSchedule/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/CreateSchedule/main.go index 3fcba51585ff..a8e1551ac236 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/CreateSchedule/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/CreateSchedule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/DeleteEnvironment/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/DeleteEnvironment/main.go index c96c2deb6be9..9341094db19c 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/DeleteEnvironment/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/DeleteEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/DeleteExecution/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/DeleteExecution/main.go index b553388dc9b4..bd5220e86a67 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/DeleteExecution/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/DeleteExecution/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/DeleteInstance/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/DeleteInstance/main.go index b14dfa0c7c7f..afaecfd36939 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/DeleteInstance/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/DeleteInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/DeleteOperation/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/DeleteOperation/main.go index b48a4be818a8..fbf66f4823f9 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/DeleteOperation/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/DeleteSchedule/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/DeleteSchedule/main.go index 576eaab24001..d7889b836770 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/DeleteSchedule/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/DeleteSchedule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/DiagnoseInstance/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/DiagnoseInstance/main.go index d9caa4834a4f..30b22604ed46 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/DiagnoseInstance/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/DiagnoseInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetEnvironment/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetEnvironment/main.go index 8b849b52b373..d0b6abe2244d 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetEnvironment/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetExecution/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetExecution/main.go index 26734b063d48..fe409ef3bc8c 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetExecution/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetExecution/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetIamPolicy/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetIamPolicy/main.go index 41be0cdf66f7..9956094a08b1 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetInstance/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetInstance/main.go index 4390c6565b9c..773e9bb91c84 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetInstance/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetInstanceHealth/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetInstanceHealth/main.go index 0815fbaf3c14..2ba36707b77b 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetInstanceHealth/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetInstanceHealth/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetLocation/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetLocation/main.go index f04b431cbc8c..ad73ccc35aea 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetLocation/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetOperation/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetOperation/main.go index edeaa428e729..e7dbe152e663 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetOperation/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetSchedule/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetSchedule/main.go index 5b907b808940..7d444c886968 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetSchedule/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/GetSchedule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/IsInstanceUpgradeable/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/IsInstanceUpgradeable/main.go index 5b37d7512b5e..d7395de9f4e6 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/IsInstanceUpgradeable/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/IsInstanceUpgradeable/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/ListEnvironments/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/ListEnvironments/main.go index bc25508338fe..a08511c42588 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/ListEnvironments/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/ListEnvironments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/ListExecutions/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/ListExecutions/main.go index a3cde7131c8d..156692d95fff 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/ListExecutions/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/ListExecutions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/ListInstances/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/ListInstances/main.go index 169268406773..b5280058044d 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/ListInstances/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/ListInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/ListLocations/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/ListLocations/main.go index 7140de69836a..ec86b163460e 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/ListLocations/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/ListOperations/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/ListOperations/main.go index 0798aa82f582..5944f15f00d3 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/ListOperations/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/ListSchedules/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/ListSchedules/main.go index d30dd01f00b2..0c6667e9561a 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/ListSchedules/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/ListSchedules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/RegisterInstance/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/RegisterInstance/main.go index c546f0a28782..f1f42e8c0f94 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/RegisterInstance/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/RegisterInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/ReportInstanceInfo/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/ReportInstanceInfo/main.go index 8918022ab467..9420e20f606a 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/ReportInstanceInfo/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/ReportInstanceInfo/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/ResetInstance/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/ResetInstance/main.go index 572f73c964cb..602a467001bc 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/ResetInstance/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/ResetInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/RollbackInstance/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/RollbackInstance/main.go index d62eaa054563..9f9c02959c0a 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/RollbackInstance/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/RollbackInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/SetIamPolicy/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/SetIamPolicy/main.go index dc239158d004..04bedcbe61ca 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/SetInstanceAccelerator/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/SetInstanceAccelerator/main.go index f78cdff2e78d..f4a320870366 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/SetInstanceAccelerator/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/SetInstanceAccelerator/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/SetInstanceLabels/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/SetInstanceLabels/main.go index aeb23c0b01ec..22d36ef54c19 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/SetInstanceLabels/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/SetInstanceLabels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/SetInstanceMachineType/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/SetInstanceMachineType/main.go index 628c8ebc9839..d57f0b1ed9a0 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/SetInstanceMachineType/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/SetInstanceMachineType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/StartInstance/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/StartInstance/main.go index 1f658c63552c..634cefd7e33a 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/StartInstance/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/StartInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/StopInstance/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/StopInstance/main.go index 72dcf4ca2d2d..e4e5f64d14d0 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/StopInstance/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/StopInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/TestIamPermissions/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/TestIamPermissions/main.go index 66e4cb315f8d..302fd28cf13c 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/TriggerSchedule/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/TriggerSchedule/main.go index 78129d22935c..e6854e1fcee6 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/TriggerSchedule/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/TriggerSchedule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/UpdateInstanceConfig/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/UpdateInstanceConfig/main.go index 706f48f761ee..4bcfd8f2d8ec 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/UpdateInstanceConfig/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/UpdateInstanceConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/UpdateInstanceMetadataItems/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/UpdateInstanceMetadataItems/main.go index 83457a2fdb36..d84dad54f6aa 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/UpdateInstanceMetadataItems/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/UpdateInstanceMetadataItems/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/UpdateShieldedInstanceConfig/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/UpdateShieldedInstanceConfig/main.go index 201e5b9901bf..a6e8ff7fe97b 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/UpdateShieldedInstanceConfig/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/UpdateShieldedInstanceConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/UpgradeInstance/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/UpgradeInstance/main.go index 7009f261aa38..34e651fa9bc5 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/UpgradeInstance/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/UpgradeInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1/NotebookClient/UpgradeInstanceInternal/main.go b/internal/generated/snippets/notebooks/apiv1/NotebookClient/UpgradeInstanceInternal/main.go index 6ed10f2bff05..64b1368c65a6 100644 --- a/internal/generated/snippets/notebooks/apiv1/NotebookClient/UpgradeInstanceInternal/main.go +++ b/internal/generated/snippets/notebooks/apiv1/NotebookClient/UpgradeInstanceInternal/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/CancelOperation/main.go b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/CancelOperation/main.go index a675568fbfbc..62aac9070349 100644 --- a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/CancelOperation/main.go +++ b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/CreateEnvironment/main.go b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/CreateEnvironment/main.go index c4458ec15227..632e580404e7 100644 --- a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/CreateEnvironment/main.go +++ b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/CreateEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/CreateInstance/main.go b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/CreateInstance/main.go index e696af53bff5..9488b690c691 100644 --- a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/CreateInstance/main.go +++ b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/CreateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/DeleteEnvironment/main.go b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/DeleteEnvironment/main.go index de89a35bf7a0..a17567302122 100644 --- a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/DeleteEnvironment/main.go +++ b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/DeleteEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/DeleteInstance/main.go b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/DeleteInstance/main.go index 5aa2dee7f748..36f299864325 100644 --- a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/DeleteInstance/main.go +++ b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/DeleteInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/DeleteOperation/main.go b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/DeleteOperation/main.go index ea03dfa828ec..05aea05ee594 100644 --- a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/DeleteOperation/main.go +++ b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/GetEnvironment/main.go b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/GetEnvironment/main.go index f9689140d77e..ebbbcd0bc7a1 100644 --- a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/GetEnvironment/main.go +++ b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/GetEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/GetIamPolicy/main.go b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/GetIamPolicy/main.go index f37c5bf55006..89be15e68693 100644 --- a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/GetInstance/main.go b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/GetInstance/main.go index 00e660bb61cf..2976ee22f666 100644 --- a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/GetInstance/main.go +++ b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/GetInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/GetLocation/main.go b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/GetLocation/main.go index b857c641350d..5a90c4c397cf 100644 --- a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/GetLocation/main.go +++ b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/GetOperation/main.go b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/GetOperation/main.go index ff5c14e95416..3da5e15fc72c 100644 --- a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/GetOperation/main.go +++ b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/IsInstanceUpgradeable/main.go b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/IsInstanceUpgradeable/main.go index 8e2b8dcb521c..d8162a00006c 100644 --- a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/IsInstanceUpgradeable/main.go +++ b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/IsInstanceUpgradeable/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/ListEnvironments/main.go b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/ListEnvironments/main.go index 0ff77df2fc2d..815ac0f022fc 100644 --- a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/ListEnvironments/main.go +++ b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/ListEnvironments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/ListInstances/main.go b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/ListInstances/main.go index 4fefacecf12f..235f10ad0ec9 100644 --- a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/ListInstances/main.go +++ b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/ListInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/ListLocations/main.go b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/ListLocations/main.go index 919931dd19e8..9c64b2cb1334 100644 --- a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/ListLocations/main.go +++ b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/ListOperations/main.go b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/ListOperations/main.go index f67488a50f73..9dbeb522c8b5 100644 --- a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/ListOperations/main.go +++ b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/RegisterInstance/main.go b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/RegisterInstance/main.go index e20599c284a9..175e76367ab0 100644 --- a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/RegisterInstance/main.go +++ b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/RegisterInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/ReportInstanceInfo/main.go b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/ReportInstanceInfo/main.go index 7edecc8b6cde..349a36b3b5c2 100644 --- a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/ReportInstanceInfo/main.go +++ b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/ReportInstanceInfo/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/ResetInstance/main.go b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/ResetInstance/main.go index 14598b5d4b2b..053469bb5f65 100644 --- a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/ResetInstance/main.go +++ b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/ResetInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/SetIamPolicy/main.go b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/SetIamPolicy/main.go index 939f110818d9..6ecbbc385046 100644 --- a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/SetInstanceAccelerator/main.go b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/SetInstanceAccelerator/main.go index 4ff7d268d385..7a9b6ff835ca 100644 --- a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/SetInstanceAccelerator/main.go +++ b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/SetInstanceAccelerator/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/SetInstanceLabels/main.go b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/SetInstanceLabels/main.go index 50e905f61d7b..a643834e63fd 100644 --- a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/SetInstanceLabels/main.go +++ b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/SetInstanceLabels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/SetInstanceMachineType/main.go b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/SetInstanceMachineType/main.go index c99730148ac8..fb1f2c959517 100644 --- a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/SetInstanceMachineType/main.go +++ b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/SetInstanceMachineType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/StartInstance/main.go b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/StartInstance/main.go index 0ef2d81c9343..5d74ec366011 100644 --- a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/StartInstance/main.go +++ b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/StartInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/StopInstance/main.go b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/StopInstance/main.go index 838cbf4c7556..aa43bdf5f3b0 100644 --- a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/StopInstance/main.go +++ b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/StopInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/TestIamPermissions/main.go b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/TestIamPermissions/main.go index 89fc77a90a8a..561577b86ce1 100644 --- a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/UpgradeInstance/main.go b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/UpgradeInstance/main.go index 2227ed4a285d..a42f8f29d055 100644 --- a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/UpgradeInstance/main.go +++ b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/UpgradeInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/UpgradeInstanceInternal/main.go b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/UpgradeInstanceInternal/main.go index 707180745c49..1779ad936db7 100644 --- a/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/UpgradeInstanceInternal/main.go +++ b/internal/generated/snippets/notebooks/apiv1beta1/NotebookClient/UpgradeInstanceInternal/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv2/NotebookClient/CancelOperation/main.go b/internal/generated/snippets/notebooks/apiv2/NotebookClient/CancelOperation/main.go index b5dc8d7fcb5a..fa70a0db7131 100644 --- a/internal/generated/snippets/notebooks/apiv2/NotebookClient/CancelOperation/main.go +++ b/internal/generated/snippets/notebooks/apiv2/NotebookClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv2/NotebookClient/CheckInstanceUpgradability/main.go b/internal/generated/snippets/notebooks/apiv2/NotebookClient/CheckInstanceUpgradability/main.go index f94f14231b89..b1a03d3fa183 100644 --- a/internal/generated/snippets/notebooks/apiv2/NotebookClient/CheckInstanceUpgradability/main.go +++ b/internal/generated/snippets/notebooks/apiv2/NotebookClient/CheckInstanceUpgradability/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv2/NotebookClient/CreateInstance/main.go b/internal/generated/snippets/notebooks/apiv2/NotebookClient/CreateInstance/main.go index ffcc8af45051..d37148df99ca 100644 --- a/internal/generated/snippets/notebooks/apiv2/NotebookClient/CreateInstance/main.go +++ b/internal/generated/snippets/notebooks/apiv2/NotebookClient/CreateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv2/NotebookClient/DeleteInstance/main.go b/internal/generated/snippets/notebooks/apiv2/NotebookClient/DeleteInstance/main.go index 9132667f60c0..371edf22dc85 100644 --- a/internal/generated/snippets/notebooks/apiv2/NotebookClient/DeleteInstance/main.go +++ b/internal/generated/snippets/notebooks/apiv2/NotebookClient/DeleteInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv2/NotebookClient/DeleteOperation/main.go b/internal/generated/snippets/notebooks/apiv2/NotebookClient/DeleteOperation/main.go index ffd119f348eb..3f8496a8d0cf 100644 --- a/internal/generated/snippets/notebooks/apiv2/NotebookClient/DeleteOperation/main.go +++ b/internal/generated/snippets/notebooks/apiv2/NotebookClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv2/NotebookClient/DiagnoseInstance/main.go b/internal/generated/snippets/notebooks/apiv2/NotebookClient/DiagnoseInstance/main.go index c6dd10e12f8d..0bccf7f9c031 100644 --- a/internal/generated/snippets/notebooks/apiv2/NotebookClient/DiagnoseInstance/main.go +++ b/internal/generated/snippets/notebooks/apiv2/NotebookClient/DiagnoseInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv2/NotebookClient/GetIamPolicy/main.go b/internal/generated/snippets/notebooks/apiv2/NotebookClient/GetIamPolicy/main.go index 3b8ef95fd2fa..b3e79f5e60a9 100644 --- a/internal/generated/snippets/notebooks/apiv2/NotebookClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/notebooks/apiv2/NotebookClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv2/NotebookClient/GetInstance/main.go b/internal/generated/snippets/notebooks/apiv2/NotebookClient/GetInstance/main.go index d0619c329afb..6bfb1791b164 100644 --- a/internal/generated/snippets/notebooks/apiv2/NotebookClient/GetInstance/main.go +++ b/internal/generated/snippets/notebooks/apiv2/NotebookClient/GetInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv2/NotebookClient/GetLocation/main.go b/internal/generated/snippets/notebooks/apiv2/NotebookClient/GetLocation/main.go index 6a3a52d81f99..35bc18333784 100644 --- a/internal/generated/snippets/notebooks/apiv2/NotebookClient/GetLocation/main.go +++ b/internal/generated/snippets/notebooks/apiv2/NotebookClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv2/NotebookClient/GetOperation/main.go b/internal/generated/snippets/notebooks/apiv2/NotebookClient/GetOperation/main.go index 3712b3efd81c..7c401a449045 100644 --- a/internal/generated/snippets/notebooks/apiv2/NotebookClient/GetOperation/main.go +++ b/internal/generated/snippets/notebooks/apiv2/NotebookClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv2/NotebookClient/ListInstances/main.go b/internal/generated/snippets/notebooks/apiv2/NotebookClient/ListInstances/main.go index 62c59efd8436..60702f907350 100644 --- a/internal/generated/snippets/notebooks/apiv2/NotebookClient/ListInstances/main.go +++ b/internal/generated/snippets/notebooks/apiv2/NotebookClient/ListInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv2/NotebookClient/ListLocations/main.go b/internal/generated/snippets/notebooks/apiv2/NotebookClient/ListLocations/main.go index 48d245514a87..201833642687 100644 --- a/internal/generated/snippets/notebooks/apiv2/NotebookClient/ListLocations/main.go +++ b/internal/generated/snippets/notebooks/apiv2/NotebookClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv2/NotebookClient/ListOperations/main.go b/internal/generated/snippets/notebooks/apiv2/NotebookClient/ListOperations/main.go index 28cc4f3327b1..bb78445d1046 100644 --- a/internal/generated/snippets/notebooks/apiv2/NotebookClient/ListOperations/main.go +++ b/internal/generated/snippets/notebooks/apiv2/NotebookClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv2/NotebookClient/ResetInstance/main.go b/internal/generated/snippets/notebooks/apiv2/NotebookClient/ResetInstance/main.go index 18bc574a75af..3dcbbfa39ee9 100644 --- a/internal/generated/snippets/notebooks/apiv2/NotebookClient/ResetInstance/main.go +++ b/internal/generated/snippets/notebooks/apiv2/NotebookClient/ResetInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv2/NotebookClient/RollbackInstance/main.go b/internal/generated/snippets/notebooks/apiv2/NotebookClient/RollbackInstance/main.go index 1c45b625de8d..0718e2219184 100644 --- a/internal/generated/snippets/notebooks/apiv2/NotebookClient/RollbackInstance/main.go +++ b/internal/generated/snippets/notebooks/apiv2/NotebookClient/RollbackInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv2/NotebookClient/SetIamPolicy/main.go b/internal/generated/snippets/notebooks/apiv2/NotebookClient/SetIamPolicy/main.go index bea264baafd5..8eb2198d7f0a 100644 --- a/internal/generated/snippets/notebooks/apiv2/NotebookClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/notebooks/apiv2/NotebookClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv2/NotebookClient/StartInstance/main.go b/internal/generated/snippets/notebooks/apiv2/NotebookClient/StartInstance/main.go index 07bf50190ca9..23020e4e825b 100644 --- a/internal/generated/snippets/notebooks/apiv2/NotebookClient/StartInstance/main.go +++ b/internal/generated/snippets/notebooks/apiv2/NotebookClient/StartInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv2/NotebookClient/StopInstance/main.go b/internal/generated/snippets/notebooks/apiv2/NotebookClient/StopInstance/main.go index a4e793952587..4d66f602128d 100644 --- a/internal/generated/snippets/notebooks/apiv2/NotebookClient/StopInstance/main.go +++ b/internal/generated/snippets/notebooks/apiv2/NotebookClient/StopInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv2/NotebookClient/TestIamPermissions/main.go b/internal/generated/snippets/notebooks/apiv2/NotebookClient/TestIamPermissions/main.go index c879212f6880..b6e133bcd490 100644 --- a/internal/generated/snippets/notebooks/apiv2/NotebookClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/notebooks/apiv2/NotebookClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv2/NotebookClient/UpdateInstance/main.go b/internal/generated/snippets/notebooks/apiv2/NotebookClient/UpdateInstance/main.go index 3f83f6e74192..f9005d89d4af 100644 --- a/internal/generated/snippets/notebooks/apiv2/NotebookClient/UpdateInstance/main.go +++ b/internal/generated/snippets/notebooks/apiv2/NotebookClient/UpdateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/notebooks/apiv2/NotebookClient/UpgradeInstance/main.go b/internal/generated/snippets/notebooks/apiv2/NotebookClient/UpgradeInstance/main.go index 11ee3d17a32d..7e94acb00dc7 100644 --- a/internal/generated/snippets/notebooks/apiv2/NotebookClient/UpgradeInstance/main.go +++ b/internal/generated/snippets/notebooks/apiv2/NotebookClient/UpgradeInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/optimization/apiv1/FleetRoutingClient/BatchOptimizeTours/main.go b/internal/generated/snippets/optimization/apiv1/FleetRoutingClient/BatchOptimizeTours/main.go index aacbe3408a1a..ea39037f2c1d 100644 --- a/internal/generated/snippets/optimization/apiv1/FleetRoutingClient/BatchOptimizeTours/main.go +++ b/internal/generated/snippets/optimization/apiv1/FleetRoutingClient/BatchOptimizeTours/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/optimization/apiv1/FleetRoutingClient/GetOperation/main.go b/internal/generated/snippets/optimization/apiv1/FleetRoutingClient/GetOperation/main.go index dce777dfe41d..a61e815247e2 100644 --- a/internal/generated/snippets/optimization/apiv1/FleetRoutingClient/GetOperation/main.go +++ b/internal/generated/snippets/optimization/apiv1/FleetRoutingClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/optimization/apiv1/FleetRoutingClient/OptimizeTours/main.go b/internal/generated/snippets/optimization/apiv1/FleetRoutingClient/OptimizeTours/main.go index 2210201669ee..c731e0973887 100644 --- a/internal/generated/snippets/optimization/apiv1/FleetRoutingClient/OptimizeTours/main.go +++ b/internal/generated/snippets/optimization/apiv1/FleetRoutingClient/OptimizeTours/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/oracledatabase/apiv1/Client/CancelOperation/main.go index 09a27748be8f..f24cc25b7077 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/oracledatabase/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/Client/CreateAutonomousDatabase/main.go b/internal/generated/snippets/oracledatabase/apiv1/Client/CreateAutonomousDatabase/main.go index 08e1818549c9..0ea03326ee11 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/Client/CreateAutonomousDatabase/main.go +++ b/internal/generated/snippets/oracledatabase/apiv1/Client/CreateAutonomousDatabase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/Client/CreateCloudExadataInfrastructure/main.go b/internal/generated/snippets/oracledatabase/apiv1/Client/CreateCloudExadataInfrastructure/main.go index eaeba1e33cda..19a80cf3fe96 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/Client/CreateCloudExadataInfrastructure/main.go +++ b/internal/generated/snippets/oracledatabase/apiv1/Client/CreateCloudExadataInfrastructure/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/Client/CreateCloudVmCluster/main.go b/internal/generated/snippets/oracledatabase/apiv1/Client/CreateCloudVmCluster/main.go index 2d02bd25c4b4..952d4f8a1efe 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/Client/CreateCloudVmCluster/main.go +++ b/internal/generated/snippets/oracledatabase/apiv1/Client/CreateCloudVmCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/Client/DeleteAutonomousDatabase/main.go b/internal/generated/snippets/oracledatabase/apiv1/Client/DeleteAutonomousDatabase/main.go index b899e5db5b16..848bd83d4d03 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/Client/DeleteAutonomousDatabase/main.go +++ b/internal/generated/snippets/oracledatabase/apiv1/Client/DeleteAutonomousDatabase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/Client/DeleteCloudExadataInfrastructure/main.go b/internal/generated/snippets/oracledatabase/apiv1/Client/DeleteCloudExadataInfrastructure/main.go index 3f03814bbe10..9d10d67a65f6 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/Client/DeleteCloudExadataInfrastructure/main.go +++ b/internal/generated/snippets/oracledatabase/apiv1/Client/DeleteCloudExadataInfrastructure/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/Client/DeleteCloudVmCluster/main.go b/internal/generated/snippets/oracledatabase/apiv1/Client/DeleteCloudVmCluster/main.go index 63ad7615b3d4..2882b598b90e 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/Client/DeleteCloudVmCluster/main.go +++ b/internal/generated/snippets/oracledatabase/apiv1/Client/DeleteCloudVmCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/oracledatabase/apiv1/Client/DeleteOperation/main.go index 73cabbc3b238..be8e95be0645 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/oracledatabase/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/Client/GenerateAutonomousDatabaseWallet/main.go b/internal/generated/snippets/oracledatabase/apiv1/Client/GenerateAutonomousDatabaseWallet/main.go index 8f71f8d0b920..d6a3524fb87c 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/Client/GenerateAutonomousDatabaseWallet/main.go +++ b/internal/generated/snippets/oracledatabase/apiv1/Client/GenerateAutonomousDatabaseWallet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/Client/GetAutonomousDatabase/main.go b/internal/generated/snippets/oracledatabase/apiv1/Client/GetAutonomousDatabase/main.go index dfac318e974c..26b278be2397 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/Client/GetAutonomousDatabase/main.go +++ b/internal/generated/snippets/oracledatabase/apiv1/Client/GetAutonomousDatabase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/Client/GetCloudExadataInfrastructure/main.go b/internal/generated/snippets/oracledatabase/apiv1/Client/GetCloudExadataInfrastructure/main.go index 752559b5ef20..4f0693ae49ae 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/Client/GetCloudExadataInfrastructure/main.go +++ b/internal/generated/snippets/oracledatabase/apiv1/Client/GetCloudExadataInfrastructure/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/Client/GetCloudVmCluster/main.go b/internal/generated/snippets/oracledatabase/apiv1/Client/GetCloudVmCluster/main.go index dae6bc8541ff..a9858c0f3f5d 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/Client/GetCloudVmCluster/main.go +++ b/internal/generated/snippets/oracledatabase/apiv1/Client/GetCloudVmCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/oracledatabase/apiv1/Client/GetLocation/main.go index 8bcfad1c121b..64fd275de1b1 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/oracledatabase/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/oracledatabase/apiv1/Client/GetOperation/main.go index b9978dba8783..6f7779f5a710 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/oracledatabase/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/Client/ListAutonomousDatabaseBackups/main.go b/internal/generated/snippets/oracledatabase/apiv1/Client/ListAutonomousDatabaseBackups/main.go index 009488a50cd7..3b46fec4de8d 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/Client/ListAutonomousDatabaseBackups/main.go +++ b/internal/generated/snippets/oracledatabase/apiv1/Client/ListAutonomousDatabaseBackups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/Client/ListAutonomousDatabaseCharacterSets/main.go b/internal/generated/snippets/oracledatabase/apiv1/Client/ListAutonomousDatabaseCharacterSets/main.go index f9633b9afe9f..f154c199c179 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/Client/ListAutonomousDatabaseCharacterSets/main.go +++ b/internal/generated/snippets/oracledatabase/apiv1/Client/ListAutonomousDatabaseCharacterSets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/Client/ListAutonomousDatabases/main.go b/internal/generated/snippets/oracledatabase/apiv1/Client/ListAutonomousDatabases/main.go index 425f3492e90f..8c7a4d1ca839 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/Client/ListAutonomousDatabases/main.go +++ b/internal/generated/snippets/oracledatabase/apiv1/Client/ListAutonomousDatabases/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/Client/ListAutonomousDbVersions/main.go b/internal/generated/snippets/oracledatabase/apiv1/Client/ListAutonomousDbVersions/main.go index c0a50d779ed1..edb9ff2e08bd 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/Client/ListAutonomousDbVersions/main.go +++ b/internal/generated/snippets/oracledatabase/apiv1/Client/ListAutonomousDbVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/Client/ListCloudExadataInfrastructures/main.go b/internal/generated/snippets/oracledatabase/apiv1/Client/ListCloudExadataInfrastructures/main.go index 8cc2ab3f4fa2..3db7b445645e 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/Client/ListCloudExadataInfrastructures/main.go +++ b/internal/generated/snippets/oracledatabase/apiv1/Client/ListCloudExadataInfrastructures/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/Client/ListCloudVmClusters/main.go b/internal/generated/snippets/oracledatabase/apiv1/Client/ListCloudVmClusters/main.go index 1bf9f213cd89..7d69bdba8e6d 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/Client/ListCloudVmClusters/main.go +++ b/internal/generated/snippets/oracledatabase/apiv1/Client/ListCloudVmClusters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/Client/ListDbNodes/main.go b/internal/generated/snippets/oracledatabase/apiv1/Client/ListDbNodes/main.go index 72496a6f4e77..532ba97993a5 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/Client/ListDbNodes/main.go +++ b/internal/generated/snippets/oracledatabase/apiv1/Client/ListDbNodes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/Client/ListDbServers/main.go b/internal/generated/snippets/oracledatabase/apiv1/Client/ListDbServers/main.go index 47287acbd1ee..95a239f52ac1 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/Client/ListDbServers/main.go +++ b/internal/generated/snippets/oracledatabase/apiv1/Client/ListDbServers/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/Client/ListDbSystemShapes/main.go b/internal/generated/snippets/oracledatabase/apiv1/Client/ListDbSystemShapes/main.go index efa19acb73c5..8403519cbb08 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/Client/ListDbSystemShapes/main.go +++ b/internal/generated/snippets/oracledatabase/apiv1/Client/ListDbSystemShapes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/Client/ListEntitlements/main.go b/internal/generated/snippets/oracledatabase/apiv1/Client/ListEntitlements/main.go index 74ad74e2124f..c849fc7cad32 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/Client/ListEntitlements/main.go +++ b/internal/generated/snippets/oracledatabase/apiv1/Client/ListEntitlements/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/Client/ListGiVersions/main.go b/internal/generated/snippets/oracledatabase/apiv1/Client/ListGiVersions/main.go index 90fc7371021e..d930063185c1 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/Client/ListGiVersions/main.go +++ b/internal/generated/snippets/oracledatabase/apiv1/Client/ListGiVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/oracledatabase/apiv1/Client/ListLocations/main.go index dcba9c6063e3..e3a81667e751 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/oracledatabase/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/oracledatabase/apiv1/Client/ListOperations/main.go index 9aa3e1798f47..43de40b1f128 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/oracledatabase/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/Client/RestoreAutonomousDatabase/main.go b/internal/generated/snippets/oracledatabase/apiv1/Client/RestoreAutonomousDatabase/main.go index 05fc7c578413..4f392b73b582 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/Client/RestoreAutonomousDatabase/main.go +++ b/internal/generated/snippets/oracledatabase/apiv1/Client/RestoreAutonomousDatabase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oracledatabase/apiv1/snippet_metadata.google.cloud.oracledatabase.v1.json b/internal/generated/snippets/oracledatabase/apiv1/snippet_metadata.google.cloud.oracledatabase.v1.json index 7123f2a79586..d46df32bfdd3 100644 --- a/internal/generated/snippets/oracledatabase/apiv1/snippet_metadata.google.cloud.oracledatabase.v1.json +++ b/internal/generated/snippets/oracledatabase/apiv1/snippet_metadata.google.cloud.oracledatabase.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/oracledatabase/apiv1", - "version": "0.1.2", + "version": "0.1.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/CheckUpgrade/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/CheckUpgrade/main.go index b54eda11005d..5d48fbcd59e2 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/CheckUpgrade/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/CheckUpgrade/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/CreateEnvironment/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/CreateEnvironment/main.go index 982c9659f114..2a1587352218 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/CreateEnvironment/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/CreateEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/CreateUserWorkloadsConfigMap/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/CreateUserWorkloadsConfigMap/main.go index c945b66d92e8..c4fe4c415ac9 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/CreateUserWorkloadsConfigMap/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/CreateUserWorkloadsConfigMap/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/CreateUserWorkloadsSecret/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/CreateUserWorkloadsSecret/main.go index 57c4a7f6b07c..e2918c0e40cc 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/CreateUserWorkloadsSecret/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/CreateUserWorkloadsSecret/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/DatabaseFailover/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/DatabaseFailover/main.go index 0636b81477cf..876a4b85009a 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/DatabaseFailover/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/DatabaseFailover/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/DeleteEnvironment/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/DeleteEnvironment/main.go index f4b4dde2d26d..e2d66693cee5 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/DeleteEnvironment/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/DeleteEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/DeleteOperation/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/DeleteOperation/main.go index 3d19091dc9d0..daa4bb4034ca 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/DeleteOperation/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/DeleteUserWorkloadsConfigMap/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/DeleteUserWorkloadsConfigMap/main.go index 0c11c164c141..54fa113b4001 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/DeleteUserWorkloadsConfigMap/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/DeleteUserWorkloadsConfigMap/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/DeleteUserWorkloadsSecret/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/DeleteUserWorkloadsSecret/main.go index 1680613912b3..7fc97e31bcb2 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/DeleteUserWorkloadsSecret/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/DeleteUserWorkloadsSecret/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/ExecuteAirflowCommand/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/ExecuteAirflowCommand/main.go index 0559b65109fe..bacdfbd5ddec 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/ExecuteAirflowCommand/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/ExecuteAirflowCommand/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/FetchDatabaseProperties/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/FetchDatabaseProperties/main.go index 3566a322bd22..3e0a1127d482 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/FetchDatabaseProperties/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/FetchDatabaseProperties/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/GetEnvironment/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/GetEnvironment/main.go index daf810570b18..19a6da52c320 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/GetEnvironment/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/GetEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/GetOperation/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/GetOperation/main.go index 425b44451e55..d5d2abeee74b 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/GetOperation/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/GetUserWorkloadsConfigMap/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/GetUserWorkloadsConfigMap/main.go index 732c780bbe5c..4c6da9b71b5b 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/GetUserWorkloadsConfigMap/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/GetUserWorkloadsConfigMap/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/GetUserWorkloadsSecret/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/GetUserWorkloadsSecret/main.go index 7e9074d067d4..e52f2af8a082 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/GetUserWorkloadsSecret/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/GetUserWorkloadsSecret/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/ListEnvironments/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/ListEnvironments/main.go index fb5c5897e980..8daa1208ea8b 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/ListEnvironments/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/ListEnvironments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/ListOperations/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/ListOperations/main.go index a816feccdcd1..dae50726074e 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/ListOperations/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/ListUserWorkloadsConfigMaps/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/ListUserWorkloadsConfigMaps/main.go index 5273005ce9bd..bad416889eac 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/ListUserWorkloadsConfigMaps/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/ListUserWorkloadsConfigMaps/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/ListUserWorkloadsSecrets/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/ListUserWorkloadsSecrets/main.go index dd3008bd499c..ff555c932251 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/ListUserWorkloadsSecrets/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/ListUserWorkloadsSecrets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/ListWorkloads/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/ListWorkloads/main.go index 2d8cc01f8cc3..55dd99bb3bc8 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/ListWorkloads/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/ListWorkloads/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/LoadSnapshot/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/LoadSnapshot/main.go index 80b8ec4675c3..fcd706ff6a84 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/LoadSnapshot/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/LoadSnapshot/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/PollAirflowCommand/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/PollAirflowCommand/main.go index cb4df7a72372..54d205288a22 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/PollAirflowCommand/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/PollAirflowCommand/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/SaveSnapshot/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/SaveSnapshot/main.go index e0e65e48cef8..c2115d9e2b0a 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/SaveSnapshot/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/SaveSnapshot/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/StopAirflowCommand/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/StopAirflowCommand/main.go index 050cceb8a487..c4149388bd45 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/StopAirflowCommand/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/StopAirflowCommand/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/UpdateEnvironment/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/UpdateEnvironment/main.go index cfe111464330..f61e414064ff 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/UpdateEnvironment/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/UpdateEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/UpdateUserWorkloadsConfigMap/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/UpdateUserWorkloadsConfigMap/main.go index 35210bce5d34..bd47a362df1d 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/UpdateUserWorkloadsConfigMap/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/UpdateUserWorkloadsConfigMap/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/UpdateUserWorkloadsSecret/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/UpdateUserWorkloadsSecret/main.go index 1409ac9a8d21..14ec67fd24e8 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/UpdateUserWorkloadsSecret/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/EnvironmentsClient/UpdateUserWorkloadsSecret/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/ImageVersionsClient/DeleteOperation/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/ImageVersionsClient/DeleteOperation/main.go index 7169ec716d49..232ea682455d 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/ImageVersionsClient/DeleteOperation/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/ImageVersionsClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/ImageVersionsClient/GetOperation/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/ImageVersionsClient/GetOperation/main.go index bb8c90affcc3..1674a9b17b29 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/ImageVersionsClient/GetOperation/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/ImageVersionsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/ImageVersionsClient/ListImageVersions/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/ImageVersionsClient/ListImageVersions/main.go index 71a64a548454..712ac385fd4e 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/ImageVersionsClient/ListImageVersions/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/ImageVersionsClient/ListImageVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/ImageVersionsClient/ListOperations/main.go b/internal/generated/snippets/orchestration/airflow/service/apiv1/ImageVersionsClient/ListOperations/main.go index 492c5f1c5a32..209740fa1526 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/ImageVersionsClient/ListOperations/main.go +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/ImageVersionsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orchestration/airflow/service/apiv1/snippet_metadata.google.cloud.orchestration.airflow.service.v1.json b/internal/generated/snippets/orchestration/airflow/service/apiv1/snippet_metadata.google.cloud.orchestration.airflow.service.v1.json index c4cce4778745..601d785843af 100644 --- a/internal/generated/snippets/orchestration/airflow/service/apiv1/snippet_metadata.google.cloud.orchestration.airflow.service.v1.json +++ b/internal/generated/snippets/orchestration/airflow/service/apiv1/snippet_metadata.google.cloud.orchestration.airflow.service.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/orchestration/airflow/service/apiv1", - "version": "1.11.2", + "version": "1.11.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/orgpolicy/apiv2/Client/CreateCustomConstraint/main.go b/internal/generated/snippets/orgpolicy/apiv2/Client/CreateCustomConstraint/main.go index 8f9b68da9ac5..127083273a0f 100644 --- a/internal/generated/snippets/orgpolicy/apiv2/Client/CreateCustomConstraint/main.go +++ b/internal/generated/snippets/orgpolicy/apiv2/Client/CreateCustomConstraint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orgpolicy/apiv2/Client/CreatePolicy/main.go b/internal/generated/snippets/orgpolicy/apiv2/Client/CreatePolicy/main.go index 7d134e710b02..d3ce3b4d262c 100644 --- a/internal/generated/snippets/orgpolicy/apiv2/Client/CreatePolicy/main.go +++ b/internal/generated/snippets/orgpolicy/apiv2/Client/CreatePolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orgpolicy/apiv2/Client/DeleteCustomConstraint/main.go b/internal/generated/snippets/orgpolicy/apiv2/Client/DeleteCustomConstraint/main.go index f9fec3ddf0b2..dfe4e74f732b 100644 --- a/internal/generated/snippets/orgpolicy/apiv2/Client/DeleteCustomConstraint/main.go +++ b/internal/generated/snippets/orgpolicy/apiv2/Client/DeleteCustomConstraint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orgpolicy/apiv2/Client/DeletePolicy/main.go b/internal/generated/snippets/orgpolicy/apiv2/Client/DeletePolicy/main.go index 669bc5457c9b..abbade217923 100644 --- a/internal/generated/snippets/orgpolicy/apiv2/Client/DeletePolicy/main.go +++ b/internal/generated/snippets/orgpolicy/apiv2/Client/DeletePolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orgpolicy/apiv2/Client/GetCustomConstraint/main.go b/internal/generated/snippets/orgpolicy/apiv2/Client/GetCustomConstraint/main.go index 982eb53e8e76..5c67af53ada9 100644 --- a/internal/generated/snippets/orgpolicy/apiv2/Client/GetCustomConstraint/main.go +++ b/internal/generated/snippets/orgpolicy/apiv2/Client/GetCustomConstraint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orgpolicy/apiv2/Client/GetEffectivePolicy/main.go b/internal/generated/snippets/orgpolicy/apiv2/Client/GetEffectivePolicy/main.go index 42cfe1b343a8..36b540017de2 100644 --- a/internal/generated/snippets/orgpolicy/apiv2/Client/GetEffectivePolicy/main.go +++ b/internal/generated/snippets/orgpolicy/apiv2/Client/GetEffectivePolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orgpolicy/apiv2/Client/GetPolicy/main.go b/internal/generated/snippets/orgpolicy/apiv2/Client/GetPolicy/main.go index 2e1089644358..a67a27fe9e9f 100644 --- a/internal/generated/snippets/orgpolicy/apiv2/Client/GetPolicy/main.go +++ b/internal/generated/snippets/orgpolicy/apiv2/Client/GetPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orgpolicy/apiv2/Client/ListConstraints/main.go b/internal/generated/snippets/orgpolicy/apiv2/Client/ListConstraints/main.go index 32f5fef8af2d..16cb1ea9084b 100644 --- a/internal/generated/snippets/orgpolicy/apiv2/Client/ListConstraints/main.go +++ b/internal/generated/snippets/orgpolicy/apiv2/Client/ListConstraints/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orgpolicy/apiv2/Client/ListCustomConstraints/main.go b/internal/generated/snippets/orgpolicy/apiv2/Client/ListCustomConstraints/main.go index a26f7ade1eea..2f42fad62e92 100644 --- a/internal/generated/snippets/orgpolicy/apiv2/Client/ListCustomConstraints/main.go +++ b/internal/generated/snippets/orgpolicy/apiv2/Client/ListCustomConstraints/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orgpolicy/apiv2/Client/ListPolicies/main.go b/internal/generated/snippets/orgpolicy/apiv2/Client/ListPolicies/main.go index 63da7a51ec8a..9d88f451d932 100644 --- a/internal/generated/snippets/orgpolicy/apiv2/Client/ListPolicies/main.go +++ b/internal/generated/snippets/orgpolicy/apiv2/Client/ListPolicies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orgpolicy/apiv2/Client/UpdateCustomConstraint/main.go b/internal/generated/snippets/orgpolicy/apiv2/Client/UpdateCustomConstraint/main.go index 946ad61a9f40..83a3c9f13024 100644 --- a/internal/generated/snippets/orgpolicy/apiv2/Client/UpdateCustomConstraint/main.go +++ b/internal/generated/snippets/orgpolicy/apiv2/Client/UpdateCustomConstraint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orgpolicy/apiv2/Client/UpdatePolicy/main.go b/internal/generated/snippets/orgpolicy/apiv2/Client/UpdatePolicy/main.go index d84cf9a37e46..5450412cb738 100644 --- a/internal/generated/snippets/orgpolicy/apiv2/Client/UpdatePolicy/main.go +++ b/internal/generated/snippets/orgpolicy/apiv2/Client/UpdatePolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/orgpolicy/apiv2/snippet_metadata.google.cloud.orgpolicy.v2.json b/internal/generated/snippets/orgpolicy/apiv2/snippet_metadata.google.cloud.orgpolicy.v2.json index a0b4d584a579..4c13dd7c23b2 100644 --- a/internal/generated/snippets/orgpolicy/apiv2/snippet_metadata.google.cloud.orgpolicy.v2.json +++ b/internal/generated/snippets/orgpolicy/apiv2/snippet_metadata.google.cloud.orgpolicy.v2.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/orgpolicy/apiv2", - "version": "1.14.1", + "version": "1.14.2", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/osconfig/agentendpoint/apiv1/Client/RegisterAgent/main.go b/internal/generated/snippets/osconfig/agentendpoint/apiv1/Client/RegisterAgent/main.go index 8fe0b53a1557..e9a0e0dcce2e 100644 --- a/internal/generated/snippets/osconfig/agentendpoint/apiv1/Client/RegisterAgent/main.go +++ b/internal/generated/snippets/osconfig/agentendpoint/apiv1/Client/RegisterAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/agentendpoint/apiv1/Client/ReportInventory/main.go b/internal/generated/snippets/osconfig/agentendpoint/apiv1/Client/ReportInventory/main.go index 7357575f47c2..8f51d30a2ec9 100644 --- a/internal/generated/snippets/osconfig/agentendpoint/apiv1/Client/ReportInventory/main.go +++ b/internal/generated/snippets/osconfig/agentendpoint/apiv1/Client/ReportInventory/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/agentendpoint/apiv1/Client/ReportTaskComplete/main.go b/internal/generated/snippets/osconfig/agentendpoint/apiv1/Client/ReportTaskComplete/main.go index c7c9fe1ff2ad..8111d3bbad9e 100644 --- a/internal/generated/snippets/osconfig/agentendpoint/apiv1/Client/ReportTaskComplete/main.go +++ b/internal/generated/snippets/osconfig/agentendpoint/apiv1/Client/ReportTaskComplete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/agentendpoint/apiv1/Client/ReportTaskProgress/main.go b/internal/generated/snippets/osconfig/agentendpoint/apiv1/Client/ReportTaskProgress/main.go index 2a855d9d1c7a..b27f64741d02 100644 --- a/internal/generated/snippets/osconfig/agentendpoint/apiv1/Client/ReportTaskProgress/main.go +++ b/internal/generated/snippets/osconfig/agentendpoint/apiv1/Client/ReportTaskProgress/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/agentendpoint/apiv1/Client/StartNextTask/main.go b/internal/generated/snippets/osconfig/agentendpoint/apiv1/Client/StartNextTask/main.go index c90e939ae6e7..00e1cf43e40e 100644 --- a/internal/generated/snippets/osconfig/agentendpoint/apiv1/Client/StartNextTask/main.go +++ b/internal/generated/snippets/osconfig/agentendpoint/apiv1/Client/StartNextTask/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/agentendpoint/apiv1/snippet_metadata.google.cloud.osconfig.agentendpoint.v1.json b/internal/generated/snippets/osconfig/agentendpoint/apiv1/snippet_metadata.google.cloud.osconfig.agentendpoint.v1.json index e3948eeb4dc8..acf070aabc0e 100644 --- a/internal/generated/snippets/osconfig/agentendpoint/apiv1/snippet_metadata.google.cloud.osconfig.agentendpoint.v1.json +++ b/internal/generated/snippets/osconfig/agentendpoint/apiv1/snippet_metadata.google.cloud.osconfig.agentendpoint.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/osconfig/agentendpoint/apiv1", - "version": "1.14.2", + "version": "1.14.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/osconfig/agentendpoint/apiv1beta/Client/LookupEffectiveGuestPolicy/main.go b/internal/generated/snippets/osconfig/agentendpoint/apiv1beta/Client/LookupEffectiveGuestPolicy/main.go index 848245f003a0..9442b43d3f67 100644 --- a/internal/generated/snippets/osconfig/agentendpoint/apiv1beta/Client/LookupEffectiveGuestPolicy/main.go +++ b/internal/generated/snippets/osconfig/agentendpoint/apiv1beta/Client/LookupEffectiveGuestPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/agentendpoint/apiv1beta/Client/RegisterAgent/main.go b/internal/generated/snippets/osconfig/agentendpoint/apiv1beta/Client/RegisterAgent/main.go index 1710cafd78ad..d4dfdfb4c0a1 100644 --- a/internal/generated/snippets/osconfig/agentendpoint/apiv1beta/Client/RegisterAgent/main.go +++ b/internal/generated/snippets/osconfig/agentendpoint/apiv1beta/Client/RegisterAgent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/agentendpoint/apiv1beta/Client/ReportTaskComplete/main.go b/internal/generated/snippets/osconfig/agentendpoint/apiv1beta/Client/ReportTaskComplete/main.go index 353e5e2cecff..bbc3afc924f4 100644 --- a/internal/generated/snippets/osconfig/agentendpoint/apiv1beta/Client/ReportTaskComplete/main.go +++ b/internal/generated/snippets/osconfig/agentendpoint/apiv1beta/Client/ReportTaskComplete/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/agentendpoint/apiv1beta/Client/ReportTaskProgress/main.go b/internal/generated/snippets/osconfig/agentendpoint/apiv1beta/Client/ReportTaskProgress/main.go index 3fe2d36c3e9e..c2bece2bb935 100644 --- a/internal/generated/snippets/osconfig/agentendpoint/apiv1beta/Client/ReportTaskProgress/main.go +++ b/internal/generated/snippets/osconfig/agentendpoint/apiv1beta/Client/ReportTaskProgress/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/agentendpoint/apiv1beta/Client/StartNextTask/main.go b/internal/generated/snippets/osconfig/agentendpoint/apiv1beta/Client/StartNextTask/main.go index a0bb18291e3a..791b250c168c 100644 --- a/internal/generated/snippets/osconfig/agentendpoint/apiv1beta/Client/StartNextTask/main.go +++ b/internal/generated/snippets/osconfig/agentendpoint/apiv1beta/Client/StartNextTask/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/agentendpoint/apiv1beta/snippet_metadata.google.cloud.osconfig.agentendpoint.v1beta.json b/internal/generated/snippets/osconfig/agentendpoint/apiv1beta/snippet_metadata.google.cloud.osconfig.agentendpoint.v1beta.json index f0b5a45157ec..44c58055b83a 100644 --- a/internal/generated/snippets/osconfig/agentendpoint/apiv1beta/snippet_metadata.google.cloud.osconfig.agentendpoint.v1beta.json +++ b/internal/generated/snippets/osconfig/agentendpoint/apiv1beta/snippet_metadata.google.cloud.osconfig.agentendpoint.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/osconfig/agentendpoint/apiv1beta", - "version": "1.14.2", + "version": "1.14.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/osconfig/apiv1/Client/CancelPatchJob/main.go b/internal/generated/snippets/osconfig/apiv1/Client/CancelPatchJob/main.go index 79dc52e1e7fb..362bfef3490a 100644 --- a/internal/generated/snippets/osconfig/apiv1/Client/CancelPatchJob/main.go +++ b/internal/generated/snippets/osconfig/apiv1/Client/CancelPatchJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1/Client/CreatePatchDeployment/main.go b/internal/generated/snippets/osconfig/apiv1/Client/CreatePatchDeployment/main.go index 64adb233e14e..2791eb2d7a17 100644 --- a/internal/generated/snippets/osconfig/apiv1/Client/CreatePatchDeployment/main.go +++ b/internal/generated/snippets/osconfig/apiv1/Client/CreatePatchDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1/Client/DeletePatchDeployment/main.go b/internal/generated/snippets/osconfig/apiv1/Client/DeletePatchDeployment/main.go index dd98550f9567..633bbfbf00fe 100644 --- a/internal/generated/snippets/osconfig/apiv1/Client/DeletePatchDeployment/main.go +++ b/internal/generated/snippets/osconfig/apiv1/Client/DeletePatchDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1/Client/ExecutePatchJob/main.go b/internal/generated/snippets/osconfig/apiv1/Client/ExecutePatchJob/main.go index 79048db5913a..651ac39ba763 100644 --- a/internal/generated/snippets/osconfig/apiv1/Client/ExecutePatchJob/main.go +++ b/internal/generated/snippets/osconfig/apiv1/Client/ExecutePatchJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1/Client/GetPatchDeployment/main.go b/internal/generated/snippets/osconfig/apiv1/Client/GetPatchDeployment/main.go index b02b86063c84..051a56276697 100644 --- a/internal/generated/snippets/osconfig/apiv1/Client/GetPatchDeployment/main.go +++ b/internal/generated/snippets/osconfig/apiv1/Client/GetPatchDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1/Client/GetPatchJob/main.go b/internal/generated/snippets/osconfig/apiv1/Client/GetPatchJob/main.go index 8f73d65478d9..92c873ba1fa3 100644 --- a/internal/generated/snippets/osconfig/apiv1/Client/GetPatchJob/main.go +++ b/internal/generated/snippets/osconfig/apiv1/Client/GetPatchJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1/Client/ListPatchDeployments/main.go b/internal/generated/snippets/osconfig/apiv1/Client/ListPatchDeployments/main.go index a4804445f34f..b57ffa7e131b 100644 --- a/internal/generated/snippets/osconfig/apiv1/Client/ListPatchDeployments/main.go +++ b/internal/generated/snippets/osconfig/apiv1/Client/ListPatchDeployments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1/Client/ListPatchJobInstanceDetails/main.go b/internal/generated/snippets/osconfig/apiv1/Client/ListPatchJobInstanceDetails/main.go index 62753a86dc68..696bac313b20 100644 --- a/internal/generated/snippets/osconfig/apiv1/Client/ListPatchJobInstanceDetails/main.go +++ b/internal/generated/snippets/osconfig/apiv1/Client/ListPatchJobInstanceDetails/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1/Client/ListPatchJobs/main.go b/internal/generated/snippets/osconfig/apiv1/Client/ListPatchJobs/main.go index 410867fa783e..39a83b0f46b8 100644 --- a/internal/generated/snippets/osconfig/apiv1/Client/ListPatchJobs/main.go +++ b/internal/generated/snippets/osconfig/apiv1/Client/ListPatchJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1/Client/PausePatchDeployment/main.go b/internal/generated/snippets/osconfig/apiv1/Client/PausePatchDeployment/main.go index c60cce806fc5..0b4ef73981ec 100644 --- a/internal/generated/snippets/osconfig/apiv1/Client/PausePatchDeployment/main.go +++ b/internal/generated/snippets/osconfig/apiv1/Client/PausePatchDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1/Client/ResumePatchDeployment/main.go b/internal/generated/snippets/osconfig/apiv1/Client/ResumePatchDeployment/main.go index a84c0293026a..bb247559b840 100644 --- a/internal/generated/snippets/osconfig/apiv1/Client/ResumePatchDeployment/main.go +++ b/internal/generated/snippets/osconfig/apiv1/Client/ResumePatchDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1/Client/UpdatePatchDeployment/main.go b/internal/generated/snippets/osconfig/apiv1/Client/UpdatePatchDeployment/main.go index ff1297fbdaf6..448581fe2955 100644 --- a/internal/generated/snippets/osconfig/apiv1/Client/UpdatePatchDeployment/main.go +++ b/internal/generated/snippets/osconfig/apiv1/Client/UpdatePatchDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/CreateOSPolicyAssignment/main.go b/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/CreateOSPolicyAssignment/main.go index 18f5a6b99e06..a84f94b46d9f 100644 --- a/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/CreateOSPolicyAssignment/main.go +++ b/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/CreateOSPolicyAssignment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/DeleteOSPolicyAssignment/main.go b/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/DeleteOSPolicyAssignment/main.go index 65d10ac90a78..77f3180219d0 100644 --- a/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/DeleteOSPolicyAssignment/main.go +++ b/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/DeleteOSPolicyAssignment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/GetInventory/main.go b/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/GetInventory/main.go index 62dacb4d6d36..b1f0f7c8e111 100644 --- a/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/GetInventory/main.go +++ b/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/GetInventory/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/GetOSPolicyAssignment/main.go b/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/GetOSPolicyAssignment/main.go index 293e7833c2dc..8d1befecbf06 100644 --- a/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/GetOSPolicyAssignment/main.go +++ b/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/GetOSPolicyAssignment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/GetOSPolicyAssignmentReport/main.go b/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/GetOSPolicyAssignmentReport/main.go index a0bf8e2be113..a659178e86d8 100644 --- a/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/GetOSPolicyAssignmentReport/main.go +++ b/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/GetOSPolicyAssignmentReport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/GetVulnerabilityReport/main.go b/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/GetVulnerabilityReport/main.go index f47c35b96f8d..bc56008d6ed1 100644 --- a/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/GetVulnerabilityReport/main.go +++ b/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/GetVulnerabilityReport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/ListInventories/main.go b/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/ListInventories/main.go index 38c1d31ea901..afd41dbeba0a 100644 --- a/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/ListInventories/main.go +++ b/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/ListInventories/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/ListOSPolicyAssignmentReports/main.go b/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/ListOSPolicyAssignmentReports/main.go index 4b2c77431358..e887ac0a8fed 100644 --- a/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/ListOSPolicyAssignmentReports/main.go +++ b/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/ListOSPolicyAssignmentReports/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/ListOSPolicyAssignmentRevisions/main.go b/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/ListOSPolicyAssignmentRevisions/main.go index ea7b8db4bbdb..8214d6b5b8ab 100644 --- a/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/ListOSPolicyAssignmentRevisions/main.go +++ b/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/ListOSPolicyAssignmentRevisions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/ListOSPolicyAssignments/main.go b/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/ListOSPolicyAssignments/main.go index e4de9b84b842..5b0e40b694de 100644 --- a/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/ListOSPolicyAssignments/main.go +++ b/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/ListOSPolicyAssignments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/ListVulnerabilityReports/main.go b/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/ListVulnerabilityReports/main.go index 2898dbe6f747..cba2076baef8 100644 --- a/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/ListVulnerabilityReports/main.go +++ b/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/ListVulnerabilityReports/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/UpdateOSPolicyAssignment/main.go b/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/UpdateOSPolicyAssignment/main.go index fc248374601b..d6e150685aff 100644 --- a/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/UpdateOSPolicyAssignment/main.go +++ b/internal/generated/snippets/osconfig/apiv1/OsConfigZonalClient/UpdateOSPolicyAssignment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1/snippet_metadata.google.cloud.osconfig.v1.json b/internal/generated/snippets/osconfig/apiv1/snippet_metadata.google.cloud.osconfig.v1.json index a35a980d32cd..42abb04db0e3 100644 --- a/internal/generated/snippets/osconfig/apiv1/snippet_metadata.google.cloud.osconfig.v1.json +++ b/internal/generated/snippets/osconfig/apiv1/snippet_metadata.google.cloud.osconfig.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/osconfig/apiv1", - "version": "1.14.2", + "version": "1.14.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/CreateOSPolicyAssignment/main.go b/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/CreateOSPolicyAssignment/main.go index 34addffc4d0d..e2df10a152c4 100644 --- a/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/CreateOSPolicyAssignment/main.go +++ b/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/CreateOSPolicyAssignment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/DeleteOSPolicyAssignment/main.go b/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/DeleteOSPolicyAssignment/main.go index 1582b3e50306..befc047ae592 100644 --- a/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/DeleteOSPolicyAssignment/main.go +++ b/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/DeleteOSPolicyAssignment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/GetInstanceOSPoliciesCompliance/main.go b/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/GetInstanceOSPoliciesCompliance/main.go index 96ecc82db69a..07130ed60ccc 100644 --- a/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/GetInstanceOSPoliciesCompliance/main.go +++ b/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/GetInstanceOSPoliciesCompliance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/GetInventory/main.go b/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/GetInventory/main.go index f11505756583..dc71b76ce052 100644 --- a/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/GetInventory/main.go +++ b/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/GetInventory/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/GetOSPolicyAssignment/main.go b/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/GetOSPolicyAssignment/main.go index abfa72501b57..d3e78a044f8b 100644 --- a/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/GetOSPolicyAssignment/main.go +++ b/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/GetOSPolicyAssignment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/GetOSPolicyAssignmentReport/main.go b/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/GetOSPolicyAssignmentReport/main.go index 8fe3eaf877f3..ea62a71a4c4c 100644 --- a/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/GetOSPolicyAssignmentReport/main.go +++ b/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/GetOSPolicyAssignmentReport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/GetVulnerabilityReport/main.go b/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/GetVulnerabilityReport/main.go index e32ee8104ffa..381b0311d341 100644 --- a/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/GetVulnerabilityReport/main.go +++ b/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/GetVulnerabilityReport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/ListInstanceOSPoliciesCompliances/main.go b/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/ListInstanceOSPoliciesCompliances/main.go index 27cec58aa1ad..dccb6642c391 100644 --- a/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/ListInstanceOSPoliciesCompliances/main.go +++ b/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/ListInstanceOSPoliciesCompliances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/ListInventories/main.go b/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/ListInventories/main.go index 206776b114b7..43b3ada3e379 100644 --- a/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/ListInventories/main.go +++ b/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/ListInventories/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/ListOSPolicyAssignmentReports/main.go b/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/ListOSPolicyAssignmentReports/main.go index 824d4c8b4310..8eda93161e33 100644 --- a/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/ListOSPolicyAssignmentReports/main.go +++ b/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/ListOSPolicyAssignmentReports/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/ListOSPolicyAssignmentRevisions/main.go b/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/ListOSPolicyAssignmentRevisions/main.go index faed0917a3ff..e4df764b4998 100644 --- a/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/ListOSPolicyAssignmentRevisions/main.go +++ b/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/ListOSPolicyAssignmentRevisions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/ListOSPolicyAssignments/main.go b/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/ListOSPolicyAssignments/main.go index 852ca06ede62..8cc740163ab6 100644 --- a/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/ListOSPolicyAssignments/main.go +++ b/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/ListOSPolicyAssignments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/ListVulnerabilityReports/main.go b/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/ListVulnerabilityReports/main.go index fc53a387541f..686981d651f4 100644 --- a/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/ListVulnerabilityReports/main.go +++ b/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/ListVulnerabilityReports/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/UpdateOSPolicyAssignment/main.go b/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/UpdateOSPolicyAssignment/main.go index 8748c115166c..65f69732ea39 100644 --- a/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/UpdateOSPolicyAssignment/main.go +++ b/internal/generated/snippets/osconfig/apiv1alpha/OsConfigZonalClient/UpdateOSPolicyAssignment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1alpha/snippet_metadata.google.cloud.osconfig.v1alpha.json b/internal/generated/snippets/osconfig/apiv1alpha/snippet_metadata.google.cloud.osconfig.v1alpha.json index b48b55b6ba88..3fd1429dc33e 100644 --- a/internal/generated/snippets/osconfig/apiv1alpha/snippet_metadata.google.cloud.osconfig.v1alpha.json +++ b/internal/generated/snippets/osconfig/apiv1alpha/snippet_metadata.google.cloud.osconfig.v1alpha.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/osconfig/apiv1alpha", - "version": "1.14.2", + "version": "1.14.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/osconfig/apiv1beta/Client/CancelPatchJob/main.go b/internal/generated/snippets/osconfig/apiv1beta/Client/CancelPatchJob/main.go index a93e3a6022c6..956cbebb568c 100644 --- a/internal/generated/snippets/osconfig/apiv1beta/Client/CancelPatchJob/main.go +++ b/internal/generated/snippets/osconfig/apiv1beta/Client/CancelPatchJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1beta/Client/CreateGuestPolicy/main.go b/internal/generated/snippets/osconfig/apiv1beta/Client/CreateGuestPolicy/main.go index d352f061436b..21fa20ec82b3 100644 --- a/internal/generated/snippets/osconfig/apiv1beta/Client/CreateGuestPolicy/main.go +++ b/internal/generated/snippets/osconfig/apiv1beta/Client/CreateGuestPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1beta/Client/CreatePatchDeployment/main.go b/internal/generated/snippets/osconfig/apiv1beta/Client/CreatePatchDeployment/main.go index 4a418aab0c15..dbebfe51aca0 100644 --- a/internal/generated/snippets/osconfig/apiv1beta/Client/CreatePatchDeployment/main.go +++ b/internal/generated/snippets/osconfig/apiv1beta/Client/CreatePatchDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1beta/Client/DeleteGuestPolicy/main.go b/internal/generated/snippets/osconfig/apiv1beta/Client/DeleteGuestPolicy/main.go index 1a1a752a1e00..18e80c1411a6 100644 --- a/internal/generated/snippets/osconfig/apiv1beta/Client/DeleteGuestPolicy/main.go +++ b/internal/generated/snippets/osconfig/apiv1beta/Client/DeleteGuestPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1beta/Client/DeletePatchDeployment/main.go b/internal/generated/snippets/osconfig/apiv1beta/Client/DeletePatchDeployment/main.go index 30a7318446ba..11de24e13d1d 100644 --- a/internal/generated/snippets/osconfig/apiv1beta/Client/DeletePatchDeployment/main.go +++ b/internal/generated/snippets/osconfig/apiv1beta/Client/DeletePatchDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1beta/Client/ExecutePatchJob/main.go b/internal/generated/snippets/osconfig/apiv1beta/Client/ExecutePatchJob/main.go index 4d21963abe55..53a783e60eae 100644 --- a/internal/generated/snippets/osconfig/apiv1beta/Client/ExecutePatchJob/main.go +++ b/internal/generated/snippets/osconfig/apiv1beta/Client/ExecutePatchJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1beta/Client/GetGuestPolicy/main.go b/internal/generated/snippets/osconfig/apiv1beta/Client/GetGuestPolicy/main.go index 565a631012f4..e4895ee62971 100644 --- a/internal/generated/snippets/osconfig/apiv1beta/Client/GetGuestPolicy/main.go +++ b/internal/generated/snippets/osconfig/apiv1beta/Client/GetGuestPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1beta/Client/GetPatchDeployment/main.go b/internal/generated/snippets/osconfig/apiv1beta/Client/GetPatchDeployment/main.go index f3ce2cf01ae6..c8cb5686121a 100644 --- a/internal/generated/snippets/osconfig/apiv1beta/Client/GetPatchDeployment/main.go +++ b/internal/generated/snippets/osconfig/apiv1beta/Client/GetPatchDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1beta/Client/GetPatchJob/main.go b/internal/generated/snippets/osconfig/apiv1beta/Client/GetPatchJob/main.go index 474234786ca9..eb21f4c3baab 100644 --- a/internal/generated/snippets/osconfig/apiv1beta/Client/GetPatchJob/main.go +++ b/internal/generated/snippets/osconfig/apiv1beta/Client/GetPatchJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1beta/Client/ListGuestPolicies/main.go b/internal/generated/snippets/osconfig/apiv1beta/Client/ListGuestPolicies/main.go index 9f942bc59403..a96d6723b2ad 100644 --- a/internal/generated/snippets/osconfig/apiv1beta/Client/ListGuestPolicies/main.go +++ b/internal/generated/snippets/osconfig/apiv1beta/Client/ListGuestPolicies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1beta/Client/ListPatchDeployments/main.go b/internal/generated/snippets/osconfig/apiv1beta/Client/ListPatchDeployments/main.go index e9654c09bd3d..685eb3376fbd 100644 --- a/internal/generated/snippets/osconfig/apiv1beta/Client/ListPatchDeployments/main.go +++ b/internal/generated/snippets/osconfig/apiv1beta/Client/ListPatchDeployments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1beta/Client/ListPatchJobInstanceDetails/main.go b/internal/generated/snippets/osconfig/apiv1beta/Client/ListPatchJobInstanceDetails/main.go index d2d8d062ab83..986dc55d6ff1 100644 --- a/internal/generated/snippets/osconfig/apiv1beta/Client/ListPatchJobInstanceDetails/main.go +++ b/internal/generated/snippets/osconfig/apiv1beta/Client/ListPatchJobInstanceDetails/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1beta/Client/ListPatchJobs/main.go b/internal/generated/snippets/osconfig/apiv1beta/Client/ListPatchJobs/main.go index 73ae443867dd..7fa8576051e8 100644 --- a/internal/generated/snippets/osconfig/apiv1beta/Client/ListPatchJobs/main.go +++ b/internal/generated/snippets/osconfig/apiv1beta/Client/ListPatchJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1beta/Client/LookupEffectiveGuestPolicy/main.go b/internal/generated/snippets/osconfig/apiv1beta/Client/LookupEffectiveGuestPolicy/main.go index 0781b8ca89c3..88a7af1b8702 100644 --- a/internal/generated/snippets/osconfig/apiv1beta/Client/LookupEffectiveGuestPolicy/main.go +++ b/internal/generated/snippets/osconfig/apiv1beta/Client/LookupEffectiveGuestPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1beta/Client/PausePatchDeployment/main.go b/internal/generated/snippets/osconfig/apiv1beta/Client/PausePatchDeployment/main.go index 777c8faad5e9..902812390f4e 100644 --- a/internal/generated/snippets/osconfig/apiv1beta/Client/PausePatchDeployment/main.go +++ b/internal/generated/snippets/osconfig/apiv1beta/Client/PausePatchDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1beta/Client/ResumePatchDeployment/main.go b/internal/generated/snippets/osconfig/apiv1beta/Client/ResumePatchDeployment/main.go index f1c0b970d14f..066f7a9f8afc 100644 --- a/internal/generated/snippets/osconfig/apiv1beta/Client/ResumePatchDeployment/main.go +++ b/internal/generated/snippets/osconfig/apiv1beta/Client/ResumePatchDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1beta/Client/UpdateGuestPolicy/main.go b/internal/generated/snippets/osconfig/apiv1beta/Client/UpdateGuestPolicy/main.go index 39dc75e59782..38eea2b63f50 100644 --- a/internal/generated/snippets/osconfig/apiv1beta/Client/UpdateGuestPolicy/main.go +++ b/internal/generated/snippets/osconfig/apiv1beta/Client/UpdateGuestPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1beta/Client/UpdatePatchDeployment/main.go b/internal/generated/snippets/osconfig/apiv1beta/Client/UpdatePatchDeployment/main.go index d8d7ea027fe6..bdb6fcf1f093 100644 --- a/internal/generated/snippets/osconfig/apiv1beta/Client/UpdatePatchDeployment/main.go +++ b/internal/generated/snippets/osconfig/apiv1beta/Client/UpdatePatchDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/osconfig/apiv1beta/snippet_metadata.google.cloud.osconfig.v1beta.json b/internal/generated/snippets/osconfig/apiv1beta/snippet_metadata.google.cloud.osconfig.v1beta.json index 53fcf2f6ec89..40a1df77a9fa 100644 --- a/internal/generated/snippets/osconfig/apiv1beta/snippet_metadata.google.cloud.osconfig.v1beta.json +++ b/internal/generated/snippets/osconfig/apiv1beta/snippet_metadata.google.cloud.osconfig.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/osconfig/apiv1beta", - "version": "1.14.2", + "version": "1.14.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/oslogin/apiv1/Client/CreateSshPublicKey/main.go b/internal/generated/snippets/oslogin/apiv1/Client/CreateSshPublicKey/main.go index bd998bfb545a..86b771f4865e 100644 --- a/internal/generated/snippets/oslogin/apiv1/Client/CreateSshPublicKey/main.go +++ b/internal/generated/snippets/oslogin/apiv1/Client/CreateSshPublicKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oslogin/apiv1/Client/DeletePosixAccount/main.go b/internal/generated/snippets/oslogin/apiv1/Client/DeletePosixAccount/main.go index af55dfdc8cf5..36a655e395a6 100644 --- a/internal/generated/snippets/oslogin/apiv1/Client/DeletePosixAccount/main.go +++ b/internal/generated/snippets/oslogin/apiv1/Client/DeletePosixAccount/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oslogin/apiv1/Client/DeleteSshPublicKey/main.go b/internal/generated/snippets/oslogin/apiv1/Client/DeleteSshPublicKey/main.go index 328b54024f37..fa1d68f18310 100644 --- a/internal/generated/snippets/oslogin/apiv1/Client/DeleteSshPublicKey/main.go +++ b/internal/generated/snippets/oslogin/apiv1/Client/DeleteSshPublicKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oslogin/apiv1/Client/GetLoginProfile/main.go b/internal/generated/snippets/oslogin/apiv1/Client/GetLoginProfile/main.go index d3c03b7e1620..db2b26b2d7e0 100644 --- a/internal/generated/snippets/oslogin/apiv1/Client/GetLoginProfile/main.go +++ b/internal/generated/snippets/oslogin/apiv1/Client/GetLoginProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oslogin/apiv1/Client/GetSshPublicKey/main.go b/internal/generated/snippets/oslogin/apiv1/Client/GetSshPublicKey/main.go index d46e2157f7b9..cf425d0e5af1 100644 --- a/internal/generated/snippets/oslogin/apiv1/Client/GetSshPublicKey/main.go +++ b/internal/generated/snippets/oslogin/apiv1/Client/GetSshPublicKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oslogin/apiv1/Client/ImportSshPublicKey/main.go b/internal/generated/snippets/oslogin/apiv1/Client/ImportSshPublicKey/main.go index fb6a0a818dc4..6187b49e950f 100644 --- a/internal/generated/snippets/oslogin/apiv1/Client/ImportSshPublicKey/main.go +++ b/internal/generated/snippets/oslogin/apiv1/Client/ImportSshPublicKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oslogin/apiv1/Client/UpdateSshPublicKey/main.go b/internal/generated/snippets/oslogin/apiv1/Client/UpdateSshPublicKey/main.go index 6796f1adc593..943c7527b3a2 100644 --- a/internal/generated/snippets/oslogin/apiv1/Client/UpdateSshPublicKey/main.go +++ b/internal/generated/snippets/oslogin/apiv1/Client/UpdateSshPublicKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oslogin/apiv1/snippet_metadata.google.cloud.oslogin.v1.json b/internal/generated/snippets/oslogin/apiv1/snippet_metadata.google.cloud.oslogin.v1.json index d9dca1a3b494..a915bcd4a8b3 100644 --- a/internal/generated/snippets/oslogin/apiv1/snippet_metadata.google.cloud.oslogin.v1.json +++ b/internal/generated/snippets/oslogin/apiv1/snippet_metadata.google.cloud.oslogin.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/oslogin/apiv1", - "version": "1.14.2", + "version": "1.14.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/oslogin/apiv1beta/Client/CreateSshPublicKey/main.go b/internal/generated/snippets/oslogin/apiv1beta/Client/CreateSshPublicKey/main.go index 0106ef0b860d..fa93dd289580 100644 --- a/internal/generated/snippets/oslogin/apiv1beta/Client/CreateSshPublicKey/main.go +++ b/internal/generated/snippets/oslogin/apiv1beta/Client/CreateSshPublicKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oslogin/apiv1beta/Client/DeletePosixAccount/main.go b/internal/generated/snippets/oslogin/apiv1beta/Client/DeletePosixAccount/main.go index bf436e67b7a1..278624c0e2d8 100644 --- a/internal/generated/snippets/oslogin/apiv1beta/Client/DeletePosixAccount/main.go +++ b/internal/generated/snippets/oslogin/apiv1beta/Client/DeletePosixAccount/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oslogin/apiv1beta/Client/DeleteSshPublicKey/main.go b/internal/generated/snippets/oslogin/apiv1beta/Client/DeleteSshPublicKey/main.go index c30684518bee..55e530b115c2 100644 --- a/internal/generated/snippets/oslogin/apiv1beta/Client/DeleteSshPublicKey/main.go +++ b/internal/generated/snippets/oslogin/apiv1beta/Client/DeleteSshPublicKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oslogin/apiv1beta/Client/GetLoginProfile/main.go b/internal/generated/snippets/oslogin/apiv1beta/Client/GetLoginProfile/main.go index c401404f5586..9808d531004f 100644 --- a/internal/generated/snippets/oslogin/apiv1beta/Client/GetLoginProfile/main.go +++ b/internal/generated/snippets/oslogin/apiv1beta/Client/GetLoginProfile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oslogin/apiv1beta/Client/GetSshPublicKey/main.go b/internal/generated/snippets/oslogin/apiv1beta/Client/GetSshPublicKey/main.go index 573893126619..4c1c3090d658 100644 --- a/internal/generated/snippets/oslogin/apiv1beta/Client/GetSshPublicKey/main.go +++ b/internal/generated/snippets/oslogin/apiv1beta/Client/GetSshPublicKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oslogin/apiv1beta/Client/ImportSshPublicKey/main.go b/internal/generated/snippets/oslogin/apiv1beta/Client/ImportSshPublicKey/main.go index c27571a48118..c4ff9f2aed31 100644 --- a/internal/generated/snippets/oslogin/apiv1beta/Client/ImportSshPublicKey/main.go +++ b/internal/generated/snippets/oslogin/apiv1beta/Client/ImportSshPublicKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oslogin/apiv1beta/Client/SignSshPublicKey/main.go b/internal/generated/snippets/oslogin/apiv1beta/Client/SignSshPublicKey/main.go index b104ed8b66f8..b5e254e8242b 100644 --- a/internal/generated/snippets/oslogin/apiv1beta/Client/SignSshPublicKey/main.go +++ b/internal/generated/snippets/oslogin/apiv1beta/Client/SignSshPublicKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oslogin/apiv1beta/Client/UpdateSshPublicKey/main.go b/internal/generated/snippets/oslogin/apiv1beta/Client/UpdateSshPublicKey/main.go index 9cb6ee408b85..3b0bb56a38df 100644 --- a/internal/generated/snippets/oslogin/apiv1beta/Client/UpdateSshPublicKey/main.go +++ b/internal/generated/snippets/oslogin/apiv1beta/Client/UpdateSshPublicKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/oslogin/apiv1beta/snippet_metadata.google.cloud.oslogin.v1beta.json b/internal/generated/snippets/oslogin/apiv1beta/snippet_metadata.google.cloud.oslogin.v1beta.json index 68e368e90cb2..3dc33531f3f4 100644 --- a/internal/generated/snippets/oslogin/apiv1beta/snippet_metadata.google.cloud.oslogin.v1beta.json +++ b/internal/generated/snippets/oslogin/apiv1beta/snippet_metadata.google.cloud.oslogin.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/oslogin/apiv1beta", - "version": "1.14.2", + "version": "1.14.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/parallelstore/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/parallelstore/apiv1/Client/CancelOperation/main.go index 9dc945fb5712..2aa7f2b19ae5 100644 --- a/internal/generated/snippets/parallelstore/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/parallelstore/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/parallelstore/apiv1/Client/CreateInstance/main.go b/internal/generated/snippets/parallelstore/apiv1/Client/CreateInstance/main.go index 8570e8731d76..92405b0c7bf0 100644 --- a/internal/generated/snippets/parallelstore/apiv1/Client/CreateInstance/main.go +++ b/internal/generated/snippets/parallelstore/apiv1/Client/CreateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/parallelstore/apiv1/Client/DeleteInstance/main.go b/internal/generated/snippets/parallelstore/apiv1/Client/DeleteInstance/main.go index 2c7fa8bf2a0f..54ed76d1aa32 100644 --- a/internal/generated/snippets/parallelstore/apiv1/Client/DeleteInstance/main.go +++ b/internal/generated/snippets/parallelstore/apiv1/Client/DeleteInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/parallelstore/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/parallelstore/apiv1/Client/DeleteOperation/main.go index 05d634fadbf0..2a952f268329 100644 --- a/internal/generated/snippets/parallelstore/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/parallelstore/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/parallelstore/apiv1/Client/ExportData/main.go b/internal/generated/snippets/parallelstore/apiv1/Client/ExportData/main.go index 4b9e8a7781a6..db5f77528bd9 100644 --- a/internal/generated/snippets/parallelstore/apiv1/Client/ExportData/main.go +++ b/internal/generated/snippets/parallelstore/apiv1/Client/ExportData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/parallelstore/apiv1/Client/GetInstance/main.go b/internal/generated/snippets/parallelstore/apiv1/Client/GetInstance/main.go index 60f810350b0a..0424cf4f3c55 100644 --- a/internal/generated/snippets/parallelstore/apiv1/Client/GetInstance/main.go +++ b/internal/generated/snippets/parallelstore/apiv1/Client/GetInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/parallelstore/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/parallelstore/apiv1/Client/GetLocation/main.go index a782349228ac..a34b13ec02ac 100644 --- a/internal/generated/snippets/parallelstore/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/parallelstore/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/parallelstore/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/parallelstore/apiv1/Client/GetOperation/main.go index 4f4a8d246cfb..207b8efcc603 100644 --- a/internal/generated/snippets/parallelstore/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/parallelstore/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/parallelstore/apiv1/Client/ImportData/main.go b/internal/generated/snippets/parallelstore/apiv1/Client/ImportData/main.go index 186658487a0d..77f33e50cf2e 100644 --- a/internal/generated/snippets/parallelstore/apiv1/Client/ImportData/main.go +++ b/internal/generated/snippets/parallelstore/apiv1/Client/ImportData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/parallelstore/apiv1/Client/ListInstances/main.go b/internal/generated/snippets/parallelstore/apiv1/Client/ListInstances/main.go index 90def2b98e55..c4cc6d43bc80 100644 --- a/internal/generated/snippets/parallelstore/apiv1/Client/ListInstances/main.go +++ b/internal/generated/snippets/parallelstore/apiv1/Client/ListInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/parallelstore/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/parallelstore/apiv1/Client/ListLocations/main.go index 097210ce6556..0b4b0b84a4ae 100644 --- a/internal/generated/snippets/parallelstore/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/parallelstore/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/parallelstore/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/parallelstore/apiv1/Client/ListOperations/main.go index 4fdeaedb06f8..a83f87ee762f 100644 --- a/internal/generated/snippets/parallelstore/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/parallelstore/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/parallelstore/apiv1/Client/UpdateInstance/main.go b/internal/generated/snippets/parallelstore/apiv1/Client/UpdateInstance/main.go index c92ee55ffc9a..219082a353d3 100644 --- a/internal/generated/snippets/parallelstore/apiv1/Client/UpdateInstance/main.go +++ b/internal/generated/snippets/parallelstore/apiv1/Client/UpdateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/parallelstore/apiv1/snippet_metadata.google.cloud.parallelstore.v1.json b/internal/generated/snippets/parallelstore/apiv1/snippet_metadata.google.cloud.parallelstore.v1.json index 7662aae4ccc1..5fb53862943b 100644 --- a/internal/generated/snippets/parallelstore/apiv1/snippet_metadata.google.cloud.parallelstore.v1.json +++ b/internal/generated/snippets/parallelstore/apiv1/snippet_metadata.google.cloud.parallelstore.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/parallelstore/apiv1", - "version": "0.9.0", + "version": "0.9.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/parallelstore/apiv1beta/Client/CancelOperation/main.go b/internal/generated/snippets/parallelstore/apiv1beta/Client/CancelOperation/main.go index bcdef65d048b..70adaf6ed6db 100644 --- a/internal/generated/snippets/parallelstore/apiv1beta/Client/CancelOperation/main.go +++ b/internal/generated/snippets/parallelstore/apiv1beta/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/parallelstore/apiv1beta/Client/CreateInstance/main.go b/internal/generated/snippets/parallelstore/apiv1beta/Client/CreateInstance/main.go index c3675f936ae9..22b5b2954a7d 100644 --- a/internal/generated/snippets/parallelstore/apiv1beta/Client/CreateInstance/main.go +++ b/internal/generated/snippets/parallelstore/apiv1beta/Client/CreateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/parallelstore/apiv1beta/Client/DeleteInstance/main.go b/internal/generated/snippets/parallelstore/apiv1beta/Client/DeleteInstance/main.go index b6c63ecea5f0..cdb637828560 100644 --- a/internal/generated/snippets/parallelstore/apiv1beta/Client/DeleteInstance/main.go +++ b/internal/generated/snippets/parallelstore/apiv1beta/Client/DeleteInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/parallelstore/apiv1beta/Client/DeleteOperation/main.go b/internal/generated/snippets/parallelstore/apiv1beta/Client/DeleteOperation/main.go index 482f00f256c1..34b1195f8fe5 100644 --- a/internal/generated/snippets/parallelstore/apiv1beta/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/parallelstore/apiv1beta/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/parallelstore/apiv1beta/Client/ExportData/main.go b/internal/generated/snippets/parallelstore/apiv1beta/Client/ExportData/main.go index 1d4267ffb107..2bc67773df0c 100644 --- a/internal/generated/snippets/parallelstore/apiv1beta/Client/ExportData/main.go +++ b/internal/generated/snippets/parallelstore/apiv1beta/Client/ExportData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/parallelstore/apiv1beta/Client/GetInstance/main.go b/internal/generated/snippets/parallelstore/apiv1beta/Client/GetInstance/main.go index 490075923c5e..2daa26ab9b7e 100644 --- a/internal/generated/snippets/parallelstore/apiv1beta/Client/GetInstance/main.go +++ b/internal/generated/snippets/parallelstore/apiv1beta/Client/GetInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/parallelstore/apiv1beta/Client/GetLocation/main.go b/internal/generated/snippets/parallelstore/apiv1beta/Client/GetLocation/main.go index 475d407dae78..667fb5320fb5 100644 --- a/internal/generated/snippets/parallelstore/apiv1beta/Client/GetLocation/main.go +++ b/internal/generated/snippets/parallelstore/apiv1beta/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/parallelstore/apiv1beta/Client/GetOperation/main.go b/internal/generated/snippets/parallelstore/apiv1beta/Client/GetOperation/main.go index c5142be2b055..6dc4a04a5793 100644 --- a/internal/generated/snippets/parallelstore/apiv1beta/Client/GetOperation/main.go +++ b/internal/generated/snippets/parallelstore/apiv1beta/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/parallelstore/apiv1beta/Client/ImportData/main.go b/internal/generated/snippets/parallelstore/apiv1beta/Client/ImportData/main.go index 02073f18393c..522ba2e0ea1d 100644 --- a/internal/generated/snippets/parallelstore/apiv1beta/Client/ImportData/main.go +++ b/internal/generated/snippets/parallelstore/apiv1beta/Client/ImportData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/parallelstore/apiv1beta/Client/ListInstances/main.go b/internal/generated/snippets/parallelstore/apiv1beta/Client/ListInstances/main.go index e6f012c42bd1..c293f6aacb9a 100644 --- a/internal/generated/snippets/parallelstore/apiv1beta/Client/ListInstances/main.go +++ b/internal/generated/snippets/parallelstore/apiv1beta/Client/ListInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/parallelstore/apiv1beta/Client/ListLocations/main.go b/internal/generated/snippets/parallelstore/apiv1beta/Client/ListLocations/main.go index a82d3e0dce58..e0d6ee7cc9b0 100644 --- a/internal/generated/snippets/parallelstore/apiv1beta/Client/ListLocations/main.go +++ b/internal/generated/snippets/parallelstore/apiv1beta/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/parallelstore/apiv1beta/Client/ListOperations/main.go b/internal/generated/snippets/parallelstore/apiv1beta/Client/ListOperations/main.go index 28c50d27a02b..29b00a638249 100644 --- a/internal/generated/snippets/parallelstore/apiv1beta/Client/ListOperations/main.go +++ b/internal/generated/snippets/parallelstore/apiv1beta/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/parallelstore/apiv1beta/Client/UpdateInstance/main.go b/internal/generated/snippets/parallelstore/apiv1beta/Client/UpdateInstance/main.go index 5cdfb05b5924..9185eddf377f 100644 --- a/internal/generated/snippets/parallelstore/apiv1beta/Client/UpdateInstance/main.go +++ b/internal/generated/snippets/parallelstore/apiv1beta/Client/UpdateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/parallelstore/apiv1beta/snippet_metadata.google.cloud.parallelstore.v1beta.json b/internal/generated/snippets/parallelstore/apiv1beta/snippet_metadata.google.cloud.parallelstore.v1beta.json index 0f7b299da1d6..c2968ead2606 100644 --- a/internal/generated/snippets/parallelstore/apiv1beta/snippet_metadata.google.cloud.parallelstore.v1beta.json +++ b/internal/generated/snippets/parallelstore/apiv1beta/snippet_metadata.google.cloud.parallelstore.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/parallelstore/apiv1beta", - "version": "0.9.0", + "version": "0.9.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/phishingprotection/apiv1beta1/PhishingProtectionServiceV1Beta1Client/ReportPhishing/main.go b/internal/generated/snippets/phishingprotection/apiv1beta1/PhishingProtectionServiceV1Beta1Client/ReportPhishing/main.go index 9d7a621c2c9c..34167f692359 100644 --- a/internal/generated/snippets/phishingprotection/apiv1beta1/PhishingProtectionServiceV1Beta1Client/ReportPhishing/main.go +++ b/internal/generated/snippets/phishingprotection/apiv1beta1/PhishingProtectionServiceV1Beta1Client/ReportPhishing/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/policysimulator/apiv1/SimulatorClient/CreateReplay/main.go b/internal/generated/snippets/policysimulator/apiv1/SimulatorClient/CreateReplay/main.go index 752c393b3dc8..8152baab72e9 100644 --- a/internal/generated/snippets/policysimulator/apiv1/SimulatorClient/CreateReplay/main.go +++ b/internal/generated/snippets/policysimulator/apiv1/SimulatorClient/CreateReplay/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/policysimulator/apiv1/SimulatorClient/GetOperation/main.go b/internal/generated/snippets/policysimulator/apiv1/SimulatorClient/GetOperation/main.go index cfb2192206ed..ad8eb668ffa0 100644 --- a/internal/generated/snippets/policysimulator/apiv1/SimulatorClient/GetOperation/main.go +++ b/internal/generated/snippets/policysimulator/apiv1/SimulatorClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/policysimulator/apiv1/SimulatorClient/GetReplay/main.go b/internal/generated/snippets/policysimulator/apiv1/SimulatorClient/GetReplay/main.go index 8b2e1a49e0eb..810b163e6789 100644 --- a/internal/generated/snippets/policysimulator/apiv1/SimulatorClient/GetReplay/main.go +++ b/internal/generated/snippets/policysimulator/apiv1/SimulatorClient/GetReplay/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/policysimulator/apiv1/SimulatorClient/ListOperations/main.go b/internal/generated/snippets/policysimulator/apiv1/SimulatorClient/ListOperations/main.go index 3035f38b3a7a..ed0206379180 100644 --- a/internal/generated/snippets/policysimulator/apiv1/SimulatorClient/ListOperations/main.go +++ b/internal/generated/snippets/policysimulator/apiv1/SimulatorClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/policysimulator/apiv1/SimulatorClient/ListReplayResults/main.go b/internal/generated/snippets/policysimulator/apiv1/SimulatorClient/ListReplayResults/main.go index 9edf194e009c..0bdf99f4f4cb 100644 --- a/internal/generated/snippets/policysimulator/apiv1/SimulatorClient/ListReplayResults/main.go +++ b/internal/generated/snippets/policysimulator/apiv1/SimulatorClient/ListReplayResults/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/policytroubleshooter/apiv1/IamCheckerClient/TroubleshootIamPolicy/main.go b/internal/generated/snippets/policytroubleshooter/apiv1/IamCheckerClient/TroubleshootIamPolicy/main.go index 43028dca21db..2cf7349fa4a6 100644 --- a/internal/generated/snippets/policytroubleshooter/apiv1/IamCheckerClient/TroubleshootIamPolicy/main.go +++ b/internal/generated/snippets/policytroubleshooter/apiv1/IamCheckerClient/TroubleshootIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/policytroubleshooter/iam/apiv3/PolicyTroubleshooterClient/TroubleshootIamPolicy/main.go b/internal/generated/snippets/policytroubleshooter/iam/apiv3/PolicyTroubleshooterClient/TroubleshootIamPolicy/main.go index e7ea58cde5a4..89a81365851a 100644 --- a/internal/generated/snippets/policytroubleshooter/iam/apiv3/PolicyTroubleshooterClient/TroubleshootIamPolicy/main.go +++ b/internal/generated/snippets/policytroubleshooter/iam/apiv3/PolicyTroubleshooterClient/TroubleshootIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/privatecatalog/apiv1beta1/Client/SearchCatalogs/main.go b/internal/generated/snippets/privatecatalog/apiv1beta1/Client/SearchCatalogs/main.go index 03f5f8ac37a6..4bc4a1992055 100644 --- a/internal/generated/snippets/privatecatalog/apiv1beta1/Client/SearchCatalogs/main.go +++ b/internal/generated/snippets/privatecatalog/apiv1beta1/Client/SearchCatalogs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/privatecatalog/apiv1beta1/Client/SearchProducts/main.go b/internal/generated/snippets/privatecatalog/apiv1beta1/Client/SearchProducts/main.go index 25fb77b539a6..e5c4f6bae2ec 100644 --- a/internal/generated/snippets/privatecatalog/apiv1beta1/Client/SearchProducts/main.go +++ b/internal/generated/snippets/privatecatalog/apiv1beta1/Client/SearchProducts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/privatecatalog/apiv1beta1/Client/SearchVersions/main.go b/internal/generated/snippets/privatecatalog/apiv1beta1/Client/SearchVersions/main.go index dd2e8d0794c2..e4c6f21149f7 100644 --- a/internal/generated/snippets/privatecatalog/apiv1beta1/Client/SearchVersions/main.go +++ b/internal/generated/snippets/privatecatalog/apiv1beta1/Client/SearchVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/ApproveGrant/main.go b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/ApproveGrant/main.go index 390348b8851b..130f71cbfe6c 100644 --- a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/ApproveGrant/main.go +++ b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/ApproveGrant/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/CheckOnboardingStatus/main.go b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/CheckOnboardingStatus/main.go index 1f487a9a7c91..fa50581e8475 100644 --- a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/CheckOnboardingStatus/main.go +++ b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/CheckOnboardingStatus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/CreateEntitlement/main.go b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/CreateEntitlement/main.go index e7d39250ebba..fd2ae28f0886 100644 --- a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/CreateEntitlement/main.go +++ b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/CreateEntitlement/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/CreateGrant/main.go b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/CreateGrant/main.go index 5a65341170cc..7868bb0defe4 100644 --- a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/CreateGrant/main.go +++ b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/CreateGrant/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/DeleteEntitlement/main.go b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/DeleteEntitlement/main.go index db4407f2d19c..869a8b787b81 100644 --- a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/DeleteEntitlement/main.go +++ b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/DeleteEntitlement/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/DeleteOperation/main.go index 710ed1190e11..f7bb9d51a398 100644 --- a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/DenyGrant/main.go b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/DenyGrant/main.go index 8538545038d2..43d3cddcce05 100644 --- a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/DenyGrant/main.go +++ b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/DenyGrant/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/GetEntitlement/main.go b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/GetEntitlement/main.go index 366ca64c1fdb..9ac6e55e52f0 100644 --- a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/GetEntitlement/main.go +++ b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/GetEntitlement/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/GetGrant/main.go b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/GetGrant/main.go index 3dd39e4fba08..4bf702bc2de7 100644 --- a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/GetGrant/main.go +++ b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/GetGrant/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/GetLocation/main.go index aafa670dc481..6d087ea4e5bd 100644 --- a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/GetOperation/main.go index 7cfafc797bd9..cff74962adaf 100644 --- a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/ListEntitlements/main.go b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/ListEntitlements/main.go index c3ee0ba1a1d4..79f1fe404eef 100644 --- a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/ListEntitlements/main.go +++ b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/ListEntitlements/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/ListGrants/main.go b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/ListGrants/main.go index a59e075f282d..0f73f42982b7 100644 --- a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/ListGrants/main.go +++ b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/ListGrants/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/ListLocations/main.go index 35b053421701..cbb053883cc4 100644 --- a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/ListOperations/main.go index 8d0ea4ac7a0f..a02b86110642 100644 --- a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/RevokeGrant/main.go b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/RevokeGrant/main.go index bdcc7fbfd506..4b3f4d10950b 100644 --- a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/RevokeGrant/main.go +++ b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/RevokeGrant/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/SearchEntitlements/main.go b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/SearchEntitlements/main.go index b583c896d5f2..8ac2329d15e4 100644 --- a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/SearchEntitlements/main.go +++ b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/SearchEntitlements/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/SearchGrants/main.go b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/SearchGrants/main.go index 1ffb9f9d7875..0872102b29f3 100644 --- a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/SearchGrants/main.go +++ b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/SearchGrants/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/UpdateEntitlement/main.go b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/UpdateEntitlement/main.go index ad6491fb6e28..2aa75a0b40de 100644 --- a/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/UpdateEntitlement/main.go +++ b/internal/generated/snippets/privilegedaccessmanager/apiv1/Client/UpdateEntitlement/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/privilegedaccessmanager/apiv1/snippet_metadata.google.cloud.privilegedaccessmanager.v1.json b/internal/generated/snippets/privilegedaccessmanager/apiv1/snippet_metadata.google.cloud.privilegedaccessmanager.v1.json index 18a0eaa48af7..97991d27a5ff 100644 --- a/internal/generated/snippets/privilegedaccessmanager/apiv1/snippet_metadata.google.cloud.privilegedaccessmanager.v1.json +++ b/internal/generated/snippets/privilegedaccessmanager/apiv1/snippet_metadata.google.cloud.privilegedaccessmanager.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/privilegedaccessmanager/apiv1", - "version": "0.2.2", + "version": "0.2.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/pubsub/apiv1/PublisherClient/CreateTopic/main.go b/internal/generated/snippets/pubsub/apiv1/PublisherClient/CreateTopic/main.go index 6d8f2bc0bd34..741dee03248b 100644 --- a/internal/generated/snippets/pubsub/apiv1/PublisherClient/CreateTopic/main.go +++ b/internal/generated/snippets/pubsub/apiv1/PublisherClient/CreateTopic/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/PublisherClient/DeleteTopic/main.go b/internal/generated/snippets/pubsub/apiv1/PublisherClient/DeleteTopic/main.go index 9b8c62730414..eea03b00d1c5 100644 --- a/internal/generated/snippets/pubsub/apiv1/PublisherClient/DeleteTopic/main.go +++ b/internal/generated/snippets/pubsub/apiv1/PublisherClient/DeleteTopic/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/PublisherClient/DetachSubscription/main.go b/internal/generated/snippets/pubsub/apiv1/PublisherClient/DetachSubscription/main.go index 5203b966bb70..0584e5a21d55 100644 --- a/internal/generated/snippets/pubsub/apiv1/PublisherClient/DetachSubscription/main.go +++ b/internal/generated/snippets/pubsub/apiv1/PublisherClient/DetachSubscription/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/PublisherClient/GetIamPolicy/main.go b/internal/generated/snippets/pubsub/apiv1/PublisherClient/GetIamPolicy/main.go index 3ea0d59fa215..35a64c402e09 100644 --- a/internal/generated/snippets/pubsub/apiv1/PublisherClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/pubsub/apiv1/PublisherClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/PublisherClient/GetTopic/main.go b/internal/generated/snippets/pubsub/apiv1/PublisherClient/GetTopic/main.go index ec064068b2cc..e7782d3d1530 100644 --- a/internal/generated/snippets/pubsub/apiv1/PublisherClient/GetTopic/main.go +++ b/internal/generated/snippets/pubsub/apiv1/PublisherClient/GetTopic/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/PublisherClient/ListTopicSnapshots/main.go b/internal/generated/snippets/pubsub/apiv1/PublisherClient/ListTopicSnapshots/main.go index b65f6d1ae4d5..d8d60106dd6f 100644 --- a/internal/generated/snippets/pubsub/apiv1/PublisherClient/ListTopicSnapshots/main.go +++ b/internal/generated/snippets/pubsub/apiv1/PublisherClient/ListTopicSnapshots/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/PublisherClient/ListTopicSubscriptions/main.go b/internal/generated/snippets/pubsub/apiv1/PublisherClient/ListTopicSubscriptions/main.go index 766d9e3fa3f9..c8823c2860c1 100644 --- a/internal/generated/snippets/pubsub/apiv1/PublisherClient/ListTopicSubscriptions/main.go +++ b/internal/generated/snippets/pubsub/apiv1/PublisherClient/ListTopicSubscriptions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/PublisherClient/ListTopics/main.go b/internal/generated/snippets/pubsub/apiv1/PublisherClient/ListTopics/main.go index 8ec19ba05b54..5b89028723ea 100644 --- a/internal/generated/snippets/pubsub/apiv1/PublisherClient/ListTopics/main.go +++ b/internal/generated/snippets/pubsub/apiv1/PublisherClient/ListTopics/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/PublisherClient/Publish/main.go b/internal/generated/snippets/pubsub/apiv1/PublisherClient/Publish/main.go index 088bcbb68a52..449937a30434 100644 --- a/internal/generated/snippets/pubsub/apiv1/PublisherClient/Publish/main.go +++ b/internal/generated/snippets/pubsub/apiv1/PublisherClient/Publish/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/PublisherClient/SetIamPolicy/main.go b/internal/generated/snippets/pubsub/apiv1/PublisherClient/SetIamPolicy/main.go index 29969a6f6150..9b976f09dd9c 100644 --- a/internal/generated/snippets/pubsub/apiv1/PublisherClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/pubsub/apiv1/PublisherClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/PublisherClient/TestIamPermissions/main.go b/internal/generated/snippets/pubsub/apiv1/PublisherClient/TestIamPermissions/main.go index 380edb1f2195..efe880013448 100644 --- a/internal/generated/snippets/pubsub/apiv1/PublisherClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/pubsub/apiv1/PublisherClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/PublisherClient/UpdateTopic/main.go b/internal/generated/snippets/pubsub/apiv1/PublisherClient/UpdateTopic/main.go index 7f4f958581f2..a82225ee5011 100644 --- a/internal/generated/snippets/pubsub/apiv1/PublisherClient/UpdateTopic/main.go +++ b/internal/generated/snippets/pubsub/apiv1/PublisherClient/UpdateTopic/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SchemaClient/CommitSchema/main.go b/internal/generated/snippets/pubsub/apiv1/SchemaClient/CommitSchema/main.go index 5f50cec56be7..f6872a2f26a1 100644 --- a/internal/generated/snippets/pubsub/apiv1/SchemaClient/CommitSchema/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SchemaClient/CommitSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SchemaClient/CreateSchema/main.go b/internal/generated/snippets/pubsub/apiv1/SchemaClient/CreateSchema/main.go index 38cd6a995859..17dfaa177424 100644 --- a/internal/generated/snippets/pubsub/apiv1/SchemaClient/CreateSchema/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SchemaClient/CreateSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SchemaClient/DeleteSchema/main.go b/internal/generated/snippets/pubsub/apiv1/SchemaClient/DeleteSchema/main.go index 2986f3e3add9..33cb57d7b611 100644 --- a/internal/generated/snippets/pubsub/apiv1/SchemaClient/DeleteSchema/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SchemaClient/DeleteSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SchemaClient/DeleteSchemaRevision/main.go b/internal/generated/snippets/pubsub/apiv1/SchemaClient/DeleteSchemaRevision/main.go index 7d73f8efe918..b8c1e717e928 100644 --- a/internal/generated/snippets/pubsub/apiv1/SchemaClient/DeleteSchemaRevision/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SchemaClient/DeleteSchemaRevision/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SchemaClient/GetIamPolicy/main.go b/internal/generated/snippets/pubsub/apiv1/SchemaClient/GetIamPolicy/main.go index 8f7d6e9323c9..4862b97b3094 100644 --- a/internal/generated/snippets/pubsub/apiv1/SchemaClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SchemaClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SchemaClient/GetSchema/main.go b/internal/generated/snippets/pubsub/apiv1/SchemaClient/GetSchema/main.go index 138bc4f4f55d..51047f1ee665 100644 --- a/internal/generated/snippets/pubsub/apiv1/SchemaClient/GetSchema/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SchemaClient/GetSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SchemaClient/ListSchemaRevisions/main.go b/internal/generated/snippets/pubsub/apiv1/SchemaClient/ListSchemaRevisions/main.go index bf73076d8870..2bf827725e07 100644 --- a/internal/generated/snippets/pubsub/apiv1/SchemaClient/ListSchemaRevisions/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SchemaClient/ListSchemaRevisions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SchemaClient/ListSchemas/main.go b/internal/generated/snippets/pubsub/apiv1/SchemaClient/ListSchemas/main.go index 9669206b55d0..27b7b2e6e61b 100644 --- a/internal/generated/snippets/pubsub/apiv1/SchemaClient/ListSchemas/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SchemaClient/ListSchemas/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SchemaClient/RollbackSchema/main.go b/internal/generated/snippets/pubsub/apiv1/SchemaClient/RollbackSchema/main.go index aabb6d294db1..357ad026748f 100644 --- a/internal/generated/snippets/pubsub/apiv1/SchemaClient/RollbackSchema/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SchemaClient/RollbackSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SchemaClient/SetIamPolicy/main.go b/internal/generated/snippets/pubsub/apiv1/SchemaClient/SetIamPolicy/main.go index 7c7a5af4732c..a5061248b4a9 100644 --- a/internal/generated/snippets/pubsub/apiv1/SchemaClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SchemaClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SchemaClient/TestIamPermissions/main.go b/internal/generated/snippets/pubsub/apiv1/SchemaClient/TestIamPermissions/main.go index f97a5cfe086e..4cb1284913c1 100644 --- a/internal/generated/snippets/pubsub/apiv1/SchemaClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SchemaClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SchemaClient/ValidateMessage/main.go b/internal/generated/snippets/pubsub/apiv1/SchemaClient/ValidateMessage/main.go index d8ff787a9130..55b6f5ed13b6 100644 --- a/internal/generated/snippets/pubsub/apiv1/SchemaClient/ValidateMessage/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SchemaClient/ValidateMessage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SchemaClient/ValidateSchema/main.go b/internal/generated/snippets/pubsub/apiv1/SchemaClient/ValidateSchema/main.go index 7b4bdc0cafe4..14df3d910311 100644 --- a/internal/generated/snippets/pubsub/apiv1/SchemaClient/ValidateSchema/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SchemaClient/ValidateSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/Acknowledge/main.go b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/Acknowledge/main.go index 1faa2ff27ea8..5da002f1d0d4 100644 --- a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/Acknowledge/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/Acknowledge/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/CreateSnapshot/main.go b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/CreateSnapshot/main.go index 220e028b87c7..b9b90091a24e 100644 --- a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/CreateSnapshot/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/CreateSnapshot/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/CreateSubscription/main.go b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/CreateSubscription/main.go index 1cc3263253eb..8e901c0775d2 100644 --- a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/CreateSubscription/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/CreateSubscription/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/DeleteSnapshot/main.go b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/DeleteSnapshot/main.go index 868cdd6f353b..215c57e7f4bc 100644 --- a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/DeleteSnapshot/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/DeleteSnapshot/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/DeleteSubscription/main.go b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/DeleteSubscription/main.go index 5bcf695b0d2f..5bdc21456ff2 100644 --- a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/DeleteSubscription/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/DeleteSubscription/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/GetIamPolicy/main.go b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/GetIamPolicy/main.go index 684783965098..f7a60fc34685 100644 --- a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/GetSnapshot/main.go b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/GetSnapshot/main.go index 39918aae43f5..c1c98606196c 100644 --- a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/GetSnapshot/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/GetSnapshot/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/GetSubscription/main.go b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/GetSubscription/main.go index ac4104c59243..94ecdc13b46c 100644 --- a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/GetSubscription/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/GetSubscription/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/ListSnapshots/main.go b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/ListSnapshots/main.go index d5a3eb35f5fd..b3114d17fb8f 100644 --- a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/ListSnapshots/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/ListSnapshots/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/ListSubscriptions/main.go b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/ListSubscriptions/main.go index 08a9e2f1e61b..c01fbefabb10 100644 --- a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/ListSubscriptions/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/ListSubscriptions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/ModifyAckDeadline/main.go b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/ModifyAckDeadline/main.go index 98351e6aa440..235d99789995 100644 --- a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/ModifyAckDeadline/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/ModifyAckDeadline/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/ModifyPushConfig/main.go b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/ModifyPushConfig/main.go index 764ee9a1c801..8eafe331dc31 100644 --- a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/ModifyPushConfig/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/ModifyPushConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/Pull/main.go b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/Pull/main.go index ca02901bcd39..4f5e8a78f2ae 100644 --- a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/Pull/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/Pull/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/Seek/main.go b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/Seek/main.go index d4adf1bbd50e..af60bfff2aee 100644 --- a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/Seek/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/Seek/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/SetIamPolicy/main.go b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/SetIamPolicy/main.go index 16a9d24e44de..189a54d35a2c 100644 --- a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/StreamingPull/main.go b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/StreamingPull/main.go index 302a69036524..22c1979d5941 100644 --- a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/StreamingPull/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/StreamingPull/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/TestIamPermissions/main.go b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/TestIamPermissions/main.go index 1428521ab4e8..0b1e87cba09f 100644 --- a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/UpdateSnapshot/main.go b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/UpdateSnapshot/main.go index 44eebb097ae6..33ffccb05aac 100644 --- a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/UpdateSnapshot/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/UpdateSnapshot/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/UpdateSubscription/main.go b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/UpdateSubscription/main.go index 63fb20f8c9d1..15a95d74ac97 100644 --- a/internal/generated/snippets/pubsub/apiv1/SubscriberClient/UpdateSubscription/main.go +++ b/internal/generated/snippets/pubsub/apiv1/SubscriberClient/UpdateSubscription/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/AdminClient/CancelOperation/main.go b/internal/generated/snippets/pubsublite/apiv1/AdminClient/CancelOperation/main.go index dcecb3fe08fb..07859dc4e2c4 100644 --- a/internal/generated/snippets/pubsublite/apiv1/AdminClient/CancelOperation/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/AdminClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/AdminClient/CreateReservation/main.go b/internal/generated/snippets/pubsublite/apiv1/AdminClient/CreateReservation/main.go index 5869986150c9..11e8ec17d24a 100644 --- a/internal/generated/snippets/pubsublite/apiv1/AdminClient/CreateReservation/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/AdminClient/CreateReservation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/AdminClient/CreateSubscription/main.go b/internal/generated/snippets/pubsublite/apiv1/AdminClient/CreateSubscription/main.go index ae0cfc3b74a2..410f46e46e27 100644 --- a/internal/generated/snippets/pubsublite/apiv1/AdminClient/CreateSubscription/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/AdminClient/CreateSubscription/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/AdminClient/CreateTopic/main.go b/internal/generated/snippets/pubsublite/apiv1/AdminClient/CreateTopic/main.go index 5707dd709a36..e8c3f880d549 100644 --- a/internal/generated/snippets/pubsublite/apiv1/AdminClient/CreateTopic/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/AdminClient/CreateTopic/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/AdminClient/DeleteOperation/main.go b/internal/generated/snippets/pubsublite/apiv1/AdminClient/DeleteOperation/main.go index 852ea799c9c2..90a3b6369810 100644 --- a/internal/generated/snippets/pubsublite/apiv1/AdminClient/DeleteOperation/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/AdminClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/AdminClient/DeleteReservation/main.go b/internal/generated/snippets/pubsublite/apiv1/AdminClient/DeleteReservation/main.go index ffb89ce7e3a4..de4861b49486 100644 --- a/internal/generated/snippets/pubsublite/apiv1/AdminClient/DeleteReservation/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/AdminClient/DeleteReservation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/AdminClient/DeleteSubscription/main.go b/internal/generated/snippets/pubsublite/apiv1/AdminClient/DeleteSubscription/main.go index 4fefe414a086..fc5c67160e5c 100644 --- a/internal/generated/snippets/pubsublite/apiv1/AdminClient/DeleteSubscription/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/AdminClient/DeleteSubscription/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/AdminClient/DeleteTopic/main.go b/internal/generated/snippets/pubsublite/apiv1/AdminClient/DeleteTopic/main.go index c460f5df9535..89bd36ae622f 100644 --- a/internal/generated/snippets/pubsublite/apiv1/AdminClient/DeleteTopic/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/AdminClient/DeleteTopic/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/AdminClient/GetOperation/main.go b/internal/generated/snippets/pubsublite/apiv1/AdminClient/GetOperation/main.go index 008f3fc45acc..cad9a6e3f293 100644 --- a/internal/generated/snippets/pubsublite/apiv1/AdminClient/GetOperation/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/AdminClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/AdminClient/GetReservation/main.go b/internal/generated/snippets/pubsublite/apiv1/AdminClient/GetReservation/main.go index 1ee7bf70270a..c7fc83fc176a 100644 --- a/internal/generated/snippets/pubsublite/apiv1/AdminClient/GetReservation/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/AdminClient/GetReservation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/AdminClient/GetSubscription/main.go b/internal/generated/snippets/pubsublite/apiv1/AdminClient/GetSubscription/main.go index 0af7bc9a2145..6c58e63dffde 100644 --- a/internal/generated/snippets/pubsublite/apiv1/AdminClient/GetSubscription/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/AdminClient/GetSubscription/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/AdminClient/GetTopic/main.go b/internal/generated/snippets/pubsublite/apiv1/AdminClient/GetTopic/main.go index 9d9a7e006404..d0493a60a793 100644 --- a/internal/generated/snippets/pubsublite/apiv1/AdminClient/GetTopic/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/AdminClient/GetTopic/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/AdminClient/GetTopicPartitions/main.go b/internal/generated/snippets/pubsublite/apiv1/AdminClient/GetTopicPartitions/main.go index 62550a399508..c5e481735bb4 100644 --- a/internal/generated/snippets/pubsublite/apiv1/AdminClient/GetTopicPartitions/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/AdminClient/GetTopicPartitions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/AdminClient/ListOperations/main.go b/internal/generated/snippets/pubsublite/apiv1/AdminClient/ListOperations/main.go index 1dc4028a5e29..85b9de1cb556 100644 --- a/internal/generated/snippets/pubsublite/apiv1/AdminClient/ListOperations/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/AdminClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/AdminClient/ListReservationTopics/main.go b/internal/generated/snippets/pubsublite/apiv1/AdminClient/ListReservationTopics/main.go index 295e8a051814..e307a4f74ce3 100644 --- a/internal/generated/snippets/pubsublite/apiv1/AdminClient/ListReservationTopics/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/AdminClient/ListReservationTopics/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/AdminClient/ListReservations/main.go b/internal/generated/snippets/pubsublite/apiv1/AdminClient/ListReservations/main.go index 5dfecca57004..7548799febad 100644 --- a/internal/generated/snippets/pubsublite/apiv1/AdminClient/ListReservations/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/AdminClient/ListReservations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/AdminClient/ListSubscriptions/main.go b/internal/generated/snippets/pubsublite/apiv1/AdminClient/ListSubscriptions/main.go index 793cde8ba59c..749776942386 100644 --- a/internal/generated/snippets/pubsublite/apiv1/AdminClient/ListSubscriptions/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/AdminClient/ListSubscriptions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/AdminClient/ListTopicSubscriptions/main.go b/internal/generated/snippets/pubsublite/apiv1/AdminClient/ListTopicSubscriptions/main.go index 2b7425c7f5f3..8a2e7158e713 100644 --- a/internal/generated/snippets/pubsublite/apiv1/AdminClient/ListTopicSubscriptions/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/AdminClient/ListTopicSubscriptions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/AdminClient/ListTopics/main.go b/internal/generated/snippets/pubsublite/apiv1/AdminClient/ListTopics/main.go index 35142b182c35..b31802128068 100644 --- a/internal/generated/snippets/pubsublite/apiv1/AdminClient/ListTopics/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/AdminClient/ListTopics/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/AdminClient/SeekSubscription/main.go b/internal/generated/snippets/pubsublite/apiv1/AdminClient/SeekSubscription/main.go index c0c529018035..ef7352278b97 100644 --- a/internal/generated/snippets/pubsublite/apiv1/AdminClient/SeekSubscription/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/AdminClient/SeekSubscription/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/AdminClient/UpdateReservation/main.go b/internal/generated/snippets/pubsublite/apiv1/AdminClient/UpdateReservation/main.go index 785d03dbec1a..a246059a16b4 100644 --- a/internal/generated/snippets/pubsublite/apiv1/AdminClient/UpdateReservation/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/AdminClient/UpdateReservation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/AdminClient/UpdateSubscription/main.go b/internal/generated/snippets/pubsublite/apiv1/AdminClient/UpdateSubscription/main.go index a2b513e6d795..9ab369bc5d79 100644 --- a/internal/generated/snippets/pubsublite/apiv1/AdminClient/UpdateSubscription/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/AdminClient/UpdateSubscription/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/AdminClient/UpdateTopic/main.go b/internal/generated/snippets/pubsublite/apiv1/AdminClient/UpdateTopic/main.go index 4fc0258d442b..56aa5774286d 100644 --- a/internal/generated/snippets/pubsublite/apiv1/AdminClient/UpdateTopic/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/AdminClient/UpdateTopic/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/CursorClient/CancelOperation/main.go b/internal/generated/snippets/pubsublite/apiv1/CursorClient/CancelOperation/main.go index 0c1345195a1c..24e129706067 100644 --- a/internal/generated/snippets/pubsublite/apiv1/CursorClient/CancelOperation/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/CursorClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/CursorClient/CommitCursor/main.go b/internal/generated/snippets/pubsublite/apiv1/CursorClient/CommitCursor/main.go index 05f6d8bd35bd..22738c3171da 100644 --- a/internal/generated/snippets/pubsublite/apiv1/CursorClient/CommitCursor/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/CursorClient/CommitCursor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/CursorClient/DeleteOperation/main.go b/internal/generated/snippets/pubsublite/apiv1/CursorClient/DeleteOperation/main.go index a946836a1c9f..0707da6ab736 100644 --- a/internal/generated/snippets/pubsublite/apiv1/CursorClient/DeleteOperation/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/CursorClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/CursorClient/GetOperation/main.go b/internal/generated/snippets/pubsublite/apiv1/CursorClient/GetOperation/main.go index 5c259c234f48..766ba4ac4067 100644 --- a/internal/generated/snippets/pubsublite/apiv1/CursorClient/GetOperation/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/CursorClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/CursorClient/ListOperations/main.go b/internal/generated/snippets/pubsublite/apiv1/CursorClient/ListOperations/main.go index 99260b88597e..430a9a71018a 100644 --- a/internal/generated/snippets/pubsublite/apiv1/CursorClient/ListOperations/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/CursorClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/CursorClient/ListPartitionCursors/main.go b/internal/generated/snippets/pubsublite/apiv1/CursorClient/ListPartitionCursors/main.go index b1f3bdda559a..47924129c573 100644 --- a/internal/generated/snippets/pubsublite/apiv1/CursorClient/ListPartitionCursors/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/CursorClient/ListPartitionCursors/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/CursorClient/StreamingCommitCursor/main.go b/internal/generated/snippets/pubsublite/apiv1/CursorClient/StreamingCommitCursor/main.go index cd49efce4f0e..fcf85d29bccf 100644 --- a/internal/generated/snippets/pubsublite/apiv1/CursorClient/StreamingCommitCursor/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/CursorClient/StreamingCommitCursor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/PartitionAssignmentClient/AssignPartitions/main.go b/internal/generated/snippets/pubsublite/apiv1/PartitionAssignmentClient/AssignPartitions/main.go index c975b09d2eb6..333803f6a413 100644 --- a/internal/generated/snippets/pubsublite/apiv1/PartitionAssignmentClient/AssignPartitions/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/PartitionAssignmentClient/AssignPartitions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/PartitionAssignmentClient/CancelOperation/main.go b/internal/generated/snippets/pubsublite/apiv1/PartitionAssignmentClient/CancelOperation/main.go index 4e3397dc65bb..a36a26760879 100644 --- a/internal/generated/snippets/pubsublite/apiv1/PartitionAssignmentClient/CancelOperation/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/PartitionAssignmentClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/PartitionAssignmentClient/DeleteOperation/main.go b/internal/generated/snippets/pubsublite/apiv1/PartitionAssignmentClient/DeleteOperation/main.go index 61e56b8fd987..ee8611b5982e 100644 --- a/internal/generated/snippets/pubsublite/apiv1/PartitionAssignmentClient/DeleteOperation/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/PartitionAssignmentClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/PartitionAssignmentClient/GetOperation/main.go b/internal/generated/snippets/pubsublite/apiv1/PartitionAssignmentClient/GetOperation/main.go index 33b309784eab..a49c146878af 100644 --- a/internal/generated/snippets/pubsublite/apiv1/PartitionAssignmentClient/GetOperation/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/PartitionAssignmentClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/PartitionAssignmentClient/ListOperations/main.go b/internal/generated/snippets/pubsublite/apiv1/PartitionAssignmentClient/ListOperations/main.go index fc44079abe4e..c3bcc6892f72 100644 --- a/internal/generated/snippets/pubsublite/apiv1/PartitionAssignmentClient/ListOperations/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/PartitionAssignmentClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/PublisherClient/CancelOperation/main.go b/internal/generated/snippets/pubsublite/apiv1/PublisherClient/CancelOperation/main.go index 03eee8d60200..f6b4a645511f 100644 --- a/internal/generated/snippets/pubsublite/apiv1/PublisherClient/CancelOperation/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/PublisherClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/PublisherClient/DeleteOperation/main.go b/internal/generated/snippets/pubsublite/apiv1/PublisherClient/DeleteOperation/main.go index 9679069b525f..0df29867509c 100644 --- a/internal/generated/snippets/pubsublite/apiv1/PublisherClient/DeleteOperation/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/PublisherClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/PublisherClient/GetOperation/main.go b/internal/generated/snippets/pubsublite/apiv1/PublisherClient/GetOperation/main.go index 0bd81cef571c..2f7d4874faae 100644 --- a/internal/generated/snippets/pubsublite/apiv1/PublisherClient/GetOperation/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/PublisherClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/PublisherClient/ListOperations/main.go b/internal/generated/snippets/pubsublite/apiv1/PublisherClient/ListOperations/main.go index 31a634827713..e50d333badbf 100644 --- a/internal/generated/snippets/pubsublite/apiv1/PublisherClient/ListOperations/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/PublisherClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/PublisherClient/Publish/main.go b/internal/generated/snippets/pubsublite/apiv1/PublisherClient/Publish/main.go index 4a3fa2b745d2..a12d55c2411a 100644 --- a/internal/generated/snippets/pubsublite/apiv1/PublisherClient/Publish/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/PublisherClient/Publish/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/SubscriberClient/CancelOperation/main.go b/internal/generated/snippets/pubsublite/apiv1/SubscriberClient/CancelOperation/main.go index be128999472b..6581d3ca5d18 100644 --- a/internal/generated/snippets/pubsublite/apiv1/SubscriberClient/CancelOperation/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/SubscriberClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/SubscriberClient/DeleteOperation/main.go b/internal/generated/snippets/pubsublite/apiv1/SubscriberClient/DeleteOperation/main.go index 12d90695d2cc..a9e32b787dac 100644 --- a/internal/generated/snippets/pubsublite/apiv1/SubscriberClient/DeleteOperation/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/SubscriberClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/SubscriberClient/GetOperation/main.go b/internal/generated/snippets/pubsublite/apiv1/SubscriberClient/GetOperation/main.go index 922c9da2cd03..34514b8588e9 100644 --- a/internal/generated/snippets/pubsublite/apiv1/SubscriberClient/GetOperation/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/SubscriberClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/SubscriberClient/ListOperations/main.go b/internal/generated/snippets/pubsublite/apiv1/SubscriberClient/ListOperations/main.go index e45858b3f30e..a4a669e72324 100644 --- a/internal/generated/snippets/pubsublite/apiv1/SubscriberClient/ListOperations/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/SubscriberClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/SubscriberClient/Subscribe/main.go b/internal/generated/snippets/pubsublite/apiv1/SubscriberClient/Subscribe/main.go index 72136d542370..a0f795702061 100644 --- a/internal/generated/snippets/pubsublite/apiv1/SubscriberClient/Subscribe/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/SubscriberClient/Subscribe/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/TopicStatsClient/CancelOperation/main.go b/internal/generated/snippets/pubsublite/apiv1/TopicStatsClient/CancelOperation/main.go index 95e50aa37531..87d14a4a51ef 100644 --- a/internal/generated/snippets/pubsublite/apiv1/TopicStatsClient/CancelOperation/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/TopicStatsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/TopicStatsClient/ComputeHeadCursor/main.go b/internal/generated/snippets/pubsublite/apiv1/TopicStatsClient/ComputeHeadCursor/main.go index 45886d665384..ca328113d8f5 100644 --- a/internal/generated/snippets/pubsublite/apiv1/TopicStatsClient/ComputeHeadCursor/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/TopicStatsClient/ComputeHeadCursor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/TopicStatsClient/ComputeMessageStats/main.go b/internal/generated/snippets/pubsublite/apiv1/TopicStatsClient/ComputeMessageStats/main.go index d8cbfaa4066b..cf631f4b6f41 100644 --- a/internal/generated/snippets/pubsublite/apiv1/TopicStatsClient/ComputeMessageStats/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/TopicStatsClient/ComputeMessageStats/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/TopicStatsClient/ComputeTimeCursor/main.go b/internal/generated/snippets/pubsublite/apiv1/TopicStatsClient/ComputeTimeCursor/main.go index efad1766c73e..a77815d766ec 100644 --- a/internal/generated/snippets/pubsublite/apiv1/TopicStatsClient/ComputeTimeCursor/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/TopicStatsClient/ComputeTimeCursor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/TopicStatsClient/DeleteOperation/main.go b/internal/generated/snippets/pubsublite/apiv1/TopicStatsClient/DeleteOperation/main.go index 0b540dcbcc1a..d7318164e1a9 100644 --- a/internal/generated/snippets/pubsublite/apiv1/TopicStatsClient/DeleteOperation/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/TopicStatsClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/TopicStatsClient/GetOperation/main.go b/internal/generated/snippets/pubsublite/apiv1/TopicStatsClient/GetOperation/main.go index 4c48310f1680..ddfb0898ba54 100644 --- a/internal/generated/snippets/pubsublite/apiv1/TopicStatsClient/GetOperation/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/TopicStatsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/pubsublite/apiv1/TopicStatsClient/ListOperations/main.go b/internal/generated/snippets/pubsublite/apiv1/TopicStatsClient/ListOperations/main.go index 21d059a590a4..89d9582493ac 100644 --- a/internal/generated/snippets/pubsublite/apiv1/TopicStatsClient/ListOperations/main.go +++ b/internal/generated/snippets/pubsublite/apiv1/TopicStatsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/CancelOperation/main.go index 15bd8cf46abe..03dcf86733d0 100644 --- a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/CreateAnnotation/main.go b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/CreateAnnotation/main.go index 8e0144934541..4432d92a8349 100644 --- a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/CreateAnnotation/main.go +++ b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/CreateAnnotation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/CreateCollector/main.go b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/CreateCollector/main.go index 18a12506ed7f..97f36c02b614 100644 --- a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/CreateCollector/main.go +++ b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/CreateCollector/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/DeleteCollector/main.go b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/DeleteCollector/main.go index c10c6ed3e8f1..692be093db93 100644 --- a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/DeleteCollector/main.go +++ b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/DeleteCollector/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/DeleteOperation/main.go index 19be18c8d037..e83a8f6babef 100644 --- a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/GetAnnotation/main.go b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/GetAnnotation/main.go index bc53cf580f6d..ad3ee8fbd6bd 100644 --- a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/GetAnnotation/main.go +++ b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/GetAnnotation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/GetCollector/main.go b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/GetCollector/main.go index 5ffc4290ef26..0f5f351d3b4a 100644 --- a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/GetCollector/main.go +++ b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/GetCollector/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/GetLocation/main.go index b394d3b05e72..f330ad71551c 100644 --- a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/GetOperation/main.go index 955c5c5dd149..560ac165f545 100644 --- a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/ListCollectors/main.go b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/ListCollectors/main.go index fe51e7065e1b..be8015b84e58 100644 --- a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/ListCollectors/main.go +++ b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/ListCollectors/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/ListLocations/main.go index ebce7071cd7b..7b64e4b3052b 100644 --- a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/ListOperations/main.go index eb842142c4fd..2b0d04452507 100644 --- a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/PauseCollector/main.go b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/PauseCollector/main.go index 0df3e71abda4..e5ea21d5aa23 100644 --- a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/PauseCollector/main.go +++ b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/PauseCollector/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/RegisterCollector/main.go b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/RegisterCollector/main.go index 3a0e4a122377..f06e19a8ecf1 100644 --- a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/RegisterCollector/main.go +++ b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/RegisterCollector/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/ResumeCollector/main.go b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/ResumeCollector/main.go index 5f4a79b93bce..c8141cf69dc0 100644 --- a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/ResumeCollector/main.go +++ b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/ResumeCollector/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/UpdateCollector/main.go b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/UpdateCollector/main.go index ba8bdd3a67a3..88009fefc116 100644 --- a/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/UpdateCollector/main.go +++ b/internal/generated/snippets/rapidmigrationassessment/apiv1/Client/UpdateCollector/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/AddIpOverride/main.go b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/AddIpOverride/main.go index e56717de930b..2ab2113d7b86 100644 --- a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/AddIpOverride/main.go +++ b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/AddIpOverride/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/AnnotateAssessment/main.go b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/AnnotateAssessment/main.go index 0f96d123d573..6e3bbd84b33f 100644 --- a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/AnnotateAssessment/main.go +++ b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/AnnotateAssessment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/CreateAssessment/main.go b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/CreateAssessment/main.go index 0c683341e23c..2ed7fe6da435 100644 --- a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/CreateAssessment/main.go +++ b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/CreateAssessment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/CreateFirewallPolicy/main.go b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/CreateFirewallPolicy/main.go index ff3729e6e192..d87b011c8651 100644 --- a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/CreateFirewallPolicy/main.go +++ b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/CreateFirewallPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/CreateKey/main.go b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/CreateKey/main.go index 210392e77bc6..74d33e17c95e 100644 --- a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/CreateKey/main.go +++ b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/CreateKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/DeleteFirewallPolicy/main.go b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/DeleteFirewallPolicy/main.go index d0be0b2289fa..16c413862e8d 100644 --- a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/DeleteFirewallPolicy/main.go +++ b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/DeleteFirewallPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/DeleteKey/main.go b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/DeleteKey/main.go index 52440bd5f4b3..e96e1879e0f0 100644 --- a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/DeleteKey/main.go +++ b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/DeleteKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/GetFirewallPolicy/main.go b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/GetFirewallPolicy/main.go index 9a79043dc8d3..119c9b5096ec 100644 --- a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/GetFirewallPolicy/main.go +++ b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/GetFirewallPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/GetKey/main.go b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/GetKey/main.go index 62cd22ecc491..40b464d541e6 100644 --- a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/GetKey/main.go +++ b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/GetKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/GetMetrics/main.go b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/GetMetrics/main.go index f954ca4cda3d..83f8651b7fd3 100644 --- a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/GetMetrics/main.go +++ b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/GetMetrics/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/ListFirewallPolicies/main.go b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/ListFirewallPolicies/main.go index 43c002885cf4..a34a0f72b499 100644 --- a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/ListFirewallPolicies/main.go +++ b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/ListFirewallPolicies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/ListIpOverrides/main.go b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/ListIpOverrides/main.go index 0f2da9224dc0..1d0e14caa6fb 100644 --- a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/ListIpOverrides/main.go +++ b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/ListIpOverrides/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/ListKeys/main.go b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/ListKeys/main.go index 9531145a9ca1..473e353eb163 100644 --- a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/ListKeys/main.go +++ b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/ListKeys/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/ListRelatedAccountGroupMemberships/main.go b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/ListRelatedAccountGroupMemberships/main.go index c970f5a944ab..f180d9c02f6a 100644 --- a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/ListRelatedAccountGroupMemberships/main.go +++ b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/ListRelatedAccountGroupMemberships/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/ListRelatedAccountGroups/main.go b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/ListRelatedAccountGroups/main.go index 1ea4ad92e88e..fadae63c333e 100644 --- a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/ListRelatedAccountGroups/main.go +++ b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/ListRelatedAccountGroups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/MigrateKey/main.go b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/MigrateKey/main.go index f0e8fbd4a069..9a464abcb379 100644 --- a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/MigrateKey/main.go +++ b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/MigrateKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/RemoveIpOverride/main.go b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/RemoveIpOverride/main.go index 455200d44583..55a05db8b3ad 100644 --- a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/RemoveIpOverride/main.go +++ b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/RemoveIpOverride/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/ReorderFirewallPolicies/main.go b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/ReorderFirewallPolicies/main.go index 67e64fdcae40..019ff690db2b 100644 --- a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/ReorderFirewallPolicies/main.go +++ b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/ReorderFirewallPolicies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/RetrieveLegacySecretKey/main.go b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/RetrieveLegacySecretKey/main.go index 9a2441d7cc67..72f250ad4bd3 100644 --- a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/RetrieveLegacySecretKey/main.go +++ b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/RetrieveLegacySecretKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/SearchRelatedAccountGroupMemberships/main.go b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/SearchRelatedAccountGroupMemberships/main.go index fe2a2b5e0cda..6cf685e0c4fe 100644 --- a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/SearchRelatedAccountGroupMemberships/main.go +++ b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/SearchRelatedAccountGroupMemberships/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/UpdateFirewallPolicy/main.go b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/UpdateFirewallPolicy/main.go index 10424666bf48..2ba29e42d513 100644 --- a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/UpdateFirewallPolicy/main.go +++ b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/UpdateFirewallPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/UpdateKey/main.go b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/UpdateKey/main.go index d523fbe22413..a42e4e602ff6 100644 --- a/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/UpdateKey/main.go +++ b/internal/generated/snippets/recaptchaenterprise/v2/apiv1/Client/UpdateKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recaptchaenterprise/v2/apiv1beta1/RecaptchaEnterpriseServiceV1Beta1Client/AnnotateAssessment/main.go b/internal/generated/snippets/recaptchaenterprise/v2/apiv1beta1/RecaptchaEnterpriseServiceV1Beta1Client/AnnotateAssessment/main.go index f791e2e020e0..3fece5d54445 100644 --- a/internal/generated/snippets/recaptchaenterprise/v2/apiv1beta1/RecaptchaEnterpriseServiceV1Beta1Client/AnnotateAssessment/main.go +++ b/internal/generated/snippets/recaptchaenterprise/v2/apiv1beta1/RecaptchaEnterpriseServiceV1Beta1Client/AnnotateAssessment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recaptchaenterprise/v2/apiv1beta1/RecaptchaEnterpriseServiceV1Beta1Client/CreateAssessment/main.go b/internal/generated/snippets/recaptchaenterprise/v2/apiv1beta1/RecaptchaEnterpriseServiceV1Beta1Client/CreateAssessment/main.go index a41aa90ac849..c2593b6df066 100644 --- a/internal/generated/snippets/recaptchaenterprise/v2/apiv1beta1/RecaptchaEnterpriseServiceV1Beta1Client/CreateAssessment/main.go +++ b/internal/generated/snippets/recaptchaenterprise/v2/apiv1beta1/RecaptchaEnterpriseServiceV1Beta1Client/CreateAssessment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommendationengine/apiv1beta1/CatalogClient/CreateCatalogItem/main.go b/internal/generated/snippets/recommendationengine/apiv1beta1/CatalogClient/CreateCatalogItem/main.go index 9e66e0b56b36..570df1a426d5 100644 --- a/internal/generated/snippets/recommendationengine/apiv1beta1/CatalogClient/CreateCatalogItem/main.go +++ b/internal/generated/snippets/recommendationengine/apiv1beta1/CatalogClient/CreateCatalogItem/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommendationengine/apiv1beta1/CatalogClient/DeleteCatalogItem/main.go b/internal/generated/snippets/recommendationengine/apiv1beta1/CatalogClient/DeleteCatalogItem/main.go index 3db390526117..b99127e4fc07 100644 --- a/internal/generated/snippets/recommendationengine/apiv1beta1/CatalogClient/DeleteCatalogItem/main.go +++ b/internal/generated/snippets/recommendationengine/apiv1beta1/CatalogClient/DeleteCatalogItem/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommendationengine/apiv1beta1/CatalogClient/GetCatalogItem/main.go b/internal/generated/snippets/recommendationengine/apiv1beta1/CatalogClient/GetCatalogItem/main.go index 274c0a406187..8883fc5fddd9 100644 --- a/internal/generated/snippets/recommendationengine/apiv1beta1/CatalogClient/GetCatalogItem/main.go +++ b/internal/generated/snippets/recommendationengine/apiv1beta1/CatalogClient/GetCatalogItem/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommendationengine/apiv1beta1/CatalogClient/ImportCatalogItems/main.go b/internal/generated/snippets/recommendationengine/apiv1beta1/CatalogClient/ImportCatalogItems/main.go index ac874d536138..3eee2960783a 100644 --- a/internal/generated/snippets/recommendationengine/apiv1beta1/CatalogClient/ImportCatalogItems/main.go +++ b/internal/generated/snippets/recommendationengine/apiv1beta1/CatalogClient/ImportCatalogItems/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommendationengine/apiv1beta1/CatalogClient/ListCatalogItems/main.go b/internal/generated/snippets/recommendationengine/apiv1beta1/CatalogClient/ListCatalogItems/main.go index 5b5abe1cc6b4..dcfd6b51db81 100644 --- a/internal/generated/snippets/recommendationengine/apiv1beta1/CatalogClient/ListCatalogItems/main.go +++ b/internal/generated/snippets/recommendationengine/apiv1beta1/CatalogClient/ListCatalogItems/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommendationengine/apiv1beta1/CatalogClient/UpdateCatalogItem/main.go b/internal/generated/snippets/recommendationengine/apiv1beta1/CatalogClient/UpdateCatalogItem/main.go index afd501f46fd4..51a2ab06cff5 100644 --- a/internal/generated/snippets/recommendationengine/apiv1beta1/CatalogClient/UpdateCatalogItem/main.go +++ b/internal/generated/snippets/recommendationengine/apiv1beta1/CatalogClient/UpdateCatalogItem/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommendationengine/apiv1beta1/PredictionApiKeyRegistryClient/CreatePredictionApiKeyRegistration/main.go b/internal/generated/snippets/recommendationengine/apiv1beta1/PredictionApiKeyRegistryClient/CreatePredictionApiKeyRegistration/main.go index 8c6b7e4e6cab..70fc4324f394 100644 --- a/internal/generated/snippets/recommendationengine/apiv1beta1/PredictionApiKeyRegistryClient/CreatePredictionApiKeyRegistration/main.go +++ b/internal/generated/snippets/recommendationengine/apiv1beta1/PredictionApiKeyRegistryClient/CreatePredictionApiKeyRegistration/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommendationengine/apiv1beta1/PredictionApiKeyRegistryClient/DeletePredictionApiKeyRegistration/main.go b/internal/generated/snippets/recommendationengine/apiv1beta1/PredictionApiKeyRegistryClient/DeletePredictionApiKeyRegistration/main.go index 55dcebf2bf4b..82d60122b2d1 100644 --- a/internal/generated/snippets/recommendationengine/apiv1beta1/PredictionApiKeyRegistryClient/DeletePredictionApiKeyRegistration/main.go +++ b/internal/generated/snippets/recommendationengine/apiv1beta1/PredictionApiKeyRegistryClient/DeletePredictionApiKeyRegistration/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommendationengine/apiv1beta1/PredictionApiKeyRegistryClient/ListPredictionApiKeyRegistrations/main.go b/internal/generated/snippets/recommendationengine/apiv1beta1/PredictionApiKeyRegistryClient/ListPredictionApiKeyRegistrations/main.go index 7041a61d5cf5..d321f6e95159 100644 --- a/internal/generated/snippets/recommendationengine/apiv1beta1/PredictionApiKeyRegistryClient/ListPredictionApiKeyRegistrations/main.go +++ b/internal/generated/snippets/recommendationengine/apiv1beta1/PredictionApiKeyRegistryClient/ListPredictionApiKeyRegistrations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommendationengine/apiv1beta1/PredictionClient/Predict/main.go b/internal/generated/snippets/recommendationengine/apiv1beta1/PredictionClient/Predict/main.go index 41a1bdd6dbe6..4595d0690b55 100644 --- a/internal/generated/snippets/recommendationengine/apiv1beta1/PredictionClient/Predict/main.go +++ b/internal/generated/snippets/recommendationengine/apiv1beta1/PredictionClient/Predict/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommendationengine/apiv1beta1/UserEventClient/CollectUserEvent/main.go b/internal/generated/snippets/recommendationengine/apiv1beta1/UserEventClient/CollectUserEvent/main.go index 763dc396f89c..b673dccb5e77 100644 --- a/internal/generated/snippets/recommendationengine/apiv1beta1/UserEventClient/CollectUserEvent/main.go +++ b/internal/generated/snippets/recommendationengine/apiv1beta1/UserEventClient/CollectUserEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommendationengine/apiv1beta1/UserEventClient/ImportUserEvents/main.go b/internal/generated/snippets/recommendationengine/apiv1beta1/UserEventClient/ImportUserEvents/main.go index e8892760cd45..3cf8ec0caa55 100644 --- a/internal/generated/snippets/recommendationengine/apiv1beta1/UserEventClient/ImportUserEvents/main.go +++ b/internal/generated/snippets/recommendationengine/apiv1beta1/UserEventClient/ImportUserEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommendationengine/apiv1beta1/UserEventClient/ListUserEvents/main.go b/internal/generated/snippets/recommendationengine/apiv1beta1/UserEventClient/ListUserEvents/main.go index 1fe82cb585a9..68454c83fb33 100644 --- a/internal/generated/snippets/recommendationengine/apiv1beta1/UserEventClient/ListUserEvents/main.go +++ b/internal/generated/snippets/recommendationengine/apiv1beta1/UserEventClient/ListUserEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommendationengine/apiv1beta1/UserEventClient/PurgeUserEvents/main.go b/internal/generated/snippets/recommendationengine/apiv1beta1/UserEventClient/PurgeUserEvents/main.go index 618bf5446efb..f345d0720859 100644 --- a/internal/generated/snippets/recommendationengine/apiv1beta1/UserEventClient/PurgeUserEvents/main.go +++ b/internal/generated/snippets/recommendationengine/apiv1beta1/UserEventClient/PurgeUserEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommendationengine/apiv1beta1/UserEventClient/WriteUserEvent/main.go b/internal/generated/snippets/recommendationengine/apiv1beta1/UserEventClient/WriteUserEvent/main.go index 4c0f8178beb6..82342b512b4b 100644 --- a/internal/generated/snippets/recommendationengine/apiv1beta1/UserEventClient/WriteUserEvent/main.go +++ b/internal/generated/snippets/recommendationengine/apiv1beta1/UserEventClient/WriteUserEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommender/apiv1/Client/GetInsight/main.go b/internal/generated/snippets/recommender/apiv1/Client/GetInsight/main.go index 22c7c1dd1d5f..5b0c73979d03 100644 --- a/internal/generated/snippets/recommender/apiv1/Client/GetInsight/main.go +++ b/internal/generated/snippets/recommender/apiv1/Client/GetInsight/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommender/apiv1/Client/GetInsightTypeConfig/main.go b/internal/generated/snippets/recommender/apiv1/Client/GetInsightTypeConfig/main.go index ce16274552e3..7b20f212d1ce 100644 --- a/internal/generated/snippets/recommender/apiv1/Client/GetInsightTypeConfig/main.go +++ b/internal/generated/snippets/recommender/apiv1/Client/GetInsightTypeConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommender/apiv1/Client/GetRecommendation/main.go b/internal/generated/snippets/recommender/apiv1/Client/GetRecommendation/main.go index 13f8ba93b74a..544d8cea2536 100644 --- a/internal/generated/snippets/recommender/apiv1/Client/GetRecommendation/main.go +++ b/internal/generated/snippets/recommender/apiv1/Client/GetRecommendation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommender/apiv1/Client/GetRecommenderConfig/main.go b/internal/generated/snippets/recommender/apiv1/Client/GetRecommenderConfig/main.go index 14340ed33fc0..2e6350775c17 100644 --- a/internal/generated/snippets/recommender/apiv1/Client/GetRecommenderConfig/main.go +++ b/internal/generated/snippets/recommender/apiv1/Client/GetRecommenderConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommender/apiv1/Client/ListInsights/main.go b/internal/generated/snippets/recommender/apiv1/Client/ListInsights/main.go index f97086f1ac9d..450acc51b216 100644 --- a/internal/generated/snippets/recommender/apiv1/Client/ListInsights/main.go +++ b/internal/generated/snippets/recommender/apiv1/Client/ListInsights/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommender/apiv1/Client/ListRecommendations/main.go b/internal/generated/snippets/recommender/apiv1/Client/ListRecommendations/main.go index 34f2b1177642..f717c3219446 100644 --- a/internal/generated/snippets/recommender/apiv1/Client/ListRecommendations/main.go +++ b/internal/generated/snippets/recommender/apiv1/Client/ListRecommendations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommender/apiv1/Client/MarkInsightAccepted/main.go b/internal/generated/snippets/recommender/apiv1/Client/MarkInsightAccepted/main.go index 05b8a496db59..ea22c30d71af 100644 --- a/internal/generated/snippets/recommender/apiv1/Client/MarkInsightAccepted/main.go +++ b/internal/generated/snippets/recommender/apiv1/Client/MarkInsightAccepted/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommender/apiv1/Client/MarkRecommendationClaimed/main.go b/internal/generated/snippets/recommender/apiv1/Client/MarkRecommendationClaimed/main.go index 576df447d175..e669a6aa435b 100644 --- a/internal/generated/snippets/recommender/apiv1/Client/MarkRecommendationClaimed/main.go +++ b/internal/generated/snippets/recommender/apiv1/Client/MarkRecommendationClaimed/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommender/apiv1/Client/MarkRecommendationDismissed/main.go b/internal/generated/snippets/recommender/apiv1/Client/MarkRecommendationDismissed/main.go index cb7883728802..1a8ac2276591 100644 --- a/internal/generated/snippets/recommender/apiv1/Client/MarkRecommendationDismissed/main.go +++ b/internal/generated/snippets/recommender/apiv1/Client/MarkRecommendationDismissed/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommender/apiv1/Client/MarkRecommendationFailed/main.go b/internal/generated/snippets/recommender/apiv1/Client/MarkRecommendationFailed/main.go index 8f650b525335..2a25429aca85 100644 --- a/internal/generated/snippets/recommender/apiv1/Client/MarkRecommendationFailed/main.go +++ b/internal/generated/snippets/recommender/apiv1/Client/MarkRecommendationFailed/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommender/apiv1/Client/MarkRecommendationSucceeded/main.go b/internal/generated/snippets/recommender/apiv1/Client/MarkRecommendationSucceeded/main.go index 1f384595565a..97e1a49fc913 100644 --- a/internal/generated/snippets/recommender/apiv1/Client/MarkRecommendationSucceeded/main.go +++ b/internal/generated/snippets/recommender/apiv1/Client/MarkRecommendationSucceeded/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommender/apiv1/Client/UpdateInsightTypeConfig/main.go b/internal/generated/snippets/recommender/apiv1/Client/UpdateInsightTypeConfig/main.go index 484941f5a4c5..1d80a165ec60 100644 --- a/internal/generated/snippets/recommender/apiv1/Client/UpdateInsightTypeConfig/main.go +++ b/internal/generated/snippets/recommender/apiv1/Client/UpdateInsightTypeConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommender/apiv1/Client/UpdateRecommenderConfig/main.go b/internal/generated/snippets/recommender/apiv1/Client/UpdateRecommenderConfig/main.go index a768cdfa9160..212292f1cc2b 100644 --- a/internal/generated/snippets/recommender/apiv1/Client/UpdateRecommenderConfig/main.go +++ b/internal/generated/snippets/recommender/apiv1/Client/UpdateRecommenderConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommender/apiv1/snippet_metadata.google.cloud.recommender.v1.json b/internal/generated/snippets/recommender/apiv1/snippet_metadata.google.cloud.recommender.v1.json index 36e8976465c8..d4ef76b827de 100644 --- a/internal/generated/snippets/recommender/apiv1/snippet_metadata.google.cloud.recommender.v1.json +++ b/internal/generated/snippets/recommender/apiv1/snippet_metadata.google.cloud.recommender.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/recommender/apiv1", - "version": "1.13.2", + "version": "1.13.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/recommender/apiv1beta1/Client/GetInsight/main.go b/internal/generated/snippets/recommender/apiv1beta1/Client/GetInsight/main.go index 3795bf5ab8c7..d0d91a433365 100644 --- a/internal/generated/snippets/recommender/apiv1beta1/Client/GetInsight/main.go +++ b/internal/generated/snippets/recommender/apiv1beta1/Client/GetInsight/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommender/apiv1beta1/Client/GetInsightTypeConfig/main.go b/internal/generated/snippets/recommender/apiv1beta1/Client/GetInsightTypeConfig/main.go index 7df8e1dba212..8804220c3b26 100644 --- a/internal/generated/snippets/recommender/apiv1beta1/Client/GetInsightTypeConfig/main.go +++ b/internal/generated/snippets/recommender/apiv1beta1/Client/GetInsightTypeConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommender/apiv1beta1/Client/GetRecommendation/main.go b/internal/generated/snippets/recommender/apiv1beta1/Client/GetRecommendation/main.go index a882039ee5d4..17012b2e25ec 100644 --- a/internal/generated/snippets/recommender/apiv1beta1/Client/GetRecommendation/main.go +++ b/internal/generated/snippets/recommender/apiv1beta1/Client/GetRecommendation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommender/apiv1beta1/Client/GetRecommenderConfig/main.go b/internal/generated/snippets/recommender/apiv1beta1/Client/GetRecommenderConfig/main.go index fb7d9d6cc92e..4ef9fff9a7d7 100644 --- a/internal/generated/snippets/recommender/apiv1beta1/Client/GetRecommenderConfig/main.go +++ b/internal/generated/snippets/recommender/apiv1beta1/Client/GetRecommenderConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommender/apiv1beta1/Client/ListInsightTypes/main.go b/internal/generated/snippets/recommender/apiv1beta1/Client/ListInsightTypes/main.go index d6543dcd2043..4a231df13a0f 100644 --- a/internal/generated/snippets/recommender/apiv1beta1/Client/ListInsightTypes/main.go +++ b/internal/generated/snippets/recommender/apiv1beta1/Client/ListInsightTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommender/apiv1beta1/Client/ListInsights/main.go b/internal/generated/snippets/recommender/apiv1beta1/Client/ListInsights/main.go index 044262285e3b..5bce3d879f34 100644 --- a/internal/generated/snippets/recommender/apiv1beta1/Client/ListInsights/main.go +++ b/internal/generated/snippets/recommender/apiv1beta1/Client/ListInsights/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommender/apiv1beta1/Client/ListRecommendations/main.go b/internal/generated/snippets/recommender/apiv1beta1/Client/ListRecommendations/main.go index ab34f5bf00db..7de40e244571 100644 --- a/internal/generated/snippets/recommender/apiv1beta1/Client/ListRecommendations/main.go +++ b/internal/generated/snippets/recommender/apiv1beta1/Client/ListRecommendations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommender/apiv1beta1/Client/ListRecommenders/main.go b/internal/generated/snippets/recommender/apiv1beta1/Client/ListRecommenders/main.go index f4d521f3fb6c..37df5634e3c2 100644 --- a/internal/generated/snippets/recommender/apiv1beta1/Client/ListRecommenders/main.go +++ b/internal/generated/snippets/recommender/apiv1beta1/Client/ListRecommenders/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommender/apiv1beta1/Client/MarkInsightAccepted/main.go b/internal/generated/snippets/recommender/apiv1beta1/Client/MarkInsightAccepted/main.go index 09cc2c94f71d..207072521fcb 100644 --- a/internal/generated/snippets/recommender/apiv1beta1/Client/MarkInsightAccepted/main.go +++ b/internal/generated/snippets/recommender/apiv1beta1/Client/MarkInsightAccepted/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommender/apiv1beta1/Client/MarkRecommendationClaimed/main.go b/internal/generated/snippets/recommender/apiv1beta1/Client/MarkRecommendationClaimed/main.go index 31b40925b034..9bf31fe5f793 100644 --- a/internal/generated/snippets/recommender/apiv1beta1/Client/MarkRecommendationClaimed/main.go +++ b/internal/generated/snippets/recommender/apiv1beta1/Client/MarkRecommendationClaimed/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommender/apiv1beta1/Client/MarkRecommendationFailed/main.go b/internal/generated/snippets/recommender/apiv1beta1/Client/MarkRecommendationFailed/main.go index 90261bd06d6e..381a1af6d6bd 100644 --- a/internal/generated/snippets/recommender/apiv1beta1/Client/MarkRecommendationFailed/main.go +++ b/internal/generated/snippets/recommender/apiv1beta1/Client/MarkRecommendationFailed/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommender/apiv1beta1/Client/MarkRecommendationSucceeded/main.go b/internal/generated/snippets/recommender/apiv1beta1/Client/MarkRecommendationSucceeded/main.go index 9ccd8f675cc0..12e941fe9027 100644 --- a/internal/generated/snippets/recommender/apiv1beta1/Client/MarkRecommendationSucceeded/main.go +++ b/internal/generated/snippets/recommender/apiv1beta1/Client/MarkRecommendationSucceeded/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommender/apiv1beta1/Client/UpdateInsightTypeConfig/main.go b/internal/generated/snippets/recommender/apiv1beta1/Client/UpdateInsightTypeConfig/main.go index 519ac07818e8..c2971a79761f 100644 --- a/internal/generated/snippets/recommender/apiv1beta1/Client/UpdateInsightTypeConfig/main.go +++ b/internal/generated/snippets/recommender/apiv1beta1/Client/UpdateInsightTypeConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommender/apiv1beta1/Client/UpdateRecommenderConfig/main.go b/internal/generated/snippets/recommender/apiv1beta1/Client/UpdateRecommenderConfig/main.go index 5fdaec807011..4e2326ff3c04 100644 --- a/internal/generated/snippets/recommender/apiv1beta1/Client/UpdateRecommenderConfig/main.go +++ b/internal/generated/snippets/recommender/apiv1beta1/Client/UpdateRecommenderConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/recommender/apiv1beta1/snippet_metadata.google.cloud.recommender.v1beta1.json b/internal/generated/snippets/recommender/apiv1beta1/snippet_metadata.google.cloud.recommender.v1beta1.json index 7c78725af8c3..6a076a3c346c 100644 --- a/internal/generated/snippets/recommender/apiv1beta1/snippet_metadata.google.cloud.recommender.v1beta1.json +++ b/internal/generated/snippets/recommender/apiv1beta1/snippet_metadata.google.cloud.recommender.v1beta1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/recommender/apiv1beta1", - "version": "1.13.2", + "version": "1.13.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/redis/apiv1/CloudRedisClient/CancelOperation/main.go b/internal/generated/snippets/redis/apiv1/CloudRedisClient/CancelOperation/main.go index af0fca75ada9..5350fceba19e 100644 --- a/internal/generated/snippets/redis/apiv1/CloudRedisClient/CancelOperation/main.go +++ b/internal/generated/snippets/redis/apiv1/CloudRedisClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/apiv1/CloudRedisClient/CreateInstance/main.go b/internal/generated/snippets/redis/apiv1/CloudRedisClient/CreateInstance/main.go index c2be523c97c0..0d85c1fc8742 100644 --- a/internal/generated/snippets/redis/apiv1/CloudRedisClient/CreateInstance/main.go +++ b/internal/generated/snippets/redis/apiv1/CloudRedisClient/CreateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/apiv1/CloudRedisClient/DeleteInstance/main.go b/internal/generated/snippets/redis/apiv1/CloudRedisClient/DeleteInstance/main.go index fed5b53349f9..36b504329148 100644 --- a/internal/generated/snippets/redis/apiv1/CloudRedisClient/DeleteInstance/main.go +++ b/internal/generated/snippets/redis/apiv1/CloudRedisClient/DeleteInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/apiv1/CloudRedisClient/DeleteOperation/main.go b/internal/generated/snippets/redis/apiv1/CloudRedisClient/DeleteOperation/main.go index 3be4e098196c..a9f892ffb60b 100644 --- a/internal/generated/snippets/redis/apiv1/CloudRedisClient/DeleteOperation/main.go +++ b/internal/generated/snippets/redis/apiv1/CloudRedisClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/apiv1/CloudRedisClient/ExportInstance/main.go b/internal/generated/snippets/redis/apiv1/CloudRedisClient/ExportInstance/main.go index 14cf7796ade2..99b18211242f 100644 --- a/internal/generated/snippets/redis/apiv1/CloudRedisClient/ExportInstance/main.go +++ b/internal/generated/snippets/redis/apiv1/CloudRedisClient/ExportInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/apiv1/CloudRedisClient/FailoverInstance/main.go b/internal/generated/snippets/redis/apiv1/CloudRedisClient/FailoverInstance/main.go index 7b5d79057764..51e6e23fbce5 100644 --- a/internal/generated/snippets/redis/apiv1/CloudRedisClient/FailoverInstance/main.go +++ b/internal/generated/snippets/redis/apiv1/CloudRedisClient/FailoverInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/apiv1/CloudRedisClient/GetInstance/main.go b/internal/generated/snippets/redis/apiv1/CloudRedisClient/GetInstance/main.go index 3fba81a9c6b6..060c7e42153f 100644 --- a/internal/generated/snippets/redis/apiv1/CloudRedisClient/GetInstance/main.go +++ b/internal/generated/snippets/redis/apiv1/CloudRedisClient/GetInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/apiv1/CloudRedisClient/GetInstanceAuthString/main.go b/internal/generated/snippets/redis/apiv1/CloudRedisClient/GetInstanceAuthString/main.go index ed20962263a6..2b77165fbbd7 100644 --- a/internal/generated/snippets/redis/apiv1/CloudRedisClient/GetInstanceAuthString/main.go +++ b/internal/generated/snippets/redis/apiv1/CloudRedisClient/GetInstanceAuthString/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/apiv1/CloudRedisClient/GetLocation/main.go b/internal/generated/snippets/redis/apiv1/CloudRedisClient/GetLocation/main.go index 60d048332ffe..4550963cd5cc 100644 --- a/internal/generated/snippets/redis/apiv1/CloudRedisClient/GetLocation/main.go +++ b/internal/generated/snippets/redis/apiv1/CloudRedisClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/apiv1/CloudRedisClient/GetOperation/main.go b/internal/generated/snippets/redis/apiv1/CloudRedisClient/GetOperation/main.go index 66dfcb3f3fae..fd5745807e51 100644 --- a/internal/generated/snippets/redis/apiv1/CloudRedisClient/GetOperation/main.go +++ b/internal/generated/snippets/redis/apiv1/CloudRedisClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/apiv1/CloudRedisClient/ImportInstance/main.go b/internal/generated/snippets/redis/apiv1/CloudRedisClient/ImportInstance/main.go index 8ca4e348123b..654660281292 100644 --- a/internal/generated/snippets/redis/apiv1/CloudRedisClient/ImportInstance/main.go +++ b/internal/generated/snippets/redis/apiv1/CloudRedisClient/ImportInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/apiv1/CloudRedisClient/ListInstances/main.go b/internal/generated/snippets/redis/apiv1/CloudRedisClient/ListInstances/main.go index 60e07f94c7b2..aa58fe73c4eb 100644 --- a/internal/generated/snippets/redis/apiv1/CloudRedisClient/ListInstances/main.go +++ b/internal/generated/snippets/redis/apiv1/CloudRedisClient/ListInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/apiv1/CloudRedisClient/ListLocations/main.go b/internal/generated/snippets/redis/apiv1/CloudRedisClient/ListLocations/main.go index e2d497f56b56..091be910f27e 100644 --- a/internal/generated/snippets/redis/apiv1/CloudRedisClient/ListLocations/main.go +++ b/internal/generated/snippets/redis/apiv1/CloudRedisClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/apiv1/CloudRedisClient/ListOperations/main.go b/internal/generated/snippets/redis/apiv1/CloudRedisClient/ListOperations/main.go index f81598d918d6..c376432f33b9 100644 --- a/internal/generated/snippets/redis/apiv1/CloudRedisClient/ListOperations/main.go +++ b/internal/generated/snippets/redis/apiv1/CloudRedisClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/apiv1/CloudRedisClient/RescheduleMaintenance/main.go b/internal/generated/snippets/redis/apiv1/CloudRedisClient/RescheduleMaintenance/main.go index 53cf69c72235..8ede98743ad3 100644 --- a/internal/generated/snippets/redis/apiv1/CloudRedisClient/RescheduleMaintenance/main.go +++ b/internal/generated/snippets/redis/apiv1/CloudRedisClient/RescheduleMaintenance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/apiv1/CloudRedisClient/UpdateInstance/main.go b/internal/generated/snippets/redis/apiv1/CloudRedisClient/UpdateInstance/main.go index a83cacfc3544..218809353d9d 100644 --- a/internal/generated/snippets/redis/apiv1/CloudRedisClient/UpdateInstance/main.go +++ b/internal/generated/snippets/redis/apiv1/CloudRedisClient/UpdateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/apiv1/CloudRedisClient/UpgradeInstance/main.go b/internal/generated/snippets/redis/apiv1/CloudRedisClient/UpgradeInstance/main.go index 8d8ce930d855..f1b3befd0eb2 100644 --- a/internal/generated/snippets/redis/apiv1/CloudRedisClient/UpgradeInstance/main.go +++ b/internal/generated/snippets/redis/apiv1/CloudRedisClient/UpgradeInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/apiv1/snippet_metadata.google.cloud.redis.v1.json b/internal/generated/snippets/redis/apiv1/snippet_metadata.google.cloud.redis.v1.json index ca5c912e4a0f..7fb65c796fae 100644 --- a/internal/generated/snippets/redis/apiv1/snippet_metadata.google.cloud.redis.v1.json +++ b/internal/generated/snippets/redis/apiv1/snippet_metadata.google.cloud.redis.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/redis/apiv1", - "version": "1.17.2", + "version": "1.17.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/CreateInstance/main.go b/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/CreateInstance/main.go index bac4d4bf6302..8f3ace8d6b4a 100644 --- a/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/CreateInstance/main.go +++ b/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/CreateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/DeleteInstance/main.go b/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/DeleteInstance/main.go index 27ef0162f2a6..e00e45084718 100644 --- a/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/DeleteInstance/main.go +++ b/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/DeleteInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/ExportInstance/main.go b/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/ExportInstance/main.go index 6063d104de07..34b503791aa9 100644 --- a/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/ExportInstance/main.go +++ b/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/ExportInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/FailoverInstance/main.go b/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/FailoverInstance/main.go index 5e3541021193..210aa415d627 100644 --- a/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/FailoverInstance/main.go +++ b/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/FailoverInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/GetInstance/main.go b/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/GetInstance/main.go index 20b44d63c4a4..e19cd49e9604 100644 --- a/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/GetInstance/main.go +++ b/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/GetInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/GetInstanceAuthString/main.go b/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/GetInstanceAuthString/main.go index 2389de2de7c1..661b6664a61a 100644 --- a/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/GetInstanceAuthString/main.go +++ b/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/GetInstanceAuthString/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/ImportInstance/main.go b/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/ImportInstance/main.go index aeb839fa9831..3830306c7c9d 100644 --- a/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/ImportInstance/main.go +++ b/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/ImportInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/ListInstances/main.go b/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/ListInstances/main.go index a5ad56b52edf..394d95f1475b 100644 --- a/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/ListInstances/main.go +++ b/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/ListInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/RescheduleMaintenance/main.go b/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/RescheduleMaintenance/main.go index e85eb3a2afe6..357a076dacc8 100644 --- a/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/RescheduleMaintenance/main.go +++ b/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/RescheduleMaintenance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/UpdateInstance/main.go b/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/UpdateInstance/main.go index f6c7330e8575..8692750214c9 100644 --- a/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/UpdateInstance/main.go +++ b/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/UpdateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/UpgradeInstance/main.go b/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/UpgradeInstance/main.go index b0a788e19aa6..8d657f2fc1a0 100644 --- a/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/UpgradeInstance/main.go +++ b/internal/generated/snippets/redis/apiv1beta1/CloudRedisClient/UpgradeInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/apiv1beta1/snippet_metadata.google.cloud.redis.v1beta1.json b/internal/generated/snippets/redis/apiv1beta1/snippet_metadata.google.cloud.redis.v1beta1.json index 5329e43e1eff..4d33304bb863 100644 --- a/internal/generated/snippets/redis/apiv1beta1/snippet_metadata.google.cloud.redis.v1beta1.json +++ b/internal/generated/snippets/redis/apiv1beta1/snippet_metadata.google.cloud.redis.v1beta1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/redis/apiv1beta1", - "version": "1.17.2", + "version": "1.17.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/CancelOperation/main.go b/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/CancelOperation/main.go index 696614003f00..5758f4faf7ef 100644 --- a/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/CancelOperation/main.go +++ b/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/CreateCluster/main.go b/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/CreateCluster/main.go index d6ca0df15544..b2d9799d5966 100644 --- a/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/CreateCluster/main.go +++ b/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/CreateCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/DeleteCluster/main.go b/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/DeleteCluster/main.go index fdc7c8ce609a..2fec624f7df2 100644 --- a/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/DeleteCluster/main.go +++ b/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/DeleteCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/DeleteOperation/main.go b/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/DeleteOperation/main.go index 4068056294fa..988dce1d6f79 100644 --- a/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/DeleteOperation/main.go +++ b/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/GetCluster/main.go b/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/GetCluster/main.go index 5ff19c77cd70..a8fa2cb6fd3e 100644 --- a/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/GetCluster/main.go +++ b/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/GetCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/GetClusterCertificateAuthority/main.go b/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/GetClusterCertificateAuthority/main.go index bbe66b3ec758..3f602e31b528 100644 --- a/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/GetClusterCertificateAuthority/main.go +++ b/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/GetClusterCertificateAuthority/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/GetLocation/main.go b/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/GetLocation/main.go index 4be9710078e4..0f62daf0e179 100644 --- a/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/GetLocation/main.go +++ b/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/GetOperation/main.go b/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/GetOperation/main.go index b2fd1a165e30..a68dbf4475d7 100644 --- a/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/GetOperation/main.go +++ b/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/ListClusters/main.go b/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/ListClusters/main.go index bb588ad433d8..25125bddfa6e 100644 --- a/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/ListClusters/main.go +++ b/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/ListClusters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/ListLocations/main.go b/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/ListLocations/main.go index 7a49ba097d28..2ab36073d227 100644 --- a/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/ListLocations/main.go +++ b/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/ListOperations/main.go b/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/ListOperations/main.go index 2919100b3afe..7625e2a07f56 100644 --- a/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/ListOperations/main.go +++ b/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/UpdateCluster/main.go b/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/UpdateCluster/main.go index 94a8443756fc..a4af56f6069a 100644 --- a/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/UpdateCluster/main.go +++ b/internal/generated/snippets/redis/cluster/apiv1/CloudRedisClusterClient/UpdateCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/redis/cluster/apiv1/snippet_metadata.google.cloud.redis.cluster.v1.json b/internal/generated/snippets/redis/cluster/apiv1/snippet_metadata.google.cloud.redis.cluster.v1.json index 28576f4cd42e..ead3d6755708 100644 --- a/internal/generated/snippets/redis/cluster/apiv1/snippet_metadata.google.cloud.redis.cluster.v1.json +++ b/internal/generated/snippets/redis/cluster/apiv1/snippet_metadata.google.cloud.redis.cluster.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/redis/cluster/apiv1", - "version": "1.17.2", + "version": "1.17.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/CreateFolder/main.go b/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/CreateFolder/main.go index 08ff613241fe..4920ff4afdd7 100644 --- a/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/CreateFolder/main.go +++ b/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/CreateFolder/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/DeleteFolder/main.go b/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/DeleteFolder/main.go index 55d98927c4c6..41de1e2a0004 100644 --- a/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/DeleteFolder/main.go +++ b/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/DeleteFolder/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/GetFolder/main.go b/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/GetFolder/main.go index 61db7ff2d321..e464721ecf0f 100644 --- a/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/GetFolder/main.go +++ b/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/GetFolder/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/GetIamPolicy/main.go b/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/GetIamPolicy/main.go index d84d9585624d..fef2cc3db603 100644 --- a/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/ListFolders/main.go b/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/ListFolders/main.go index 470ba33cc27b..ac2e7b793b5a 100644 --- a/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/ListFolders/main.go +++ b/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/ListFolders/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/MoveFolder/main.go b/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/MoveFolder/main.go index 66f994523026..08485eed95f1 100644 --- a/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/MoveFolder/main.go +++ b/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/MoveFolder/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/SearchFolders/main.go b/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/SearchFolders/main.go index e9420bb779da..46f421254a00 100644 --- a/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/SearchFolders/main.go +++ b/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/SearchFolders/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/SetIamPolicy/main.go b/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/SetIamPolicy/main.go index 8903fa9acee9..655c9712bef6 100644 --- a/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/TestIamPermissions/main.go b/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/TestIamPermissions/main.go index 51fe61000ee5..86caaa901695 100644 --- a/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/UndeleteFolder/main.go b/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/UndeleteFolder/main.go index da736529a6a9..59cbdca747f1 100644 --- a/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/UndeleteFolder/main.go +++ b/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/UndeleteFolder/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/UpdateFolder/main.go b/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/UpdateFolder/main.go index c77a82ec03cf..9e42fffc9e46 100644 --- a/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/UpdateFolder/main.go +++ b/internal/generated/snippets/resourcemanager/apiv2/FoldersClient/UpdateFolder/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/CreateFolder/main.go b/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/CreateFolder/main.go index fbaee07ce4a0..961eafacef2e 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/CreateFolder/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/CreateFolder/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/DeleteFolder/main.go b/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/DeleteFolder/main.go index a9cf68009381..d901dd6eab4a 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/DeleteFolder/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/DeleteFolder/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/GetFolder/main.go b/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/GetFolder/main.go index 2c9ec6be3491..d7c823899354 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/GetFolder/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/GetFolder/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/GetIamPolicy/main.go b/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/GetIamPolicy/main.go index 6b08bc512da2..77192b4e5885 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/GetOperation/main.go b/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/GetOperation/main.go index b5deb5788f3d..0acd14cd09a8 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/GetOperation/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/ListFolders/main.go b/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/ListFolders/main.go index 31f5b88523bc..611d722a980f 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/ListFolders/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/ListFolders/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/MoveFolder/main.go b/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/MoveFolder/main.go index a90f6f825761..ef3ad0867d7d 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/MoveFolder/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/MoveFolder/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/SearchFolders/main.go b/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/SearchFolders/main.go index 757d57305fdb..93efac498421 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/SearchFolders/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/SearchFolders/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/SetIamPolicy/main.go b/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/SetIamPolicy/main.go index 70798b99c4a0..9c34976716c4 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/TestIamPermissions/main.go b/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/TestIamPermissions/main.go index e34af95e258f..95b603065ed4 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/UndeleteFolder/main.go b/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/UndeleteFolder/main.go index e433ceeff919..b6377ae0c1c5 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/UndeleteFolder/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/UndeleteFolder/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/UpdateFolder/main.go b/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/UpdateFolder/main.go index a083dd2fc1a4..65a9c1e9e241 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/UpdateFolder/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/FoldersClient/UpdateFolder/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/OrganizationsClient/GetIamPolicy/main.go b/internal/generated/snippets/resourcemanager/apiv3/OrganizationsClient/GetIamPolicy/main.go index 82663aa67462..430f1c972fc5 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/OrganizationsClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/OrganizationsClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/OrganizationsClient/GetOperation/main.go b/internal/generated/snippets/resourcemanager/apiv3/OrganizationsClient/GetOperation/main.go index e04fe09c4781..af42a2151627 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/OrganizationsClient/GetOperation/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/OrganizationsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/OrganizationsClient/GetOrganization/main.go b/internal/generated/snippets/resourcemanager/apiv3/OrganizationsClient/GetOrganization/main.go index 8e9eef162dfa..c51204849652 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/OrganizationsClient/GetOrganization/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/OrganizationsClient/GetOrganization/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/OrganizationsClient/SearchOrganizations/main.go b/internal/generated/snippets/resourcemanager/apiv3/OrganizationsClient/SearchOrganizations/main.go index 71c8f1b862d5..72b673c4339e 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/OrganizationsClient/SearchOrganizations/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/OrganizationsClient/SearchOrganizations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/OrganizationsClient/SetIamPolicy/main.go b/internal/generated/snippets/resourcemanager/apiv3/OrganizationsClient/SetIamPolicy/main.go index 4b92be85c807..7c7d6799a3ee 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/OrganizationsClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/OrganizationsClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/OrganizationsClient/TestIamPermissions/main.go b/internal/generated/snippets/resourcemanager/apiv3/OrganizationsClient/TestIamPermissions/main.go index 623dd0b52b20..9f223c61f3e1 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/OrganizationsClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/OrganizationsClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/CreateProject/main.go b/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/CreateProject/main.go index 2800ec04abc7..3a2ee61452ab 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/CreateProject/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/CreateProject/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/DeleteProject/main.go b/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/DeleteProject/main.go index b01a775cbdb9..335753713ea9 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/DeleteProject/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/DeleteProject/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/GetIamPolicy/main.go b/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/GetIamPolicy/main.go index 7a9bac781a0c..185dffb00749 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/GetOperation/main.go b/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/GetOperation/main.go index 7d147bcf568f..7855e3e85f4e 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/GetOperation/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/GetProject/main.go b/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/GetProject/main.go index 902c2c6c9d88..8f5e71ed4ea2 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/GetProject/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/GetProject/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/ListProjects/main.go b/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/ListProjects/main.go index 8c81c20a7dcc..d98de1aa92da 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/ListProjects/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/ListProjects/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/MoveProject/main.go b/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/MoveProject/main.go index f23ccfa9d747..045b15c5c5dc 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/MoveProject/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/MoveProject/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/SearchProjects/main.go b/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/SearchProjects/main.go index 43de6fce8f91..accfb2f5d271 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/SearchProjects/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/SearchProjects/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/SetIamPolicy/main.go b/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/SetIamPolicy/main.go index d3e7b0f511ec..64bf0b047e78 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/TestIamPermissions/main.go b/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/TestIamPermissions/main.go index 374e66f188ca..a61e3dbfea45 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/UndeleteProject/main.go b/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/UndeleteProject/main.go index 1cba33f1dded..351b0e40b7d2 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/UndeleteProject/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/UndeleteProject/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/UpdateProject/main.go b/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/UpdateProject/main.go index c09e0a75c779..8e52cd48e491 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/UpdateProject/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/ProjectsClient/UpdateProject/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagBindingsClient/CreateTagBinding/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagBindingsClient/CreateTagBinding/main.go index a136cf2cdfe2..e9f805574bc3 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagBindingsClient/CreateTagBinding/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagBindingsClient/CreateTagBinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagBindingsClient/DeleteTagBinding/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagBindingsClient/DeleteTagBinding/main.go index 328ec1161887..4746d87284c0 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagBindingsClient/DeleteTagBinding/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagBindingsClient/DeleteTagBinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagBindingsClient/GetOperation/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagBindingsClient/GetOperation/main.go index 8cac93dd1fb3..0febe204e734 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagBindingsClient/GetOperation/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagBindingsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagBindingsClient/ListEffectiveTags/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagBindingsClient/ListEffectiveTags/main.go index ed0b67898779..6840916f7161 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagBindingsClient/ListEffectiveTags/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagBindingsClient/ListEffectiveTags/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagBindingsClient/ListTagBindings/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagBindingsClient/ListTagBindings/main.go index d35ff7476d79..4d7b3c7030ab 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagBindingsClient/ListTagBindings/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagBindingsClient/ListTagBindings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagHoldsClient/CreateTagHold/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagHoldsClient/CreateTagHold/main.go index 340d1144defa..500397c610f3 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagHoldsClient/CreateTagHold/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagHoldsClient/CreateTagHold/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagHoldsClient/DeleteTagHold/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagHoldsClient/DeleteTagHold/main.go index fe1d32562f0e..b4d20ce5578d 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagHoldsClient/DeleteTagHold/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagHoldsClient/DeleteTagHold/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagHoldsClient/GetOperation/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagHoldsClient/GetOperation/main.go index 1dca9d92016a..4b7651d2ea3e 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagHoldsClient/GetOperation/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagHoldsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagHoldsClient/ListTagHolds/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagHoldsClient/ListTagHolds/main.go index fd303a34f9e3..5dc42f670fc7 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagHoldsClient/ListTagHolds/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagHoldsClient/ListTagHolds/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/CreateTagKey/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/CreateTagKey/main.go index 9847e2a21429..23d563174bbd 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/CreateTagKey/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/CreateTagKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/DeleteTagKey/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/DeleteTagKey/main.go index 86989ddba484..e842c55c1721 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/DeleteTagKey/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/DeleteTagKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/GetIamPolicy/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/GetIamPolicy/main.go index 3474cfbc0197..84fd88279a16 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/GetNamespacedTagKey/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/GetNamespacedTagKey/main.go index 1ee03c371a47..ca1a7212c673 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/GetNamespacedTagKey/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/GetNamespacedTagKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/GetOperation/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/GetOperation/main.go index 2f84877ce429..e879a9a709b8 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/GetOperation/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/GetTagKey/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/GetTagKey/main.go index abb1472aa9bb..9bb3183a513a 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/GetTagKey/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/GetTagKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/ListTagKeys/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/ListTagKeys/main.go index f0976aa91071..7fb9bb884279 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/ListTagKeys/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/ListTagKeys/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/SetIamPolicy/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/SetIamPolicy/main.go index 8c4df1744649..7f128d60828e 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/TestIamPermissions/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/TestIamPermissions/main.go index dd4e254ba010..f9dd33363b07 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/UpdateTagKey/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/UpdateTagKey/main.go index 2f1e3959d857..e8d10f391666 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/UpdateTagKey/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagKeysClient/UpdateTagKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/CreateTagValue/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/CreateTagValue/main.go index 0ec82022e16e..7bc4bc340d07 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/CreateTagValue/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/CreateTagValue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/DeleteTagValue/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/DeleteTagValue/main.go index 074ce3f56d33..2b77fe5d743a 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/DeleteTagValue/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/DeleteTagValue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/GetIamPolicy/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/GetIamPolicy/main.go index 6311c6b088f5..7a791ee119a8 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/GetNamespacedTagValue/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/GetNamespacedTagValue/main.go index 279184182ae4..6aa04f0b991f 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/GetNamespacedTagValue/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/GetNamespacedTagValue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/GetOperation/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/GetOperation/main.go index 3f819c6d9413..62c24d231142 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/GetOperation/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/GetTagValue/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/GetTagValue/main.go index 7e654445ddec..86e7ef337e1d 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/GetTagValue/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/GetTagValue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/ListTagValues/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/ListTagValues/main.go index 6c00be3693e9..dd53be7cb3bb 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/ListTagValues/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/ListTagValues/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/SetIamPolicy/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/SetIamPolicy/main.go index 39341d0470a7..231fc86784ce 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/TestIamPermissions/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/TestIamPermissions/main.go index 14435d6eddf9..f4f0e0113f39 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/UpdateTagValue/main.go b/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/UpdateTagValue/main.go index 02f714163156..7ab2ca8ebd2f 100644 --- a/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/UpdateTagValue/main.go +++ b/internal/generated/snippets/resourcemanager/apiv3/TagValuesClient/UpdateTagValue/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcesettings/apiv1/Client/GetSetting/main.go b/internal/generated/snippets/resourcesettings/apiv1/Client/GetSetting/main.go index 4474940aa345..9fdd8c2a1938 100644 --- a/internal/generated/snippets/resourcesettings/apiv1/Client/GetSetting/main.go +++ b/internal/generated/snippets/resourcesettings/apiv1/Client/GetSetting/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcesettings/apiv1/Client/ListSettings/main.go b/internal/generated/snippets/resourcesettings/apiv1/Client/ListSettings/main.go index f3b1aa2d43d4..cd072d638bcd 100644 --- a/internal/generated/snippets/resourcesettings/apiv1/Client/ListSettings/main.go +++ b/internal/generated/snippets/resourcesettings/apiv1/Client/ListSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcesettings/apiv1/Client/UpdateSetting/main.go b/internal/generated/snippets/resourcesettings/apiv1/Client/UpdateSetting/main.go index 5d7dbd8a0e56..010d057a57be 100644 --- a/internal/generated/snippets/resourcesettings/apiv1/Client/UpdateSetting/main.go +++ b/internal/generated/snippets/resourcesettings/apiv1/Client/UpdateSetting/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/resourcesettings/apiv1/snippet_metadata.google.cloud.resourcesettings.v1.json b/internal/generated/snippets/resourcesettings/apiv1/snippet_metadata.google.cloud.resourcesettings.v1.json index ac9ecafb7896..db2e4feb237e 100644 --- a/internal/generated/snippets/resourcesettings/apiv1/snippet_metadata.google.cloud.resourcesettings.v1.json +++ b/internal/generated/snippets/resourcesettings/apiv1/snippet_metadata.google.cloud.resourcesettings.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/resourcesettings/apiv1", - "version": "1.8.2", + "version": "1.8.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/retail/apiv2/AnalyticsClient/ExportAnalyticsMetrics/main.go b/internal/generated/snippets/retail/apiv2/AnalyticsClient/ExportAnalyticsMetrics/main.go index 8360b9918538..d58914358e95 100644 --- a/internal/generated/snippets/retail/apiv2/AnalyticsClient/ExportAnalyticsMetrics/main.go +++ b/internal/generated/snippets/retail/apiv2/AnalyticsClient/ExportAnalyticsMetrics/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/AnalyticsClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2/AnalyticsClient/GetOperation/main.go index 5a9bb37983f8..d7ce76ad6dec 100644 --- a/internal/generated/snippets/retail/apiv2/AnalyticsClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2/AnalyticsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/AnalyticsClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2/AnalyticsClient/ListOperations/main.go index 0b69dbd6de0e..7ad269c6ddc5 100644 --- a/internal/generated/snippets/retail/apiv2/AnalyticsClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2/AnalyticsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/CatalogClient/AddCatalogAttribute/main.go b/internal/generated/snippets/retail/apiv2/CatalogClient/AddCatalogAttribute/main.go index 38e16a9a00b9..aa5dfb9cab9f 100644 --- a/internal/generated/snippets/retail/apiv2/CatalogClient/AddCatalogAttribute/main.go +++ b/internal/generated/snippets/retail/apiv2/CatalogClient/AddCatalogAttribute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/CatalogClient/GetAttributesConfig/main.go b/internal/generated/snippets/retail/apiv2/CatalogClient/GetAttributesConfig/main.go index 019ac341045b..1a06597e2410 100644 --- a/internal/generated/snippets/retail/apiv2/CatalogClient/GetAttributesConfig/main.go +++ b/internal/generated/snippets/retail/apiv2/CatalogClient/GetAttributesConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/CatalogClient/GetCompletionConfig/main.go b/internal/generated/snippets/retail/apiv2/CatalogClient/GetCompletionConfig/main.go index d513bf07d6eb..0f89f129d989 100644 --- a/internal/generated/snippets/retail/apiv2/CatalogClient/GetCompletionConfig/main.go +++ b/internal/generated/snippets/retail/apiv2/CatalogClient/GetCompletionConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/CatalogClient/GetDefaultBranch/main.go b/internal/generated/snippets/retail/apiv2/CatalogClient/GetDefaultBranch/main.go index 05d165e859a6..4837735e7a4b 100644 --- a/internal/generated/snippets/retail/apiv2/CatalogClient/GetDefaultBranch/main.go +++ b/internal/generated/snippets/retail/apiv2/CatalogClient/GetDefaultBranch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/CatalogClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2/CatalogClient/GetOperation/main.go index df36ef22611a..ba455e29478b 100644 --- a/internal/generated/snippets/retail/apiv2/CatalogClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2/CatalogClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/CatalogClient/ListCatalogs/main.go b/internal/generated/snippets/retail/apiv2/CatalogClient/ListCatalogs/main.go index dabec765018f..6c73190fcfe4 100644 --- a/internal/generated/snippets/retail/apiv2/CatalogClient/ListCatalogs/main.go +++ b/internal/generated/snippets/retail/apiv2/CatalogClient/ListCatalogs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/CatalogClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2/CatalogClient/ListOperations/main.go index 64557fd521bb..72df0ab060d8 100644 --- a/internal/generated/snippets/retail/apiv2/CatalogClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2/CatalogClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/CatalogClient/RemoveCatalogAttribute/main.go b/internal/generated/snippets/retail/apiv2/CatalogClient/RemoveCatalogAttribute/main.go index dda87e98405a..6df82a629653 100644 --- a/internal/generated/snippets/retail/apiv2/CatalogClient/RemoveCatalogAttribute/main.go +++ b/internal/generated/snippets/retail/apiv2/CatalogClient/RemoveCatalogAttribute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/CatalogClient/ReplaceCatalogAttribute/main.go b/internal/generated/snippets/retail/apiv2/CatalogClient/ReplaceCatalogAttribute/main.go index cbb59bec9182..f3c539e99314 100644 --- a/internal/generated/snippets/retail/apiv2/CatalogClient/ReplaceCatalogAttribute/main.go +++ b/internal/generated/snippets/retail/apiv2/CatalogClient/ReplaceCatalogAttribute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/CatalogClient/SetDefaultBranch/main.go b/internal/generated/snippets/retail/apiv2/CatalogClient/SetDefaultBranch/main.go index 0158926bc3c3..a51cb68f493a 100644 --- a/internal/generated/snippets/retail/apiv2/CatalogClient/SetDefaultBranch/main.go +++ b/internal/generated/snippets/retail/apiv2/CatalogClient/SetDefaultBranch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/CatalogClient/UpdateAttributesConfig/main.go b/internal/generated/snippets/retail/apiv2/CatalogClient/UpdateAttributesConfig/main.go index 87435467bab1..fb78e5471c56 100644 --- a/internal/generated/snippets/retail/apiv2/CatalogClient/UpdateAttributesConfig/main.go +++ b/internal/generated/snippets/retail/apiv2/CatalogClient/UpdateAttributesConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/CatalogClient/UpdateCatalog/main.go b/internal/generated/snippets/retail/apiv2/CatalogClient/UpdateCatalog/main.go index 55066c659714..1ccc643fc416 100644 --- a/internal/generated/snippets/retail/apiv2/CatalogClient/UpdateCatalog/main.go +++ b/internal/generated/snippets/retail/apiv2/CatalogClient/UpdateCatalog/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/CatalogClient/UpdateCompletionConfig/main.go b/internal/generated/snippets/retail/apiv2/CatalogClient/UpdateCompletionConfig/main.go index aa7be1e99ca4..1db0865a4458 100644 --- a/internal/generated/snippets/retail/apiv2/CatalogClient/UpdateCompletionConfig/main.go +++ b/internal/generated/snippets/retail/apiv2/CatalogClient/UpdateCompletionConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/CompletionClient/CompleteQuery/main.go b/internal/generated/snippets/retail/apiv2/CompletionClient/CompleteQuery/main.go index cd4acc6373fc..70aecc8bf63c 100644 --- a/internal/generated/snippets/retail/apiv2/CompletionClient/CompleteQuery/main.go +++ b/internal/generated/snippets/retail/apiv2/CompletionClient/CompleteQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/CompletionClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2/CompletionClient/GetOperation/main.go index 609dc5bc6fd8..f4fca8539772 100644 --- a/internal/generated/snippets/retail/apiv2/CompletionClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2/CompletionClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/CompletionClient/ImportCompletionData/main.go b/internal/generated/snippets/retail/apiv2/CompletionClient/ImportCompletionData/main.go index a05b01361c88..e8d0bc8ba238 100644 --- a/internal/generated/snippets/retail/apiv2/CompletionClient/ImportCompletionData/main.go +++ b/internal/generated/snippets/retail/apiv2/CompletionClient/ImportCompletionData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/CompletionClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2/CompletionClient/ListOperations/main.go index 343f912ca8b9..4946135c1f7d 100644 --- a/internal/generated/snippets/retail/apiv2/CompletionClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2/CompletionClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ControlClient/CreateControl/main.go b/internal/generated/snippets/retail/apiv2/ControlClient/CreateControl/main.go index 323027581596..6cb569ad960f 100644 --- a/internal/generated/snippets/retail/apiv2/ControlClient/CreateControl/main.go +++ b/internal/generated/snippets/retail/apiv2/ControlClient/CreateControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ControlClient/DeleteControl/main.go b/internal/generated/snippets/retail/apiv2/ControlClient/DeleteControl/main.go index f21b5ad0c12f..a78e5b3fe9e7 100644 --- a/internal/generated/snippets/retail/apiv2/ControlClient/DeleteControl/main.go +++ b/internal/generated/snippets/retail/apiv2/ControlClient/DeleteControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ControlClient/GetControl/main.go b/internal/generated/snippets/retail/apiv2/ControlClient/GetControl/main.go index 82afa7bc0615..17a82941c39b 100644 --- a/internal/generated/snippets/retail/apiv2/ControlClient/GetControl/main.go +++ b/internal/generated/snippets/retail/apiv2/ControlClient/GetControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ControlClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2/ControlClient/GetOperation/main.go index 14572a7613e2..bd02dfc2ef7e 100644 --- a/internal/generated/snippets/retail/apiv2/ControlClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2/ControlClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ControlClient/ListControls/main.go b/internal/generated/snippets/retail/apiv2/ControlClient/ListControls/main.go index f99fe6b530b7..41071c236a9d 100644 --- a/internal/generated/snippets/retail/apiv2/ControlClient/ListControls/main.go +++ b/internal/generated/snippets/retail/apiv2/ControlClient/ListControls/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ControlClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2/ControlClient/ListOperations/main.go index 2ee0c294f9c8..2ed0be0b4d02 100644 --- a/internal/generated/snippets/retail/apiv2/ControlClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2/ControlClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ControlClient/UpdateControl/main.go b/internal/generated/snippets/retail/apiv2/ControlClient/UpdateControl/main.go index aef9a19aed0f..2edf1335e998 100644 --- a/internal/generated/snippets/retail/apiv2/ControlClient/UpdateControl/main.go +++ b/internal/generated/snippets/retail/apiv2/ControlClient/UpdateControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/GenerativeQuestionClient/BatchUpdateGenerativeQuestionConfigs/main.go b/internal/generated/snippets/retail/apiv2/GenerativeQuestionClient/BatchUpdateGenerativeQuestionConfigs/main.go index 439dd1f4ed0e..6c73fc3a2e0b 100644 --- a/internal/generated/snippets/retail/apiv2/GenerativeQuestionClient/BatchUpdateGenerativeQuestionConfigs/main.go +++ b/internal/generated/snippets/retail/apiv2/GenerativeQuestionClient/BatchUpdateGenerativeQuestionConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/GenerativeQuestionClient/GetGenerativeQuestionsFeatureConfig/main.go b/internal/generated/snippets/retail/apiv2/GenerativeQuestionClient/GetGenerativeQuestionsFeatureConfig/main.go index bafdc3882bf5..91d9ad707732 100644 --- a/internal/generated/snippets/retail/apiv2/GenerativeQuestionClient/GetGenerativeQuestionsFeatureConfig/main.go +++ b/internal/generated/snippets/retail/apiv2/GenerativeQuestionClient/GetGenerativeQuestionsFeatureConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/GenerativeQuestionClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2/GenerativeQuestionClient/GetOperation/main.go index 2b1f76e66f90..169610a49c0d 100644 --- a/internal/generated/snippets/retail/apiv2/GenerativeQuestionClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2/GenerativeQuestionClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/GenerativeQuestionClient/ListGenerativeQuestionConfigs/main.go b/internal/generated/snippets/retail/apiv2/GenerativeQuestionClient/ListGenerativeQuestionConfigs/main.go index e63bd5097565..3128d935b9ee 100644 --- a/internal/generated/snippets/retail/apiv2/GenerativeQuestionClient/ListGenerativeQuestionConfigs/main.go +++ b/internal/generated/snippets/retail/apiv2/GenerativeQuestionClient/ListGenerativeQuestionConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/GenerativeQuestionClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2/GenerativeQuestionClient/ListOperations/main.go index 35ab12a1336a..192e810082d5 100644 --- a/internal/generated/snippets/retail/apiv2/GenerativeQuestionClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2/GenerativeQuestionClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/GenerativeQuestionClient/UpdateGenerativeQuestionConfig/main.go b/internal/generated/snippets/retail/apiv2/GenerativeQuestionClient/UpdateGenerativeQuestionConfig/main.go index 9d03800b9dce..79e97042acbe 100644 --- a/internal/generated/snippets/retail/apiv2/GenerativeQuestionClient/UpdateGenerativeQuestionConfig/main.go +++ b/internal/generated/snippets/retail/apiv2/GenerativeQuestionClient/UpdateGenerativeQuestionConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/GenerativeQuestionClient/UpdateGenerativeQuestionsFeatureConfig/main.go b/internal/generated/snippets/retail/apiv2/GenerativeQuestionClient/UpdateGenerativeQuestionsFeatureConfig/main.go index d1e3e54d9dd9..9fd862d05174 100644 --- a/internal/generated/snippets/retail/apiv2/GenerativeQuestionClient/UpdateGenerativeQuestionsFeatureConfig/main.go +++ b/internal/generated/snippets/retail/apiv2/GenerativeQuestionClient/UpdateGenerativeQuestionsFeatureConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ModelClient/CreateModel/main.go b/internal/generated/snippets/retail/apiv2/ModelClient/CreateModel/main.go index 90d7447a9c16..2752b2568319 100644 --- a/internal/generated/snippets/retail/apiv2/ModelClient/CreateModel/main.go +++ b/internal/generated/snippets/retail/apiv2/ModelClient/CreateModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ModelClient/DeleteModel/main.go b/internal/generated/snippets/retail/apiv2/ModelClient/DeleteModel/main.go index a9a72e270633..37c8dffecfec 100644 --- a/internal/generated/snippets/retail/apiv2/ModelClient/DeleteModel/main.go +++ b/internal/generated/snippets/retail/apiv2/ModelClient/DeleteModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ModelClient/GetModel/main.go b/internal/generated/snippets/retail/apiv2/ModelClient/GetModel/main.go index de6ea341d225..c03d400cf0e4 100644 --- a/internal/generated/snippets/retail/apiv2/ModelClient/GetModel/main.go +++ b/internal/generated/snippets/retail/apiv2/ModelClient/GetModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ModelClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2/ModelClient/GetOperation/main.go index 34f5db075988..e3c2a2fe4bad 100644 --- a/internal/generated/snippets/retail/apiv2/ModelClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2/ModelClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ModelClient/ListModels/main.go b/internal/generated/snippets/retail/apiv2/ModelClient/ListModels/main.go index 88aad7631ac6..7e2a4260905e 100644 --- a/internal/generated/snippets/retail/apiv2/ModelClient/ListModels/main.go +++ b/internal/generated/snippets/retail/apiv2/ModelClient/ListModels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ModelClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2/ModelClient/ListOperations/main.go index 5cd122534043..9f59a00f6e02 100644 --- a/internal/generated/snippets/retail/apiv2/ModelClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2/ModelClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ModelClient/PauseModel/main.go b/internal/generated/snippets/retail/apiv2/ModelClient/PauseModel/main.go index 60cabe6d6f5d..7a10613370cf 100644 --- a/internal/generated/snippets/retail/apiv2/ModelClient/PauseModel/main.go +++ b/internal/generated/snippets/retail/apiv2/ModelClient/PauseModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ModelClient/ResumeModel/main.go b/internal/generated/snippets/retail/apiv2/ModelClient/ResumeModel/main.go index c671662510e2..ff78ff649eec 100644 --- a/internal/generated/snippets/retail/apiv2/ModelClient/ResumeModel/main.go +++ b/internal/generated/snippets/retail/apiv2/ModelClient/ResumeModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ModelClient/TuneModel/main.go b/internal/generated/snippets/retail/apiv2/ModelClient/TuneModel/main.go index 73fde75ae8d9..7b5ae2be2c8a 100644 --- a/internal/generated/snippets/retail/apiv2/ModelClient/TuneModel/main.go +++ b/internal/generated/snippets/retail/apiv2/ModelClient/TuneModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ModelClient/UpdateModel/main.go b/internal/generated/snippets/retail/apiv2/ModelClient/UpdateModel/main.go index e580325fc95b..027b6229cd8e 100644 --- a/internal/generated/snippets/retail/apiv2/ModelClient/UpdateModel/main.go +++ b/internal/generated/snippets/retail/apiv2/ModelClient/UpdateModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/PredictionClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2/PredictionClient/GetOperation/main.go index 7727c10288bc..2e5584fa179e 100644 --- a/internal/generated/snippets/retail/apiv2/PredictionClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2/PredictionClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/PredictionClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2/PredictionClient/ListOperations/main.go index 656499158d40..f31093327b4b 100644 --- a/internal/generated/snippets/retail/apiv2/PredictionClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2/PredictionClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/PredictionClient/Predict/main.go b/internal/generated/snippets/retail/apiv2/PredictionClient/Predict/main.go index bf02145a7b58..7c5373e598e2 100644 --- a/internal/generated/snippets/retail/apiv2/PredictionClient/Predict/main.go +++ b/internal/generated/snippets/retail/apiv2/PredictionClient/Predict/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ProductClient/AddFulfillmentPlaces/main.go b/internal/generated/snippets/retail/apiv2/ProductClient/AddFulfillmentPlaces/main.go index f66adc9514d3..5fef37f3ce64 100644 --- a/internal/generated/snippets/retail/apiv2/ProductClient/AddFulfillmentPlaces/main.go +++ b/internal/generated/snippets/retail/apiv2/ProductClient/AddFulfillmentPlaces/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ProductClient/AddLocalInventories/main.go b/internal/generated/snippets/retail/apiv2/ProductClient/AddLocalInventories/main.go index dcfb6542a55d..aba4111fa136 100644 --- a/internal/generated/snippets/retail/apiv2/ProductClient/AddLocalInventories/main.go +++ b/internal/generated/snippets/retail/apiv2/ProductClient/AddLocalInventories/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ProductClient/CreateProduct/main.go b/internal/generated/snippets/retail/apiv2/ProductClient/CreateProduct/main.go index 88d9b1b90a81..45c4ba72768b 100644 --- a/internal/generated/snippets/retail/apiv2/ProductClient/CreateProduct/main.go +++ b/internal/generated/snippets/retail/apiv2/ProductClient/CreateProduct/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ProductClient/DeleteProduct/main.go b/internal/generated/snippets/retail/apiv2/ProductClient/DeleteProduct/main.go index bed80f5ce946..c2fa4086cea0 100644 --- a/internal/generated/snippets/retail/apiv2/ProductClient/DeleteProduct/main.go +++ b/internal/generated/snippets/retail/apiv2/ProductClient/DeleteProduct/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ProductClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2/ProductClient/GetOperation/main.go index 96a304af09c1..8f9323a7debf 100644 --- a/internal/generated/snippets/retail/apiv2/ProductClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2/ProductClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ProductClient/GetProduct/main.go b/internal/generated/snippets/retail/apiv2/ProductClient/GetProduct/main.go index 1d1a1fdc58ec..1ddfb2697a68 100644 --- a/internal/generated/snippets/retail/apiv2/ProductClient/GetProduct/main.go +++ b/internal/generated/snippets/retail/apiv2/ProductClient/GetProduct/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ProductClient/ImportProducts/main.go b/internal/generated/snippets/retail/apiv2/ProductClient/ImportProducts/main.go index e384fdb4d193..6aeca518a1db 100644 --- a/internal/generated/snippets/retail/apiv2/ProductClient/ImportProducts/main.go +++ b/internal/generated/snippets/retail/apiv2/ProductClient/ImportProducts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ProductClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2/ProductClient/ListOperations/main.go index eefaa300c62e..7e6ded548580 100644 --- a/internal/generated/snippets/retail/apiv2/ProductClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2/ProductClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ProductClient/ListProducts/main.go b/internal/generated/snippets/retail/apiv2/ProductClient/ListProducts/main.go index e92fd0e77396..c5cc2d057782 100644 --- a/internal/generated/snippets/retail/apiv2/ProductClient/ListProducts/main.go +++ b/internal/generated/snippets/retail/apiv2/ProductClient/ListProducts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ProductClient/PurgeProducts/main.go b/internal/generated/snippets/retail/apiv2/ProductClient/PurgeProducts/main.go index badd2b68d913..474dac1a197a 100644 --- a/internal/generated/snippets/retail/apiv2/ProductClient/PurgeProducts/main.go +++ b/internal/generated/snippets/retail/apiv2/ProductClient/PurgeProducts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ProductClient/RemoveFulfillmentPlaces/main.go b/internal/generated/snippets/retail/apiv2/ProductClient/RemoveFulfillmentPlaces/main.go index 4812a7acd656..ce521c5b5f8e 100644 --- a/internal/generated/snippets/retail/apiv2/ProductClient/RemoveFulfillmentPlaces/main.go +++ b/internal/generated/snippets/retail/apiv2/ProductClient/RemoveFulfillmentPlaces/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ProductClient/RemoveLocalInventories/main.go b/internal/generated/snippets/retail/apiv2/ProductClient/RemoveLocalInventories/main.go index ac1809aedc68..4bdd4efdae6c 100644 --- a/internal/generated/snippets/retail/apiv2/ProductClient/RemoveLocalInventories/main.go +++ b/internal/generated/snippets/retail/apiv2/ProductClient/RemoveLocalInventories/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ProductClient/SetInventory/main.go b/internal/generated/snippets/retail/apiv2/ProductClient/SetInventory/main.go index a8113f175698..e43fabc4cc84 100644 --- a/internal/generated/snippets/retail/apiv2/ProductClient/SetInventory/main.go +++ b/internal/generated/snippets/retail/apiv2/ProductClient/SetInventory/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ProductClient/UpdateProduct/main.go b/internal/generated/snippets/retail/apiv2/ProductClient/UpdateProduct/main.go index 30ab0481bd1e..c3d9acf0f4f2 100644 --- a/internal/generated/snippets/retail/apiv2/ProductClient/UpdateProduct/main.go +++ b/internal/generated/snippets/retail/apiv2/ProductClient/UpdateProduct/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/SearchClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2/SearchClient/GetOperation/main.go index 8c802acef9a3..9fddc5c2ff3d 100644 --- a/internal/generated/snippets/retail/apiv2/SearchClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2/SearchClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/SearchClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2/SearchClient/ListOperations/main.go index 01f8d5d91730..6ccd167a6a19 100644 --- a/internal/generated/snippets/retail/apiv2/SearchClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2/SearchClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/SearchClient/Search/main.go b/internal/generated/snippets/retail/apiv2/SearchClient/Search/main.go index 26bd1d82c94b..c56fe6cc74be 100644 --- a/internal/generated/snippets/retail/apiv2/SearchClient/Search/main.go +++ b/internal/generated/snippets/retail/apiv2/SearchClient/Search/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ServingConfigClient/AddControl/main.go b/internal/generated/snippets/retail/apiv2/ServingConfigClient/AddControl/main.go index 4ebea40ee36f..c697fc3d80c2 100644 --- a/internal/generated/snippets/retail/apiv2/ServingConfigClient/AddControl/main.go +++ b/internal/generated/snippets/retail/apiv2/ServingConfigClient/AddControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ServingConfigClient/CreateServingConfig/main.go b/internal/generated/snippets/retail/apiv2/ServingConfigClient/CreateServingConfig/main.go index 58a8c86b5e4a..ac5ba2ed370b 100644 --- a/internal/generated/snippets/retail/apiv2/ServingConfigClient/CreateServingConfig/main.go +++ b/internal/generated/snippets/retail/apiv2/ServingConfigClient/CreateServingConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ServingConfigClient/DeleteServingConfig/main.go b/internal/generated/snippets/retail/apiv2/ServingConfigClient/DeleteServingConfig/main.go index d37726d6620c..9b4da8a2373c 100644 --- a/internal/generated/snippets/retail/apiv2/ServingConfigClient/DeleteServingConfig/main.go +++ b/internal/generated/snippets/retail/apiv2/ServingConfigClient/DeleteServingConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ServingConfigClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2/ServingConfigClient/GetOperation/main.go index f30ae60cd383..a965d165d6e4 100644 --- a/internal/generated/snippets/retail/apiv2/ServingConfigClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2/ServingConfigClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ServingConfigClient/GetServingConfig/main.go b/internal/generated/snippets/retail/apiv2/ServingConfigClient/GetServingConfig/main.go index 8a78114e8cb1..1ab9fe03421b 100644 --- a/internal/generated/snippets/retail/apiv2/ServingConfigClient/GetServingConfig/main.go +++ b/internal/generated/snippets/retail/apiv2/ServingConfigClient/GetServingConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ServingConfigClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2/ServingConfigClient/ListOperations/main.go index b7c3bc06891d..992ae6ecc7a9 100644 --- a/internal/generated/snippets/retail/apiv2/ServingConfigClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2/ServingConfigClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ServingConfigClient/ListServingConfigs/main.go b/internal/generated/snippets/retail/apiv2/ServingConfigClient/ListServingConfigs/main.go index 755493ec662f..1b270242c72b 100644 --- a/internal/generated/snippets/retail/apiv2/ServingConfigClient/ListServingConfigs/main.go +++ b/internal/generated/snippets/retail/apiv2/ServingConfigClient/ListServingConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ServingConfigClient/RemoveControl/main.go b/internal/generated/snippets/retail/apiv2/ServingConfigClient/RemoveControl/main.go index 86f6745bca15..0f3c1319c18a 100644 --- a/internal/generated/snippets/retail/apiv2/ServingConfigClient/RemoveControl/main.go +++ b/internal/generated/snippets/retail/apiv2/ServingConfigClient/RemoveControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/ServingConfigClient/UpdateServingConfig/main.go b/internal/generated/snippets/retail/apiv2/ServingConfigClient/UpdateServingConfig/main.go index 518b379f0fec..3b4e369e2d22 100644 --- a/internal/generated/snippets/retail/apiv2/ServingConfigClient/UpdateServingConfig/main.go +++ b/internal/generated/snippets/retail/apiv2/ServingConfigClient/UpdateServingConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/UserEventClient/CollectUserEvent/main.go b/internal/generated/snippets/retail/apiv2/UserEventClient/CollectUserEvent/main.go index 3748e63aab97..a57ef53db4f8 100644 --- a/internal/generated/snippets/retail/apiv2/UserEventClient/CollectUserEvent/main.go +++ b/internal/generated/snippets/retail/apiv2/UserEventClient/CollectUserEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/UserEventClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2/UserEventClient/GetOperation/main.go index ddadb3949956..be7460ec04ce 100644 --- a/internal/generated/snippets/retail/apiv2/UserEventClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2/UserEventClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/UserEventClient/ImportUserEvents/main.go b/internal/generated/snippets/retail/apiv2/UserEventClient/ImportUserEvents/main.go index d3ab34bc88d7..e8a4883dea02 100644 --- a/internal/generated/snippets/retail/apiv2/UserEventClient/ImportUserEvents/main.go +++ b/internal/generated/snippets/retail/apiv2/UserEventClient/ImportUserEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/UserEventClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2/UserEventClient/ListOperations/main.go index 1fc8e24a3d9d..0fd9ae84bbd5 100644 --- a/internal/generated/snippets/retail/apiv2/UserEventClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2/UserEventClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/UserEventClient/PurgeUserEvents/main.go b/internal/generated/snippets/retail/apiv2/UserEventClient/PurgeUserEvents/main.go index f292d58934c9..4ee0fe694940 100644 --- a/internal/generated/snippets/retail/apiv2/UserEventClient/PurgeUserEvents/main.go +++ b/internal/generated/snippets/retail/apiv2/UserEventClient/PurgeUserEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/UserEventClient/RejoinUserEvents/main.go b/internal/generated/snippets/retail/apiv2/UserEventClient/RejoinUserEvents/main.go index 2e213ccaaebc..9a46469dc89d 100644 --- a/internal/generated/snippets/retail/apiv2/UserEventClient/RejoinUserEvents/main.go +++ b/internal/generated/snippets/retail/apiv2/UserEventClient/RejoinUserEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/UserEventClient/WriteUserEvent/main.go b/internal/generated/snippets/retail/apiv2/UserEventClient/WriteUserEvent/main.go index cd0e3ab073d2..f2374d15bd7c 100644 --- a/internal/generated/snippets/retail/apiv2/UserEventClient/WriteUserEvent/main.go +++ b/internal/generated/snippets/retail/apiv2/UserEventClient/WriteUserEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2/snippet_metadata.google.cloud.retail.v2.json b/internal/generated/snippets/retail/apiv2/snippet_metadata.google.cloud.retail.v2.json index 919f1b131609..a8a5b581f353 100644 --- a/internal/generated/snippets/retail/apiv2/snippet_metadata.google.cloud.retail.v2.json +++ b/internal/generated/snippets/retail/apiv2/snippet_metadata.google.cloud.retail.v2.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/retail/apiv2", - "version": "1.19.1", + "version": "1.19.2", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/retail/apiv2alpha/AnalyticsClient/ExportAnalyticsMetrics/main.go b/internal/generated/snippets/retail/apiv2alpha/AnalyticsClient/ExportAnalyticsMetrics/main.go index 106f958aae26..126fd0e35fe3 100644 --- a/internal/generated/snippets/retail/apiv2alpha/AnalyticsClient/ExportAnalyticsMetrics/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/AnalyticsClient/ExportAnalyticsMetrics/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/AnalyticsClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2alpha/AnalyticsClient/GetOperation/main.go index 9a152f9994bc..b6aaa6c3984c 100644 --- a/internal/generated/snippets/retail/apiv2alpha/AnalyticsClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/AnalyticsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/AnalyticsClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2alpha/AnalyticsClient/ListOperations/main.go index fa57899c9d45..84ee289b81a0 100644 --- a/internal/generated/snippets/retail/apiv2alpha/AnalyticsClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/AnalyticsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/BranchClient/GetBranch/main.go b/internal/generated/snippets/retail/apiv2alpha/BranchClient/GetBranch/main.go index fc9925fae058..52593d7b08dc 100644 --- a/internal/generated/snippets/retail/apiv2alpha/BranchClient/GetBranch/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/BranchClient/GetBranch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/BranchClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2alpha/BranchClient/GetOperation/main.go index b6513fe05f5e..69b384c8d85c 100644 --- a/internal/generated/snippets/retail/apiv2alpha/BranchClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/BranchClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/BranchClient/ListBranches/main.go b/internal/generated/snippets/retail/apiv2alpha/BranchClient/ListBranches/main.go index dbc6b42dd3bc..dda6e6cb2c5c 100644 --- a/internal/generated/snippets/retail/apiv2alpha/BranchClient/ListBranches/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/BranchClient/ListBranches/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/BranchClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2alpha/BranchClient/ListOperations/main.go index 3cf5ad604e2c..1f873afca39a 100644 --- a/internal/generated/snippets/retail/apiv2alpha/BranchClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/BranchClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/CatalogClient/AddCatalogAttribute/main.go b/internal/generated/snippets/retail/apiv2alpha/CatalogClient/AddCatalogAttribute/main.go index b22725e133c6..0b70654975bb 100644 --- a/internal/generated/snippets/retail/apiv2alpha/CatalogClient/AddCatalogAttribute/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/CatalogClient/AddCatalogAttribute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/CatalogClient/BatchRemoveCatalogAttributes/main.go b/internal/generated/snippets/retail/apiv2alpha/CatalogClient/BatchRemoveCatalogAttributes/main.go index 6fd2572b8c7a..cef2b59c267e 100644 --- a/internal/generated/snippets/retail/apiv2alpha/CatalogClient/BatchRemoveCatalogAttributes/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/CatalogClient/BatchRemoveCatalogAttributes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/CatalogClient/GetAttributesConfig/main.go b/internal/generated/snippets/retail/apiv2alpha/CatalogClient/GetAttributesConfig/main.go index 752b9916a81a..c2caf269b4e7 100644 --- a/internal/generated/snippets/retail/apiv2alpha/CatalogClient/GetAttributesConfig/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/CatalogClient/GetAttributesConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/CatalogClient/GetCompletionConfig/main.go b/internal/generated/snippets/retail/apiv2alpha/CatalogClient/GetCompletionConfig/main.go index 91f1794c063e..da1096a22dc6 100644 --- a/internal/generated/snippets/retail/apiv2alpha/CatalogClient/GetCompletionConfig/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/CatalogClient/GetCompletionConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/CatalogClient/GetDefaultBranch/main.go b/internal/generated/snippets/retail/apiv2alpha/CatalogClient/GetDefaultBranch/main.go index 3da4166f5721..0f11768d840c 100644 --- a/internal/generated/snippets/retail/apiv2alpha/CatalogClient/GetDefaultBranch/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/CatalogClient/GetDefaultBranch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/CatalogClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2alpha/CatalogClient/GetOperation/main.go index 293d5b0bd99b..00fa75cc4499 100644 --- a/internal/generated/snippets/retail/apiv2alpha/CatalogClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/CatalogClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/CatalogClient/ListCatalogs/main.go b/internal/generated/snippets/retail/apiv2alpha/CatalogClient/ListCatalogs/main.go index 41b03f21ee40..56560e59f293 100644 --- a/internal/generated/snippets/retail/apiv2alpha/CatalogClient/ListCatalogs/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/CatalogClient/ListCatalogs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/CatalogClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2alpha/CatalogClient/ListOperations/main.go index cd3057ec6250..816ae6aee917 100644 --- a/internal/generated/snippets/retail/apiv2alpha/CatalogClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/CatalogClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/CatalogClient/RemoveCatalogAttribute/main.go b/internal/generated/snippets/retail/apiv2alpha/CatalogClient/RemoveCatalogAttribute/main.go index b717e6832f93..27a66b058722 100644 --- a/internal/generated/snippets/retail/apiv2alpha/CatalogClient/RemoveCatalogAttribute/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/CatalogClient/RemoveCatalogAttribute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/CatalogClient/ReplaceCatalogAttribute/main.go b/internal/generated/snippets/retail/apiv2alpha/CatalogClient/ReplaceCatalogAttribute/main.go index 69f826c0bc18..7aa7606d17d0 100644 --- a/internal/generated/snippets/retail/apiv2alpha/CatalogClient/ReplaceCatalogAttribute/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/CatalogClient/ReplaceCatalogAttribute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/CatalogClient/SetDefaultBranch/main.go b/internal/generated/snippets/retail/apiv2alpha/CatalogClient/SetDefaultBranch/main.go index f23f24eb9777..d1ea8616e11b 100644 --- a/internal/generated/snippets/retail/apiv2alpha/CatalogClient/SetDefaultBranch/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/CatalogClient/SetDefaultBranch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/CatalogClient/UpdateAttributesConfig/main.go b/internal/generated/snippets/retail/apiv2alpha/CatalogClient/UpdateAttributesConfig/main.go index 8ca7ef0328d9..22a1804a62d5 100644 --- a/internal/generated/snippets/retail/apiv2alpha/CatalogClient/UpdateAttributesConfig/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/CatalogClient/UpdateAttributesConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/CatalogClient/UpdateCatalog/main.go b/internal/generated/snippets/retail/apiv2alpha/CatalogClient/UpdateCatalog/main.go index 50a27dc68e02..ce76dea61a8c 100644 --- a/internal/generated/snippets/retail/apiv2alpha/CatalogClient/UpdateCatalog/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/CatalogClient/UpdateCatalog/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/CatalogClient/UpdateCompletionConfig/main.go b/internal/generated/snippets/retail/apiv2alpha/CatalogClient/UpdateCompletionConfig/main.go index ad1aa526dbda..aeb9b9e25f14 100644 --- a/internal/generated/snippets/retail/apiv2alpha/CatalogClient/UpdateCompletionConfig/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/CatalogClient/UpdateCompletionConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/CompletionClient/CompleteQuery/main.go b/internal/generated/snippets/retail/apiv2alpha/CompletionClient/CompleteQuery/main.go index 73d4b89f52cc..7d12b6cd83c8 100644 --- a/internal/generated/snippets/retail/apiv2alpha/CompletionClient/CompleteQuery/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/CompletionClient/CompleteQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/CompletionClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2alpha/CompletionClient/GetOperation/main.go index 7088e135153b..47a16bc4fc7a 100644 --- a/internal/generated/snippets/retail/apiv2alpha/CompletionClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/CompletionClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/CompletionClient/ImportCompletionData/main.go b/internal/generated/snippets/retail/apiv2alpha/CompletionClient/ImportCompletionData/main.go index 55ee30739604..d1679289e57b 100644 --- a/internal/generated/snippets/retail/apiv2alpha/CompletionClient/ImportCompletionData/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/CompletionClient/ImportCompletionData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/CompletionClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2alpha/CompletionClient/ListOperations/main.go index 09d1644b8b15..fc47d6dc9bd8 100644 --- a/internal/generated/snippets/retail/apiv2alpha/CompletionClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/CompletionClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ControlClient/CreateControl/main.go b/internal/generated/snippets/retail/apiv2alpha/ControlClient/CreateControl/main.go index 77c58eba461a..16d9f54a036f 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ControlClient/CreateControl/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ControlClient/CreateControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ControlClient/DeleteControl/main.go b/internal/generated/snippets/retail/apiv2alpha/ControlClient/DeleteControl/main.go index 93213f1cdecf..b4dd841e8cd8 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ControlClient/DeleteControl/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ControlClient/DeleteControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ControlClient/GetControl/main.go b/internal/generated/snippets/retail/apiv2alpha/ControlClient/GetControl/main.go index 5a3e6d2b6c85..7948193ec855 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ControlClient/GetControl/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ControlClient/GetControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ControlClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2alpha/ControlClient/GetOperation/main.go index 71948cf2d8b3..ce63df3e9cfa 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ControlClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ControlClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ControlClient/ListControls/main.go b/internal/generated/snippets/retail/apiv2alpha/ControlClient/ListControls/main.go index 51162fb8bfa4..f8a2e7a33020 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ControlClient/ListControls/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ControlClient/ListControls/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ControlClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2alpha/ControlClient/ListOperations/main.go index df639cef0b55..9768bcd485bd 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ControlClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ControlClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ControlClient/UpdateControl/main.go b/internal/generated/snippets/retail/apiv2alpha/ControlClient/UpdateControl/main.go index bdd0fd301639..56163e960a78 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ControlClient/UpdateControl/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ControlClient/UpdateControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/GenerativeQuestionClient/BatchUpdateGenerativeQuestionConfigs/main.go b/internal/generated/snippets/retail/apiv2alpha/GenerativeQuestionClient/BatchUpdateGenerativeQuestionConfigs/main.go index efb356133923..330e9f198b7f 100644 --- a/internal/generated/snippets/retail/apiv2alpha/GenerativeQuestionClient/BatchUpdateGenerativeQuestionConfigs/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/GenerativeQuestionClient/BatchUpdateGenerativeQuestionConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/GenerativeQuestionClient/GetGenerativeQuestionsFeatureConfig/main.go b/internal/generated/snippets/retail/apiv2alpha/GenerativeQuestionClient/GetGenerativeQuestionsFeatureConfig/main.go index 98069a5edad2..358e8060c70a 100644 --- a/internal/generated/snippets/retail/apiv2alpha/GenerativeQuestionClient/GetGenerativeQuestionsFeatureConfig/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/GenerativeQuestionClient/GetGenerativeQuestionsFeatureConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/GenerativeQuestionClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2alpha/GenerativeQuestionClient/GetOperation/main.go index 64d0c8bdd212..9323c4d13afb 100644 --- a/internal/generated/snippets/retail/apiv2alpha/GenerativeQuestionClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/GenerativeQuestionClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/GenerativeQuestionClient/ListGenerativeQuestionConfigs/main.go b/internal/generated/snippets/retail/apiv2alpha/GenerativeQuestionClient/ListGenerativeQuestionConfigs/main.go index 3a2325283880..e8ff12743307 100644 --- a/internal/generated/snippets/retail/apiv2alpha/GenerativeQuestionClient/ListGenerativeQuestionConfigs/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/GenerativeQuestionClient/ListGenerativeQuestionConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/GenerativeQuestionClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2alpha/GenerativeQuestionClient/ListOperations/main.go index 7e5745769a7c..d0fbc3ac1ec4 100644 --- a/internal/generated/snippets/retail/apiv2alpha/GenerativeQuestionClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/GenerativeQuestionClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/GenerativeQuestionClient/UpdateGenerativeQuestionConfig/main.go b/internal/generated/snippets/retail/apiv2alpha/GenerativeQuestionClient/UpdateGenerativeQuestionConfig/main.go index 814014d4a8db..bd8cb6a9ea73 100644 --- a/internal/generated/snippets/retail/apiv2alpha/GenerativeQuestionClient/UpdateGenerativeQuestionConfig/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/GenerativeQuestionClient/UpdateGenerativeQuestionConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/GenerativeQuestionClient/UpdateGenerativeQuestionsFeatureConfig/main.go b/internal/generated/snippets/retail/apiv2alpha/GenerativeQuestionClient/UpdateGenerativeQuestionsFeatureConfig/main.go index c9b9c346321a..070f6a0a1811 100644 --- a/internal/generated/snippets/retail/apiv2alpha/GenerativeQuestionClient/UpdateGenerativeQuestionsFeatureConfig/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/GenerativeQuestionClient/UpdateGenerativeQuestionsFeatureConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/MerchantCenterAccountLinkClient/CreateMerchantCenterAccountLink/main.go b/internal/generated/snippets/retail/apiv2alpha/MerchantCenterAccountLinkClient/CreateMerchantCenterAccountLink/main.go index 6eaabdc23170..ac8079634343 100644 --- a/internal/generated/snippets/retail/apiv2alpha/MerchantCenterAccountLinkClient/CreateMerchantCenterAccountLink/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/MerchantCenterAccountLinkClient/CreateMerchantCenterAccountLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/MerchantCenterAccountLinkClient/DeleteMerchantCenterAccountLink/main.go b/internal/generated/snippets/retail/apiv2alpha/MerchantCenterAccountLinkClient/DeleteMerchantCenterAccountLink/main.go index 6ebf938f68f0..f3897eb50cb7 100644 --- a/internal/generated/snippets/retail/apiv2alpha/MerchantCenterAccountLinkClient/DeleteMerchantCenterAccountLink/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/MerchantCenterAccountLinkClient/DeleteMerchantCenterAccountLink/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/MerchantCenterAccountLinkClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2alpha/MerchantCenterAccountLinkClient/GetOperation/main.go index 6b1045ca0e42..958b689da5ed 100644 --- a/internal/generated/snippets/retail/apiv2alpha/MerchantCenterAccountLinkClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/MerchantCenterAccountLinkClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/MerchantCenterAccountLinkClient/ListMerchantCenterAccountLinks/main.go b/internal/generated/snippets/retail/apiv2alpha/MerchantCenterAccountLinkClient/ListMerchantCenterAccountLinks/main.go index dba3cd143657..7de9b00132a8 100644 --- a/internal/generated/snippets/retail/apiv2alpha/MerchantCenterAccountLinkClient/ListMerchantCenterAccountLinks/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/MerchantCenterAccountLinkClient/ListMerchantCenterAccountLinks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/MerchantCenterAccountLinkClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2alpha/MerchantCenterAccountLinkClient/ListOperations/main.go index 42b1767f1bea..023b6612c6f9 100644 --- a/internal/generated/snippets/retail/apiv2alpha/MerchantCenterAccountLinkClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/MerchantCenterAccountLinkClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ModelClient/CreateModel/main.go b/internal/generated/snippets/retail/apiv2alpha/ModelClient/CreateModel/main.go index 474cc4326d13..3347afed4e9b 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ModelClient/CreateModel/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ModelClient/CreateModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ModelClient/DeleteModel/main.go b/internal/generated/snippets/retail/apiv2alpha/ModelClient/DeleteModel/main.go index 6230e11fbd3a..008dc91aa4c0 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ModelClient/DeleteModel/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ModelClient/DeleteModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ModelClient/GetModel/main.go b/internal/generated/snippets/retail/apiv2alpha/ModelClient/GetModel/main.go index ce55a5788297..d256e546bc76 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ModelClient/GetModel/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ModelClient/GetModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ModelClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2alpha/ModelClient/GetOperation/main.go index 6b754a52ae74..fa0c4eb047ad 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ModelClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ModelClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ModelClient/ListModels/main.go b/internal/generated/snippets/retail/apiv2alpha/ModelClient/ListModels/main.go index 4eaf76f2ef7b..ed37e7ef14ec 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ModelClient/ListModels/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ModelClient/ListModels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ModelClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2alpha/ModelClient/ListOperations/main.go index fb771c651dfa..e35c2c004f02 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ModelClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ModelClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ModelClient/PauseModel/main.go b/internal/generated/snippets/retail/apiv2alpha/ModelClient/PauseModel/main.go index 62a3b3d4edde..ef336fef38ec 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ModelClient/PauseModel/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ModelClient/PauseModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ModelClient/ResumeModel/main.go b/internal/generated/snippets/retail/apiv2alpha/ModelClient/ResumeModel/main.go index 0e44301ac390..ff09f0e69d43 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ModelClient/ResumeModel/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ModelClient/ResumeModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ModelClient/TuneModel/main.go b/internal/generated/snippets/retail/apiv2alpha/ModelClient/TuneModel/main.go index 9641ddf1486c..56aad19c06cc 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ModelClient/TuneModel/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ModelClient/TuneModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ModelClient/UpdateModel/main.go b/internal/generated/snippets/retail/apiv2alpha/ModelClient/UpdateModel/main.go index a29b87ea4ad7..da2b03ad3bd8 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ModelClient/UpdateModel/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ModelClient/UpdateModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/PredictionClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2alpha/PredictionClient/GetOperation/main.go index 8f33b72c4ddc..3c4649c808d1 100644 --- a/internal/generated/snippets/retail/apiv2alpha/PredictionClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/PredictionClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/PredictionClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2alpha/PredictionClient/ListOperations/main.go index c124036275e8..c4180466a37e 100644 --- a/internal/generated/snippets/retail/apiv2alpha/PredictionClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/PredictionClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/PredictionClient/Predict/main.go b/internal/generated/snippets/retail/apiv2alpha/PredictionClient/Predict/main.go index 61120d372f9e..ec26a47a0373 100644 --- a/internal/generated/snippets/retail/apiv2alpha/PredictionClient/Predict/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/PredictionClient/Predict/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ProductClient/AddFulfillmentPlaces/main.go b/internal/generated/snippets/retail/apiv2alpha/ProductClient/AddFulfillmentPlaces/main.go index f204a7865d1f..61e77b68286b 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ProductClient/AddFulfillmentPlaces/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ProductClient/AddFulfillmentPlaces/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ProductClient/AddLocalInventories/main.go b/internal/generated/snippets/retail/apiv2alpha/ProductClient/AddLocalInventories/main.go index 946aff5fb061..ddcfbacfbc40 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ProductClient/AddLocalInventories/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ProductClient/AddLocalInventories/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ProductClient/CreateProduct/main.go b/internal/generated/snippets/retail/apiv2alpha/ProductClient/CreateProduct/main.go index 484ded32336f..a9a64fd15a32 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ProductClient/CreateProduct/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ProductClient/CreateProduct/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ProductClient/DeleteProduct/main.go b/internal/generated/snippets/retail/apiv2alpha/ProductClient/DeleteProduct/main.go index eb382cc2785b..bf5f94b2d272 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ProductClient/DeleteProduct/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ProductClient/DeleteProduct/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ProductClient/ExportProducts/main.go b/internal/generated/snippets/retail/apiv2alpha/ProductClient/ExportProducts/main.go index 255104a52ac8..ae42ce678077 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ProductClient/ExportProducts/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ProductClient/ExportProducts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ProductClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2alpha/ProductClient/GetOperation/main.go index 385abef4c5e4..c3e02dce45b4 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ProductClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ProductClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ProductClient/GetProduct/main.go b/internal/generated/snippets/retail/apiv2alpha/ProductClient/GetProduct/main.go index e32cb532b658..2e2115619664 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ProductClient/GetProduct/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ProductClient/GetProduct/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ProductClient/ImportProducts/main.go b/internal/generated/snippets/retail/apiv2alpha/ProductClient/ImportProducts/main.go index 24350e8e756c..d98756ebc1a4 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ProductClient/ImportProducts/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ProductClient/ImportProducts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ProductClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2alpha/ProductClient/ListOperations/main.go index 3055b4e5dab8..01562eb2d2c1 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ProductClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ProductClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ProductClient/ListProducts/main.go b/internal/generated/snippets/retail/apiv2alpha/ProductClient/ListProducts/main.go index 5fab9b9f0d07..79d98a4dc387 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ProductClient/ListProducts/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ProductClient/ListProducts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ProductClient/PurgeProducts/main.go b/internal/generated/snippets/retail/apiv2alpha/ProductClient/PurgeProducts/main.go index 5cf92d5cf87b..55c26b385483 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ProductClient/PurgeProducts/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ProductClient/PurgeProducts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ProductClient/RemoveFulfillmentPlaces/main.go b/internal/generated/snippets/retail/apiv2alpha/ProductClient/RemoveFulfillmentPlaces/main.go index 32e2d6b02c85..85ffc841aba3 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ProductClient/RemoveFulfillmentPlaces/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ProductClient/RemoveFulfillmentPlaces/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ProductClient/RemoveLocalInventories/main.go b/internal/generated/snippets/retail/apiv2alpha/ProductClient/RemoveLocalInventories/main.go index e770dd724fa8..eb3a8e1e291e 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ProductClient/RemoveLocalInventories/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ProductClient/RemoveLocalInventories/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ProductClient/SetInventory/main.go b/internal/generated/snippets/retail/apiv2alpha/ProductClient/SetInventory/main.go index 2386903d8192..fcbccfce6ceb 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ProductClient/SetInventory/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ProductClient/SetInventory/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ProductClient/UpdateProduct/main.go b/internal/generated/snippets/retail/apiv2alpha/ProductClient/UpdateProduct/main.go index a6576fe7aaab..3ce6c60bfaa2 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ProductClient/UpdateProduct/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ProductClient/UpdateProduct/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ProjectClient/AcceptTerms/main.go b/internal/generated/snippets/retail/apiv2alpha/ProjectClient/AcceptTerms/main.go index f4eaa2f5cec0..a80e693560b6 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ProjectClient/AcceptTerms/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ProjectClient/AcceptTerms/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ProjectClient/EnrollSolution/main.go b/internal/generated/snippets/retail/apiv2alpha/ProjectClient/EnrollSolution/main.go index 4bc5b014ef64..c2bce29d4125 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ProjectClient/EnrollSolution/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ProjectClient/EnrollSolution/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ProjectClient/GetAlertConfig/main.go b/internal/generated/snippets/retail/apiv2alpha/ProjectClient/GetAlertConfig/main.go index 7c53ccc421aa..00ebb4d0df7d 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ProjectClient/GetAlertConfig/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ProjectClient/GetAlertConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ProjectClient/GetLoggingConfig/main.go b/internal/generated/snippets/retail/apiv2alpha/ProjectClient/GetLoggingConfig/main.go index cfdebf348d7e..9bfded448b3c 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ProjectClient/GetLoggingConfig/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ProjectClient/GetLoggingConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ProjectClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2alpha/ProjectClient/GetOperation/main.go index 989eb41dd62f..d30b9f492faa 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ProjectClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ProjectClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ProjectClient/GetProject/main.go b/internal/generated/snippets/retail/apiv2alpha/ProjectClient/GetProject/main.go index a463622e2e12..8efc83ecaaff 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ProjectClient/GetProject/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ProjectClient/GetProject/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ProjectClient/ListEnrolledSolutions/main.go b/internal/generated/snippets/retail/apiv2alpha/ProjectClient/ListEnrolledSolutions/main.go index fec39f7ad553..132ecc2f168a 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ProjectClient/ListEnrolledSolutions/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ProjectClient/ListEnrolledSolutions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ProjectClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2alpha/ProjectClient/ListOperations/main.go index 9ba33e5a8c3a..83f596ff782b 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ProjectClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ProjectClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ProjectClient/UpdateAlertConfig/main.go b/internal/generated/snippets/retail/apiv2alpha/ProjectClient/UpdateAlertConfig/main.go index 5dcdb9f0cf6b..9c4143fa3aa6 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ProjectClient/UpdateAlertConfig/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ProjectClient/UpdateAlertConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ProjectClient/UpdateLoggingConfig/main.go b/internal/generated/snippets/retail/apiv2alpha/ProjectClient/UpdateLoggingConfig/main.go index 893c35132308..4c2f1d3fecc3 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ProjectClient/UpdateLoggingConfig/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ProjectClient/UpdateLoggingConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/SearchClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2alpha/SearchClient/GetOperation/main.go index 8adcc168b619..78078cf07f23 100644 --- a/internal/generated/snippets/retail/apiv2alpha/SearchClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/SearchClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/SearchClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2alpha/SearchClient/ListOperations/main.go index b1905f23d33f..904ed38f5986 100644 --- a/internal/generated/snippets/retail/apiv2alpha/SearchClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/SearchClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/SearchClient/Search/main.go b/internal/generated/snippets/retail/apiv2alpha/SearchClient/Search/main.go index cde322e55292..6575e091afdf 100644 --- a/internal/generated/snippets/retail/apiv2alpha/SearchClient/Search/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/SearchClient/Search/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/AddControl/main.go b/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/AddControl/main.go index d2eaa3db5aa5..2058a39a707d 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/AddControl/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/AddControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/CreateServingConfig/main.go b/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/CreateServingConfig/main.go index 5ebacc5418d2..d830a80aaf4d 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/CreateServingConfig/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/CreateServingConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/DeleteServingConfig/main.go b/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/DeleteServingConfig/main.go index 0a2c6bd57e53..d9cd5cb5cbd1 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/DeleteServingConfig/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/DeleteServingConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/GetOperation/main.go index 2147fec0a1ec..6af2cad197ca 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/GetServingConfig/main.go b/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/GetServingConfig/main.go index 3724bd7a6c42..30a9fbe0f684 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/GetServingConfig/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/GetServingConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/ListOperations/main.go index 206758d9fce5..41017341e99e 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/ListServingConfigs/main.go b/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/ListServingConfigs/main.go index eddbfbb5f273..8a600aec54a9 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/ListServingConfigs/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/ListServingConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/RemoveControl/main.go b/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/RemoveControl/main.go index c34132526b86..5cf033a8dd7a 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/RemoveControl/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/RemoveControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/UpdateServingConfig/main.go b/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/UpdateServingConfig/main.go index c68c9bc420b4..9b10aa78bd18 100644 --- a/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/UpdateServingConfig/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/ServingConfigClient/UpdateServingConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/UserEventClient/CollectUserEvent/main.go b/internal/generated/snippets/retail/apiv2alpha/UserEventClient/CollectUserEvent/main.go index 29f6ff43bf5f..5a7c78625276 100644 --- a/internal/generated/snippets/retail/apiv2alpha/UserEventClient/CollectUserEvent/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/UserEventClient/CollectUserEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/UserEventClient/ExportUserEvents/main.go b/internal/generated/snippets/retail/apiv2alpha/UserEventClient/ExportUserEvents/main.go index c551af7b409b..c49b16ab7387 100644 --- a/internal/generated/snippets/retail/apiv2alpha/UserEventClient/ExportUserEvents/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/UserEventClient/ExportUserEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/UserEventClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2alpha/UserEventClient/GetOperation/main.go index 207d183ab0cc..923f94ca7294 100644 --- a/internal/generated/snippets/retail/apiv2alpha/UserEventClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/UserEventClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/UserEventClient/ImportUserEvents/main.go b/internal/generated/snippets/retail/apiv2alpha/UserEventClient/ImportUserEvents/main.go index 3bacaf4d049f..4dc14b65c076 100644 --- a/internal/generated/snippets/retail/apiv2alpha/UserEventClient/ImportUserEvents/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/UserEventClient/ImportUserEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/UserEventClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2alpha/UserEventClient/ListOperations/main.go index d1d74408e623..962b1611678f 100644 --- a/internal/generated/snippets/retail/apiv2alpha/UserEventClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/UserEventClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/UserEventClient/PurgeUserEvents/main.go b/internal/generated/snippets/retail/apiv2alpha/UserEventClient/PurgeUserEvents/main.go index 70a8af58fdd1..e68c039fe4df 100644 --- a/internal/generated/snippets/retail/apiv2alpha/UserEventClient/PurgeUserEvents/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/UserEventClient/PurgeUserEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/UserEventClient/RejoinUserEvents/main.go b/internal/generated/snippets/retail/apiv2alpha/UserEventClient/RejoinUserEvents/main.go index e9675746c586..3f96f4eb7287 100644 --- a/internal/generated/snippets/retail/apiv2alpha/UserEventClient/RejoinUserEvents/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/UserEventClient/RejoinUserEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/UserEventClient/WriteUserEvent/main.go b/internal/generated/snippets/retail/apiv2alpha/UserEventClient/WriteUserEvent/main.go index 931ef1cf3e2f..175300e133b3 100644 --- a/internal/generated/snippets/retail/apiv2alpha/UserEventClient/WriteUserEvent/main.go +++ b/internal/generated/snippets/retail/apiv2alpha/UserEventClient/WriteUserEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2alpha/snippet_metadata.google.cloud.retail.v2alpha.json b/internal/generated/snippets/retail/apiv2alpha/snippet_metadata.google.cloud.retail.v2alpha.json index e40cbfec29f1..53d4ca3a4456 100644 --- a/internal/generated/snippets/retail/apiv2alpha/snippet_metadata.google.cloud.retail.v2alpha.json +++ b/internal/generated/snippets/retail/apiv2alpha/snippet_metadata.google.cloud.retail.v2alpha.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/retail/apiv2alpha", - "version": "1.19.1", + "version": "1.19.2", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/retail/apiv2beta/AnalyticsClient/ExportAnalyticsMetrics/main.go b/internal/generated/snippets/retail/apiv2beta/AnalyticsClient/ExportAnalyticsMetrics/main.go index fcca4529ffcf..f3c413586c75 100644 --- a/internal/generated/snippets/retail/apiv2beta/AnalyticsClient/ExportAnalyticsMetrics/main.go +++ b/internal/generated/snippets/retail/apiv2beta/AnalyticsClient/ExportAnalyticsMetrics/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/AnalyticsClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2beta/AnalyticsClient/GetOperation/main.go index a4e41362548c..9a3027c1eef6 100644 --- a/internal/generated/snippets/retail/apiv2beta/AnalyticsClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2beta/AnalyticsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/AnalyticsClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2beta/AnalyticsClient/ListOperations/main.go index 575e1d15335a..b1d2de1ecf10 100644 --- a/internal/generated/snippets/retail/apiv2beta/AnalyticsClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2beta/AnalyticsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/CatalogClient/AddCatalogAttribute/main.go b/internal/generated/snippets/retail/apiv2beta/CatalogClient/AddCatalogAttribute/main.go index 99aeb82c4cd1..aace3f639790 100644 --- a/internal/generated/snippets/retail/apiv2beta/CatalogClient/AddCatalogAttribute/main.go +++ b/internal/generated/snippets/retail/apiv2beta/CatalogClient/AddCatalogAttribute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/CatalogClient/BatchRemoveCatalogAttributes/main.go b/internal/generated/snippets/retail/apiv2beta/CatalogClient/BatchRemoveCatalogAttributes/main.go index b26e4ad7208e..6fedce816537 100644 --- a/internal/generated/snippets/retail/apiv2beta/CatalogClient/BatchRemoveCatalogAttributes/main.go +++ b/internal/generated/snippets/retail/apiv2beta/CatalogClient/BatchRemoveCatalogAttributes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/CatalogClient/GetAttributesConfig/main.go b/internal/generated/snippets/retail/apiv2beta/CatalogClient/GetAttributesConfig/main.go index e181fbeffc97..d1424bc8b08d 100644 --- a/internal/generated/snippets/retail/apiv2beta/CatalogClient/GetAttributesConfig/main.go +++ b/internal/generated/snippets/retail/apiv2beta/CatalogClient/GetAttributesConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/CatalogClient/GetCompletionConfig/main.go b/internal/generated/snippets/retail/apiv2beta/CatalogClient/GetCompletionConfig/main.go index 66dd13a6f289..2744f678cb60 100644 --- a/internal/generated/snippets/retail/apiv2beta/CatalogClient/GetCompletionConfig/main.go +++ b/internal/generated/snippets/retail/apiv2beta/CatalogClient/GetCompletionConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/CatalogClient/GetDefaultBranch/main.go b/internal/generated/snippets/retail/apiv2beta/CatalogClient/GetDefaultBranch/main.go index 08a90e2db3e1..050db744e3cc 100644 --- a/internal/generated/snippets/retail/apiv2beta/CatalogClient/GetDefaultBranch/main.go +++ b/internal/generated/snippets/retail/apiv2beta/CatalogClient/GetDefaultBranch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/CatalogClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2beta/CatalogClient/GetOperation/main.go index 27606895e06a..f6fa8f3b9499 100644 --- a/internal/generated/snippets/retail/apiv2beta/CatalogClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2beta/CatalogClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/CatalogClient/ListCatalogs/main.go b/internal/generated/snippets/retail/apiv2beta/CatalogClient/ListCatalogs/main.go index 2b1bd66f8c50..2b7a29143703 100644 --- a/internal/generated/snippets/retail/apiv2beta/CatalogClient/ListCatalogs/main.go +++ b/internal/generated/snippets/retail/apiv2beta/CatalogClient/ListCatalogs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/CatalogClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2beta/CatalogClient/ListOperations/main.go index df6590d7375c..67d582b3cebf 100644 --- a/internal/generated/snippets/retail/apiv2beta/CatalogClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2beta/CatalogClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/CatalogClient/RemoveCatalogAttribute/main.go b/internal/generated/snippets/retail/apiv2beta/CatalogClient/RemoveCatalogAttribute/main.go index f4c4f7b5a66c..c1886d87a780 100644 --- a/internal/generated/snippets/retail/apiv2beta/CatalogClient/RemoveCatalogAttribute/main.go +++ b/internal/generated/snippets/retail/apiv2beta/CatalogClient/RemoveCatalogAttribute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/CatalogClient/ReplaceCatalogAttribute/main.go b/internal/generated/snippets/retail/apiv2beta/CatalogClient/ReplaceCatalogAttribute/main.go index b16e15a557bf..0d0c6173e7f2 100644 --- a/internal/generated/snippets/retail/apiv2beta/CatalogClient/ReplaceCatalogAttribute/main.go +++ b/internal/generated/snippets/retail/apiv2beta/CatalogClient/ReplaceCatalogAttribute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/CatalogClient/SetDefaultBranch/main.go b/internal/generated/snippets/retail/apiv2beta/CatalogClient/SetDefaultBranch/main.go index 48e2c223a0ba..842270daffbb 100644 --- a/internal/generated/snippets/retail/apiv2beta/CatalogClient/SetDefaultBranch/main.go +++ b/internal/generated/snippets/retail/apiv2beta/CatalogClient/SetDefaultBranch/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/CatalogClient/UpdateAttributesConfig/main.go b/internal/generated/snippets/retail/apiv2beta/CatalogClient/UpdateAttributesConfig/main.go index 39c69d64fb54..20682434b6d1 100644 --- a/internal/generated/snippets/retail/apiv2beta/CatalogClient/UpdateAttributesConfig/main.go +++ b/internal/generated/snippets/retail/apiv2beta/CatalogClient/UpdateAttributesConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/CatalogClient/UpdateCatalog/main.go b/internal/generated/snippets/retail/apiv2beta/CatalogClient/UpdateCatalog/main.go index 07ee78dd5945..c52810ee42b3 100644 --- a/internal/generated/snippets/retail/apiv2beta/CatalogClient/UpdateCatalog/main.go +++ b/internal/generated/snippets/retail/apiv2beta/CatalogClient/UpdateCatalog/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/CatalogClient/UpdateCompletionConfig/main.go b/internal/generated/snippets/retail/apiv2beta/CatalogClient/UpdateCompletionConfig/main.go index 5fc373c4dfef..42e5f744906d 100644 --- a/internal/generated/snippets/retail/apiv2beta/CatalogClient/UpdateCompletionConfig/main.go +++ b/internal/generated/snippets/retail/apiv2beta/CatalogClient/UpdateCompletionConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/CompletionClient/CompleteQuery/main.go b/internal/generated/snippets/retail/apiv2beta/CompletionClient/CompleteQuery/main.go index e3b9dde8d43e..f323ea131cf2 100644 --- a/internal/generated/snippets/retail/apiv2beta/CompletionClient/CompleteQuery/main.go +++ b/internal/generated/snippets/retail/apiv2beta/CompletionClient/CompleteQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/CompletionClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2beta/CompletionClient/GetOperation/main.go index 1a21cb62cb91..de86d42b4519 100644 --- a/internal/generated/snippets/retail/apiv2beta/CompletionClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2beta/CompletionClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/CompletionClient/ImportCompletionData/main.go b/internal/generated/snippets/retail/apiv2beta/CompletionClient/ImportCompletionData/main.go index 6d91a88a6e10..208cc61a13c3 100644 --- a/internal/generated/snippets/retail/apiv2beta/CompletionClient/ImportCompletionData/main.go +++ b/internal/generated/snippets/retail/apiv2beta/CompletionClient/ImportCompletionData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/CompletionClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2beta/CompletionClient/ListOperations/main.go index e15072126edf..17a5fc00095c 100644 --- a/internal/generated/snippets/retail/apiv2beta/CompletionClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2beta/CompletionClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ControlClient/CreateControl/main.go b/internal/generated/snippets/retail/apiv2beta/ControlClient/CreateControl/main.go index b070a2f20ef2..ae2cf1166b9f 100644 --- a/internal/generated/snippets/retail/apiv2beta/ControlClient/CreateControl/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ControlClient/CreateControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ControlClient/DeleteControl/main.go b/internal/generated/snippets/retail/apiv2beta/ControlClient/DeleteControl/main.go index bf67795998a8..280be23d0da4 100644 --- a/internal/generated/snippets/retail/apiv2beta/ControlClient/DeleteControl/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ControlClient/DeleteControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ControlClient/GetControl/main.go b/internal/generated/snippets/retail/apiv2beta/ControlClient/GetControl/main.go index cd9f28324d2f..93b2e262521a 100644 --- a/internal/generated/snippets/retail/apiv2beta/ControlClient/GetControl/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ControlClient/GetControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ControlClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2beta/ControlClient/GetOperation/main.go index 5957a59eacdd..efdf96bee372 100644 --- a/internal/generated/snippets/retail/apiv2beta/ControlClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ControlClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ControlClient/ListControls/main.go b/internal/generated/snippets/retail/apiv2beta/ControlClient/ListControls/main.go index 9b8c7e5dcc0a..501bb256d3d0 100644 --- a/internal/generated/snippets/retail/apiv2beta/ControlClient/ListControls/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ControlClient/ListControls/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ControlClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2beta/ControlClient/ListOperations/main.go index 8fd76e381023..483f8c08dc08 100644 --- a/internal/generated/snippets/retail/apiv2beta/ControlClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ControlClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ControlClient/UpdateControl/main.go b/internal/generated/snippets/retail/apiv2beta/ControlClient/UpdateControl/main.go index 0bc56bbcb2c4..3bf637cd27a2 100644 --- a/internal/generated/snippets/retail/apiv2beta/ControlClient/UpdateControl/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ControlClient/UpdateControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/GenerativeQuestionClient/BatchUpdateGenerativeQuestionConfigs/main.go b/internal/generated/snippets/retail/apiv2beta/GenerativeQuestionClient/BatchUpdateGenerativeQuestionConfigs/main.go index a894c3adb4ce..05333ee17ee6 100644 --- a/internal/generated/snippets/retail/apiv2beta/GenerativeQuestionClient/BatchUpdateGenerativeQuestionConfigs/main.go +++ b/internal/generated/snippets/retail/apiv2beta/GenerativeQuestionClient/BatchUpdateGenerativeQuestionConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/GenerativeQuestionClient/GetGenerativeQuestionsFeatureConfig/main.go b/internal/generated/snippets/retail/apiv2beta/GenerativeQuestionClient/GetGenerativeQuestionsFeatureConfig/main.go index 01b887a60695..41b89ee7aada 100644 --- a/internal/generated/snippets/retail/apiv2beta/GenerativeQuestionClient/GetGenerativeQuestionsFeatureConfig/main.go +++ b/internal/generated/snippets/retail/apiv2beta/GenerativeQuestionClient/GetGenerativeQuestionsFeatureConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/GenerativeQuestionClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2beta/GenerativeQuestionClient/GetOperation/main.go index bf44de6ed845..5ea09c82b7a7 100644 --- a/internal/generated/snippets/retail/apiv2beta/GenerativeQuestionClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2beta/GenerativeQuestionClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/GenerativeQuestionClient/ListGenerativeQuestionConfigs/main.go b/internal/generated/snippets/retail/apiv2beta/GenerativeQuestionClient/ListGenerativeQuestionConfigs/main.go index 62bacf9e1a71..585b430a73e6 100644 --- a/internal/generated/snippets/retail/apiv2beta/GenerativeQuestionClient/ListGenerativeQuestionConfigs/main.go +++ b/internal/generated/snippets/retail/apiv2beta/GenerativeQuestionClient/ListGenerativeQuestionConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/GenerativeQuestionClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2beta/GenerativeQuestionClient/ListOperations/main.go index 8fab1e8281eb..af45a380d091 100644 --- a/internal/generated/snippets/retail/apiv2beta/GenerativeQuestionClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2beta/GenerativeQuestionClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/GenerativeQuestionClient/UpdateGenerativeQuestionConfig/main.go b/internal/generated/snippets/retail/apiv2beta/GenerativeQuestionClient/UpdateGenerativeQuestionConfig/main.go index 5abf381cab24..8aa29014d170 100644 --- a/internal/generated/snippets/retail/apiv2beta/GenerativeQuestionClient/UpdateGenerativeQuestionConfig/main.go +++ b/internal/generated/snippets/retail/apiv2beta/GenerativeQuestionClient/UpdateGenerativeQuestionConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/GenerativeQuestionClient/UpdateGenerativeQuestionsFeatureConfig/main.go b/internal/generated/snippets/retail/apiv2beta/GenerativeQuestionClient/UpdateGenerativeQuestionsFeatureConfig/main.go index e93aa6d45d3f..5ac4830fb5d8 100644 --- a/internal/generated/snippets/retail/apiv2beta/GenerativeQuestionClient/UpdateGenerativeQuestionsFeatureConfig/main.go +++ b/internal/generated/snippets/retail/apiv2beta/GenerativeQuestionClient/UpdateGenerativeQuestionsFeatureConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ModelClient/CreateModel/main.go b/internal/generated/snippets/retail/apiv2beta/ModelClient/CreateModel/main.go index 35067b06aefe..b9cd7455ea22 100644 --- a/internal/generated/snippets/retail/apiv2beta/ModelClient/CreateModel/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ModelClient/CreateModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ModelClient/DeleteModel/main.go b/internal/generated/snippets/retail/apiv2beta/ModelClient/DeleteModel/main.go index 8834150392f8..0796841ec096 100644 --- a/internal/generated/snippets/retail/apiv2beta/ModelClient/DeleteModel/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ModelClient/DeleteModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ModelClient/GetModel/main.go b/internal/generated/snippets/retail/apiv2beta/ModelClient/GetModel/main.go index c859458a0951..81e386ef31aa 100644 --- a/internal/generated/snippets/retail/apiv2beta/ModelClient/GetModel/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ModelClient/GetModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ModelClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2beta/ModelClient/GetOperation/main.go index 04c428ac372b..1c9194679667 100644 --- a/internal/generated/snippets/retail/apiv2beta/ModelClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ModelClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ModelClient/ListModels/main.go b/internal/generated/snippets/retail/apiv2beta/ModelClient/ListModels/main.go index 9852ea19dea9..e0ba57607064 100644 --- a/internal/generated/snippets/retail/apiv2beta/ModelClient/ListModels/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ModelClient/ListModels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ModelClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2beta/ModelClient/ListOperations/main.go index 0eff4cb7158a..d2411cad75e0 100644 --- a/internal/generated/snippets/retail/apiv2beta/ModelClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ModelClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ModelClient/PauseModel/main.go b/internal/generated/snippets/retail/apiv2beta/ModelClient/PauseModel/main.go index 99b1502b674a..3ad9357f55b5 100644 --- a/internal/generated/snippets/retail/apiv2beta/ModelClient/PauseModel/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ModelClient/PauseModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ModelClient/ResumeModel/main.go b/internal/generated/snippets/retail/apiv2beta/ModelClient/ResumeModel/main.go index 93d327ad68cc..74e7542a7bf2 100644 --- a/internal/generated/snippets/retail/apiv2beta/ModelClient/ResumeModel/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ModelClient/ResumeModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ModelClient/TuneModel/main.go b/internal/generated/snippets/retail/apiv2beta/ModelClient/TuneModel/main.go index 32198d234351..e76553eb2c0b 100644 --- a/internal/generated/snippets/retail/apiv2beta/ModelClient/TuneModel/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ModelClient/TuneModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ModelClient/UpdateModel/main.go b/internal/generated/snippets/retail/apiv2beta/ModelClient/UpdateModel/main.go index 36fc4be809f2..f95deea519d1 100644 --- a/internal/generated/snippets/retail/apiv2beta/ModelClient/UpdateModel/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ModelClient/UpdateModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/PredictionClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2beta/PredictionClient/GetOperation/main.go index b901eaf038d2..aeebf61dd0d0 100644 --- a/internal/generated/snippets/retail/apiv2beta/PredictionClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2beta/PredictionClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/PredictionClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2beta/PredictionClient/ListOperations/main.go index c2f86d942ec5..0dbf22bed965 100644 --- a/internal/generated/snippets/retail/apiv2beta/PredictionClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2beta/PredictionClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/PredictionClient/Predict/main.go b/internal/generated/snippets/retail/apiv2beta/PredictionClient/Predict/main.go index fb6e1bcd1bc4..350de344303a 100644 --- a/internal/generated/snippets/retail/apiv2beta/PredictionClient/Predict/main.go +++ b/internal/generated/snippets/retail/apiv2beta/PredictionClient/Predict/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ProductClient/AddFulfillmentPlaces/main.go b/internal/generated/snippets/retail/apiv2beta/ProductClient/AddFulfillmentPlaces/main.go index ea0f7847c206..34b1556b8624 100644 --- a/internal/generated/snippets/retail/apiv2beta/ProductClient/AddFulfillmentPlaces/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ProductClient/AddFulfillmentPlaces/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ProductClient/AddLocalInventories/main.go b/internal/generated/snippets/retail/apiv2beta/ProductClient/AddLocalInventories/main.go index 5f9c151129c6..f0656249afc2 100644 --- a/internal/generated/snippets/retail/apiv2beta/ProductClient/AddLocalInventories/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ProductClient/AddLocalInventories/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ProductClient/CreateProduct/main.go b/internal/generated/snippets/retail/apiv2beta/ProductClient/CreateProduct/main.go index 52409816f9c5..f9fe79da3045 100644 --- a/internal/generated/snippets/retail/apiv2beta/ProductClient/CreateProduct/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ProductClient/CreateProduct/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ProductClient/DeleteProduct/main.go b/internal/generated/snippets/retail/apiv2beta/ProductClient/DeleteProduct/main.go index 30d29e7e8fde..c4f183a95f87 100644 --- a/internal/generated/snippets/retail/apiv2beta/ProductClient/DeleteProduct/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ProductClient/DeleteProduct/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ProductClient/ExportProducts/main.go b/internal/generated/snippets/retail/apiv2beta/ProductClient/ExportProducts/main.go index a1d6c0bf8d25..afdac6bd6dbc 100644 --- a/internal/generated/snippets/retail/apiv2beta/ProductClient/ExportProducts/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ProductClient/ExportProducts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ProductClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2beta/ProductClient/GetOperation/main.go index 2623ea591bfd..22f4850469b2 100644 --- a/internal/generated/snippets/retail/apiv2beta/ProductClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ProductClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ProductClient/GetProduct/main.go b/internal/generated/snippets/retail/apiv2beta/ProductClient/GetProduct/main.go index ae445b153596..ab33e1869abc 100644 --- a/internal/generated/snippets/retail/apiv2beta/ProductClient/GetProduct/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ProductClient/GetProduct/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ProductClient/ImportProducts/main.go b/internal/generated/snippets/retail/apiv2beta/ProductClient/ImportProducts/main.go index f02781aaf091..0f2b7c6b6d77 100644 --- a/internal/generated/snippets/retail/apiv2beta/ProductClient/ImportProducts/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ProductClient/ImportProducts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ProductClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2beta/ProductClient/ListOperations/main.go index f17350a3cd15..71a903667d9d 100644 --- a/internal/generated/snippets/retail/apiv2beta/ProductClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ProductClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ProductClient/ListProducts/main.go b/internal/generated/snippets/retail/apiv2beta/ProductClient/ListProducts/main.go index db840b16b251..4ab1aff4b202 100644 --- a/internal/generated/snippets/retail/apiv2beta/ProductClient/ListProducts/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ProductClient/ListProducts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ProductClient/PurgeProducts/main.go b/internal/generated/snippets/retail/apiv2beta/ProductClient/PurgeProducts/main.go index 96f510c0e5b9..ee3ee082e5ee 100644 --- a/internal/generated/snippets/retail/apiv2beta/ProductClient/PurgeProducts/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ProductClient/PurgeProducts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ProductClient/RemoveFulfillmentPlaces/main.go b/internal/generated/snippets/retail/apiv2beta/ProductClient/RemoveFulfillmentPlaces/main.go index 45649c7950b4..c36e168351da 100644 --- a/internal/generated/snippets/retail/apiv2beta/ProductClient/RemoveFulfillmentPlaces/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ProductClient/RemoveFulfillmentPlaces/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ProductClient/RemoveLocalInventories/main.go b/internal/generated/snippets/retail/apiv2beta/ProductClient/RemoveLocalInventories/main.go index 3c4e28cce7e8..282ee156ebba 100644 --- a/internal/generated/snippets/retail/apiv2beta/ProductClient/RemoveLocalInventories/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ProductClient/RemoveLocalInventories/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ProductClient/SetInventory/main.go b/internal/generated/snippets/retail/apiv2beta/ProductClient/SetInventory/main.go index 46d1cee71f28..0f7ee26ffc45 100644 --- a/internal/generated/snippets/retail/apiv2beta/ProductClient/SetInventory/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ProductClient/SetInventory/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ProductClient/UpdateProduct/main.go b/internal/generated/snippets/retail/apiv2beta/ProductClient/UpdateProduct/main.go index c777cebaaade..1c93d3ae91e1 100644 --- a/internal/generated/snippets/retail/apiv2beta/ProductClient/UpdateProduct/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ProductClient/UpdateProduct/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ProjectClient/GetAlertConfig/main.go b/internal/generated/snippets/retail/apiv2beta/ProjectClient/GetAlertConfig/main.go index ae41d26f72d0..e3d861b0af18 100644 --- a/internal/generated/snippets/retail/apiv2beta/ProjectClient/GetAlertConfig/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ProjectClient/GetAlertConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ProjectClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2beta/ProjectClient/GetOperation/main.go index 82f10e3c8a26..647ca7da256d 100644 --- a/internal/generated/snippets/retail/apiv2beta/ProjectClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ProjectClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ProjectClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2beta/ProjectClient/ListOperations/main.go index 1bb5811b6cab..a4fe7b7b17d2 100644 --- a/internal/generated/snippets/retail/apiv2beta/ProjectClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ProjectClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ProjectClient/UpdateAlertConfig/main.go b/internal/generated/snippets/retail/apiv2beta/ProjectClient/UpdateAlertConfig/main.go index 385bd9a7b8e1..aa2f3a6362c5 100644 --- a/internal/generated/snippets/retail/apiv2beta/ProjectClient/UpdateAlertConfig/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ProjectClient/UpdateAlertConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/SearchClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2beta/SearchClient/GetOperation/main.go index da30a30f6c19..b358236b1f9f 100644 --- a/internal/generated/snippets/retail/apiv2beta/SearchClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2beta/SearchClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/SearchClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2beta/SearchClient/ListOperations/main.go index 3be3121a6988..96890579a65d 100644 --- a/internal/generated/snippets/retail/apiv2beta/SearchClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2beta/SearchClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/SearchClient/Search/main.go b/internal/generated/snippets/retail/apiv2beta/SearchClient/Search/main.go index b1dcbb6a3b93..30dd3463bbbf 100644 --- a/internal/generated/snippets/retail/apiv2beta/SearchClient/Search/main.go +++ b/internal/generated/snippets/retail/apiv2beta/SearchClient/Search/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/AddControl/main.go b/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/AddControl/main.go index f73ada170189..e62e346ee388 100644 --- a/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/AddControl/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/AddControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/CreateServingConfig/main.go b/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/CreateServingConfig/main.go index 2a4381a48380..a2a0f2b18dd5 100644 --- a/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/CreateServingConfig/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/CreateServingConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/DeleteServingConfig/main.go b/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/DeleteServingConfig/main.go index 5e904fe335da..772c0d32c883 100644 --- a/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/DeleteServingConfig/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/DeleteServingConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/GetOperation/main.go index ede762661cb6..b36c9077a42e 100644 --- a/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/GetServingConfig/main.go b/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/GetServingConfig/main.go index 5e39b0b43713..2fd0f3eb1dc4 100644 --- a/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/GetServingConfig/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/GetServingConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/ListOperations/main.go index bf9318436ecb..cb3500ccb4b4 100644 --- a/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/ListServingConfigs/main.go b/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/ListServingConfigs/main.go index 5bdbb13b3dfe..d1845f299700 100644 --- a/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/ListServingConfigs/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/ListServingConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/RemoveControl/main.go b/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/RemoveControl/main.go index bef8b7c93594..cd93c1de9fff 100644 --- a/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/RemoveControl/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/RemoveControl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/UpdateServingConfig/main.go b/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/UpdateServingConfig/main.go index 013d9c72e7cc..402449159dec 100644 --- a/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/UpdateServingConfig/main.go +++ b/internal/generated/snippets/retail/apiv2beta/ServingConfigClient/UpdateServingConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/UserEventClient/CollectUserEvent/main.go b/internal/generated/snippets/retail/apiv2beta/UserEventClient/CollectUserEvent/main.go index 763fea035c64..44d3db1beaa3 100644 --- a/internal/generated/snippets/retail/apiv2beta/UserEventClient/CollectUserEvent/main.go +++ b/internal/generated/snippets/retail/apiv2beta/UserEventClient/CollectUserEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/UserEventClient/ExportUserEvents/main.go b/internal/generated/snippets/retail/apiv2beta/UserEventClient/ExportUserEvents/main.go index 48bdf383b315..479c151eed09 100644 --- a/internal/generated/snippets/retail/apiv2beta/UserEventClient/ExportUserEvents/main.go +++ b/internal/generated/snippets/retail/apiv2beta/UserEventClient/ExportUserEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/UserEventClient/GetOperation/main.go b/internal/generated/snippets/retail/apiv2beta/UserEventClient/GetOperation/main.go index 0544117ec2a0..e20e7274d37d 100644 --- a/internal/generated/snippets/retail/apiv2beta/UserEventClient/GetOperation/main.go +++ b/internal/generated/snippets/retail/apiv2beta/UserEventClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/UserEventClient/ImportUserEvents/main.go b/internal/generated/snippets/retail/apiv2beta/UserEventClient/ImportUserEvents/main.go index 80bf15e49945..6cdd7e248e84 100644 --- a/internal/generated/snippets/retail/apiv2beta/UserEventClient/ImportUserEvents/main.go +++ b/internal/generated/snippets/retail/apiv2beta/UserEventClient/ImportUserEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/UserEventClient/ListOperations/main.go b/internal/generated/snippets/retail/apiv2beta/UserEventClient/ListOperations/main.go index 42b186747741..e1ecd8efe1ee 100644 --- a/internal/generated/snippets/retail/apiv2beta/UserEventClient/ListOperations/main.go +++ b/internal/generated/snippets/retail/apiv2beta/UserEventClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/UserEventClient/PurgeUserEvents/main.go b/internal/generated/snippets/retail/apiv2beta/UserEventClient/PurgeUserEvents/main.go index dfe71fab13ed..997742257f37 100644 --- a/internal/generated/snippets/retail/apiv2beta/UserEventClient/PurgeUserEvents/main.go +++ b/internal/generated/snippets/retail/apiv2beta/UserEventClient/PurgeUserEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/UserEventClient/RejoinUserEvents/main.go b/internal/generated/snippets/retail/apiv2beta/UserEventClient/RejoinUserEvents/main.go index 3f1a04c0bc4c..a32e46322241 100644 --- a/internal/generated/snippets/retail/apiv2beta/UserEventClient/RejoinUserEvents/main.go +++ b/internal/generated/snippets/retail/apiv2beta/UserEventClient/RejoinUserEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/UserEventClient/WriteUserEvent/main.go b/internal/generated/snippets/retail/apiv2beta/UserEventClient/WriteUserEvent/main.go index 5f40e9a09f29..dd503a04eced 100644 --- a/internal/generated/snippets/retail/apiv2beta/UserEventClient/WriteUserEvent/main.go +++ b/internal/generated/snippets/retail/apiv2beta/UserEventClient/WriteUserEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/retail/apiv2beta/snippet_metadata.google.cloud.retail.v2beta.json b/internal/generated/snippets/retail/apiv2beta/snippet_metadata.google.cloud.retail.v2beta.json index 3407e6ad79ea..c30b17482d6b 100644 --- a/internal/generated/snippets/retail/apiv2beta/snippet_metadata.google.cloud.retail.v2beta.json +++ b/internal/generated/snippets/retail/apiv2beta/snippet_metadata.google.cloud.retail.v2beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/retail/apiv2beta", - "version": "1.19.1", + "version": "1.19.2", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/run/apiv2/BuildsClient/DeleteOperation/main.go b/internal/generated/snippets/run/apiv2/BuildsClient/DeleteOperation/main.go index c80e5c2fb1ed..07885a2590bc 100644 --- a/internal/generated/snippets/run/apiv2/BuildsClient/DeleteOperation/main.go +++ b/internal/generated/snippets/run/apiv2/BuildsClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/BuildsClient/GetOperation/main.go b/internal/generated/snippets/run/apiv2/BuildsClient/GetOperation/main.go index 6747dc0504b8..0044e83dde60 100644 --- a/internal/generated/snippets/run/apiv2/BuildsClient/GetOperation/main.go +++ b/internal/generated/snippets/run/apiv2/BuildsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/BuildsClient/ListOperations/main.go b/internal/generated/snippets/run/apiv2/BuildsClient/ListOperations/main.go index 204efaf1a38d..bae437380025 100644 --- a/internal/generated/snippets/run/apiv2/BuildsClient/ListOperations/main.go +++ b/internal/generated/snippets/run/apiv2/BuildsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/BuildsClient/SubmitBuild/main.go b/internal/generated/snippets/run/apiv2/BuildsClient/SubmitBuild/main.go index d064a59f6c27..d390e4b9c6b1 100644 --- a/internal/generated/snippets/run/apiv2/BuildsClient/SubmitBuild/main.go +++ b/internal/generated/snippets/run/apiv2/BuildsClient/SubmitBuild/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/BuildsClient/WaitOperation/main.go b/internal/generated/snippets/run/apiv2/BuildsClient/WaitOperation/main.go index 4648fe9ada98..dcc89bfa69d5 100644 --- a/internal/generated/snippets/run/apiv2/BuildsClient/WaitOperation/main.go +++ b/internal/generated/snippets/run/apiv2/BuildsClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/ExecutionsClient/CancelExecution/main.go b/internal/generated/snippets/run/apiv2/ExecutionsClient/CancelExecution/main.go index f25918e1a473..e6f9c9af9ee8 100644 --- a/internal/generated/snippets/run/apiv2/ExecutionsClient/CancelExecution/main.go +++ b/internal/generated/snippets/run/apiv2/ExecutionsClient/CancelExecution/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/ExecutionsClient/DeleteExecution/main.go b/internal/generated/snippets/run/apiv2/ExecutionsClient/DeleteExecution/main.go index 0058dda4a478..2526046d4bc5 100644 --- a/internal/generated/snippets/run/apiv2/ExecutionsClient/DeleteExecution/main.go +++ b/internal/generated/snippets/run/apiv2/ExecutionsClient/DeleteExecution/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/ExecutionsClient/DeleteOperation/main.go b/internal/generated/snippets/run/apiv2/ExecutionsClient/DeleteOperation/main.go index 02a567d0d21b..d044eef31f08 100644 --- a/internal/generated/snippets/run/apiv2/ExecutionsClient/DeleteOperation/main.go +++ b/internal/generated/snippets/run/apiv2/ExecutionsClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/ExecutionsClient/GetExecution/main.go b/internal/generated/snippets/run/apiv2/ExecutionsClient/GetExecution/main.go index f3445f123ce5..3d832a140fa6 100644 --- a/internal/generated/snippets/run/apiv2/ExecutionsClient/GetExecution/main.go +++ b/internal/generated/snippets/run/apiv2/ExecutionsClient/GetExecution/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/ExecutionsClient/GetOperation/main.go b/internal/generated/snippets/run/apiv2/ExecutionsClient/GetOperation/main.go index 5b66a87c907d..7f1b4d3971a4 100644 --- a/internal/generated/snippets/run/apiv2/ExecutionsClient/GetOperation/main.go +++ b/internal/generated/snippets/run/apiv2/ExecutionsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/ExecutionsClient/ListExecutions/main.go b/internal/generated/snippets/run/apiv2/ExecutionsClient/ListExecutions/main.go index 4d27e2b97471..e3270f152941 100644 --- a/internal/generated/snippets/run/apiv2/ExecutionsClient/ListExecutions/main.go +++ b/internal/generated/snippets/run/apiv2/ExecutionsClient/ListExecutions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/ExecutionsClient/ListOperations/main.go b/internal/generated/snippets/run/apiv2/ExecutionsClient/ListOperations/main.go index 99713a005c01..421e844e5900 100644 --- a/internal/generated/snippets/run/apiv2/ExecutionsClient/ListOperations/main.go +++ b/internal/generated/snippets/run/apiv2/ExecutionsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/ExecutionsClient/WaitOperation/main.go b/internal/generated/snippets/run/apiv2/ExecutionsClient/WaitOperation/main.go index 02a0e2e0594b..bb86431ce821 100644 --- a/internal/generated/snippets/run/apiv2/ExecutionsClient/WaitOperation/main.go +++ b/internal/generated/snippets/run/apiv2/ExecutionsClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/JobsClient/CreateJob/main.go b/internal/generated/snippets/run/apiv2/JobsClient/CreateJob/main.go index 11cc4a810b4c..76d7c63ffa51 100644 --- a/internal/generated/snippets/run/apiv2/JobsClient/CreateJob/main.go +++ b/internal/generated/snippets/run/apiv2/JobsClient/CreateJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/JobsClient/DeleteJob/main.go b/internal/generated/snippets/run/apiv2/JobsClient/DeleteJob/main.go index f7e4c4647d73..25f7ddbb0732 100644 --- a/internal/generated/snippets/run/apiv2/JobsClient/DeleteJob/main.go +++ b/internal/generated/snippets/run/apiv2/JobsClient/DeleteJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/JobsClient/DeleteOperation/main.go b/internal/generated/snippets/run/apiv2/JobsClient/DeleteOperation/main.go index 623f8c03f0fa..69b266a8993e 100644 --- a/internal/generated/snippets/run/apiv2/JobsClient/DeleteOperation/main.go +++ b/internal/generated/snippets/run/apiv2/JobsClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/JobsClient/GetIamPolicy/main.go b/internal/generated/snippets/run/apiv2/JobsClient/GetIamPolicy/main.go index 63779b408df8..3ad131b887a7 100644 --- a/internal/generated/snippets/run/apiv2/JobsClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/run/apiv2/JobsClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/JobsClient/GetJob/main.go b/internal/generated/snippets/run/apiv2/JobsClient/GetJob/main.go index eb3367f4d627..41f35f2358fd 100644 --- a/internal/generated/snippets/run/apiv2/JobsClient/GetJob/main.go +++ b/internal/generated/snippets/run/apiv2/JobsClient/GetJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/JobsClient/GetOperation/main.go b/internal/generated/snippets/run/apiv2/JobsClient/GetOperation/main.go index ed86e8e9da3c..f0273b082cb2 100644 --- a/internal/generated/snippets/run/apiv2/JobsClient/GetOperation/main.go +++ b/internal/generated/snippets/run/apiv2/JobsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/JobsClient/ListJobs/main.go b/internal/generated/snippets/run/apiv2/JobsClient/ListJobs/main.go index 566dc9ef9284..1da3b6cd2221 100644 --- a/internal/generated/snippets/run/apiv2/JobsClient/ListJobs/main.go +++ b/internal/generated/snippets/run/apiv2/JobsClient/ListJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/JobsClient/ListOperations/main.go b/internal/generated/snippets/run/apiv2/JobsClient/ListOperations/main.go index 198c92902110..3a60736ed68c 100644 --- a/internal/generated/snippets/run/apiv2/JobsClient/ListOperations/main.go +++ b/internal/generated/snippets/run/apiv2/JobsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/JobsClient/RunJob/main.go b/internal/generated/snippets/run/apiv2/JobsClient/RunJob/main.go index 4441a743f999..74d28d9d8a5f 100644 --- a/internal/generated/snippets/run/apiv2/JobsClient/RunJob/main.go +++ b/internal/generated/snippets/run/apiv2/JobsClient/RunJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/JobsClient/SetIamPolicy/main.go b/internal/generated/snippets/run/apiv2/JobsClient/SetIamPolicy/main.go index c273dfad7354..a188222b8607 100644 --- a/internal/generated/snippets/run/apiv2/JobsClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/run/apiv2/JobsClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/JobsClient/TestIamPermissions/main.go b/internal/generated/snippets/run/apiv2/JobsClient/TestIamPermissions/main.go index 4e128c9a055e..bc3727880111 100644 --- a/internal/generated/snippets/run/apiv2/JobsClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/run/apiv2/JobsClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/JobsClient/UpdateJob/main.go b/internal/generated/snippets/run/apiv2/JobsClient/UpdateJob/main.go index 8cdd0aaf9bdd..581203efbc8e 100644 --- a/internal/generated/snippets/run/apiv2/JobsClient/UpdateJob/main.go +++ b/internal/generated/snippets/run/apiv2/JobsClient/UpdateJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/JobsClient/WaitOperation/main.go b/internal/generated/snippets/run/apiv2/JobsClient/WaitOperation/main.go index 5175619f5927..f1c4dc9742e1 100644 --- a/internal/generated/snippets/run/apiv2/JobsClient/WaitOperation/main.go +++ b/internal/generated/snippets/run/apiv2/JobsClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/RevisionsClient/DeleteOperation/main.go b/internal/generated/snippets/run/apiv2/RevisionsClient/DeleteOperation/main.go index 9282ca86465c..817ce77c7277 100644 --- a/internal/generated/snippets/run/apiv2/RevisionsClient/DeleteOperation/main.go +++ b/internal/generated/snippets/run/apiv2/RevisionsClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/RevisionsClient/DeleteRevision/main.go b/internal/generated/snippets/run/apiv2/RevisionsClient/DeleteRevision/main.go index 79d55b105e7d..7736d070e7c7 100644 --- a/internal/generated/snippets/run/apiv2/RevisionsClient/DeleteRevision/main.go +++ b/internal/generated/snippets/run/apiv2/RevisionsClient/DeleteRevision/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/RevisionsClient/GetOperation/main.go b/internal/generated/snippets/run/apiv2/RevisionsClient/GetOperation/main.go index 62fb208c4449..302840cf40a9 100644 --- a/internal/generated/snippets/run/apiv2/RevisionsClient/GetOperation/main.go +++ b/internal/generated/snippets/run/apiv2/RevisionsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/RevisionsClient/GetRevision/main.go b/internal/generated/snippets/run/apiv2/RevisionsClient/GetRevision/main.go index 6efdf1476949..0b36439f44c6 100644 --- a/internal/generated/snippets/run/apiv2/RevisionsClient/GetRevision/main.go +++ b/internal/generated/snippets/run/apiv2/RevisionsClient/GetRevision/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/RevisionsClient/ListOperations/main.go b/internal/generated/snippets/run/apiv2/RevisionsClient/ListOperations/main.go index 5315f84135c4..acfc50ab572b 100644 --- a/internal/generated/snippets/run/apiv2/RevisionsClient/ListOperations/main.go +++ b/internal/generated/snippets/run/apiv2/RevisionsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/RevisionsClient/ListRevisions/main.go b/internal/generated/snippets/run/apiv2/RevisionsClient/ListRevisions/main.go index 240779fd5b3c..6d1ab243d36c 100644 --- a/internal/generated/snippets/run/apiv2/RevisionsClient/ListRevisions/main.go +++ b/internal/generated/snippets/run/apiv2/RevisionsClient/ListRevisions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/RevisionsClient/WaitOperation/main.go b/internal/generated/snippets/run/apiv2/RevisionsClient/WaitOperation/main.go index daa7a0d09a7d..f263ff9dff63 100644 --- a/internal/generated/snippets/run/apiv2/RevisionsClient/WaitOperation/main.go +++ b/internal/generated/snippets/run/apiv2/RevisionsClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/ServicesClient/CreateService/main.go b/internal/generated/snippets/run/apiv2/ServicesClient/CreateService/main.go index b387237313f8..258fb104481f 100644 --- a/internal/generated/snippets/run/apiv2/ServicesClient/CreateService/main.go +++ b/internal/generated/snippets/run/apiv2/ServicesClient/CreateService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/ServicesClient/DeleteOperation/main.go b/internal/generated/snippets/run/apiv2/ServicesClient/DeleteOperation/main.go index 0a562aa0b6de..fbf83319ade4 100644 --- a/internal/generated/snippets/run/apiv2/ServicesClient/DeleteOperation/main.go +++ b/internal/generated/snippets/run/apiv2/ServicesClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/ServicesClient/DeleteService/main.go b/internal/generated/snippets/run/apiv2/ServicesClient/DeleteService/main.go index 8fbc79c45156..43e4377dac04 100644 --- a/internal/generated/snippets/run/apiv2/ServicesClient/DeleteService/main.go +++ b/internal/generated/snippets/run/apiv2/ServicesClient/DeleteService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/ServicesClient/GetIamPolicy/main.go b/internal/generated/snippets/run/apiv2/ServicesClient/GetIamPolicy/main.go index 88dad9139cad..482a08f58401 100644 --- a/internal/generated/snippets/run/apiv2/ServicesClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/run/apiv2/ServicesClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/ServicesClient/GetOperation/main.go b/internal/generated/snippets/run/apiv2/ServicesClient/GetOperation/main.go index ab36b0cf8bef..b4752780f39c 100644 --- a/internal/generated/snippets/run/apiv2/ServicesClient/GetOperation/main.go +++ b/internal/generated/snippets/run/apiv2/ServicesClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/ServicesClient/GetService/main.go b/internal/generated/snippets/run/apiv2/ServicesClient/GetService/main.go index 4f3e1c42f028..0c9002d54726 100644 --- a/internal/generated/snippets/run/apiv2/ServicesClient/GetService/main.go +++ b/internal/generated/snippets/run/apiv2/ServicesClient/GetService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/ServicesClient/ListOperations/main.go b/internal/generated/snippets/run/apiv2/ServicesClient/ListOperations/main.go index 5c1cfbb0ad78..e5cb7161c395 100644 --- a/internal/generated/snippets/run/apiv2/ServicesClient/ListOperations/main.go +++ b/internal/generated/snippets/run/apiv2/ServicesClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/ServicesClient/ListServices/main.go b/internal/generated/snippets/run/apiv2/ServicesClient/ListServices/main.go index bb1420defe53..4991dbc78fef 100644 --- a/internal/generated/snippets/run/apiv2/ServicesClient/ListServices/main.go +++ b/internal/generated/snippets/run/apiv2/ServicesClient/ListServices/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/ServicesClient/SetIamPolicy/main.go b/internal/generated/snippets/run/apiv2/ServicesClient/SetIamPolicy/main.go index 703e800cf205..e85d2d8b5a9b 100644 --- a/internal/generated/snippets/run/apiv2/ServicesClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/run/apiv2/ServicesClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/ServicesClient/TestIamPermissions/main.go b/internal/generated/snippets/run/apiv2/ServicesClient/TestIamPermissions/main.go index 7dcab713af05..9cbe4fb86e9c 100644 --- a/internal/generated/snippets/run/apiv2/ServicesClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/run/apiv2/ServicesClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/ServicesClient/UpdateService/main.go b/internal/generated/snippets/run/apiv2/ServicesClient/UpdateService/main.go index 57c4c1211202..698aa6fdc8b0 100644 --- a/internal/generated/snippets/run/apiv2/ServicesClient/UpdateService/main.go +++ b/internal/generated/snippets/run/apiv2/ServicesClient/UpdateService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/ServicesClient/WaitOperation/main.go b/internal/generated/snippets/run/apiv2/ServicesClient/WaitOperation/main.go index b227e1d0685e..61198c7a7a1a 100644 --- a/internal/generated/snippets/run/apiv2/ServicesClient/WaitOperation/main.go +++ b/internal/generated/snippets/run/apiv2/ServicesClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/TasksClient/DeleteOperation/main.go b/internal/generated/snippets/run/apiv2/TasksClient/DeleteOperation/main.go index e152d841959d..fe47fdcbd5b4 100644 --- a/internal/generated/snippets/run/apiv2/TasksClient/DeleteOperation/main.go +++ b/internal/generated/snippets/run/apiv2/TasksClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/TasksClient/GetOperation/main.go b/internal/generated/snippets/run/apiv2/TasksClient/GetOperation/main.go index 227c5de1b869..dde3f582d2f8 100644 --- a/internal/generated/snippets/run/apiv2/TasksClient/GetOperation/main.go +++ b/internal/generated/snippets/run/apiv2/TasksClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/TasksClient/GetTask/main.go b/internal/generated/snippets/run/apiv2/TasksClient/GetTask/main.go index 8e0fb18c06d9..a05120da6548 100644 --- a/internal/generated/snippets/run/apiv2/TasksClient/GetTask/main.go +++ b/internal/generated/snippets/run/apiv2/TasksClient/GetTask/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/TasksClient/ListOperations/main.go b/internal/generated/snippets/run/apiv2/TasksClient/ListOperations/main.go index bbf4f47daa79..ef15972ed4c3 100644 --- a/internal/generated/snippets/run/apiv2/TasksClient/ListOperations/main.go +++ b/internal/generated/snippets/run/apiv2/TasksClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/TasksClient/ListTasks/main.go b/internal/generated/snippets/run/apiv2/TasksClient/ListTasks/main.go index 53e42a4e6500..dd4d6c9d2b4d 100644 --- a/internal/generated/snippets/run/apiv2/TasksClient/ListTasks/main.go +++ b/internal/generated/snippets/run/apiv2/TasksClient/ListTasks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/run/apiv2/TasksClient/WaitOperation/main.go b/internal/generated/snippets/run/apiv2/TasksClient/WaitOperation/main.go index 6ce445abbdb3..f001c9d7a283 100644 --- a/internal/generated/snippets/run/apiv2/TasksClient/WaitOperation/main.go +++ b/internal/generated/snippets/run/apiv2/TasksClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/CreateJob/main.go b/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/CreateJob/main.go index 2abd7437837e..0d76e7bceb9b 100644 --- a/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/CreateJob/main.go +++ b/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/CreateJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/DeleteJob/main.go b/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/DeleteJob/main.go index 233eb3f4412b..eb5243bb39f6 100644 --- a/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/DeleteJob/main.go +++ b/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/DeleteJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/GetJob/main.go b/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/GetJob/main.go index f88358ebea9e..a73ae5b12121 100644 --- a/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/GetJob/main.go +++ b/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/GetJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/GetLocation/main.go b/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/GetLocation/main.go index 6eeefb1439ed..18ddb5d1e5a1 100644 --- a/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/GetLocation/main.go +++ b/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/ListJobs/main.go b/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/ListJobs/main.go index 7dd0761907c7..a2bba5f9129d 100644 --- a/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/ListJobs/main.go +++ b/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/ListJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/ListLocations/main.go b/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/ListLocations/main.go index 8da7d576fc6e..b18edc4d6b0a 100644 --- a/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/ListLocations/main.go +++ b/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/PauseJob/main.go b/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/PauseJob/main.go index ed4916a0a499..a78a5378debc 100644 --- a/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/PauseJob/main.go +++ b/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/PauseJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/ResumeJob/main.go b/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/ResumeJob/main.go index 5737bf231f72..19bc2732a8c5 100644 --- a/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/ResumeJob/main.go +++ b/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/ResumeJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/RunJob/main.go b/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/RunJob/main.go index 618af7444ad5..df67c87cb5dc 100644 --- a/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/RunJob/main.go +++ b/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/RunJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/UpdateJob/main.go b/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/UpdateJob/main.go index 8ca64f789256..691fdd9f6dfa 100644 --- a/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/UpdateJob/main.go +++ b/internal/generated/snippets/scheduler/apiv1/CloudSchedulerClient/UpdateJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/CreateJob/main.go b/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/CreateJob/main.go index ab24250a1180..d134fb40eabd 100644 --- a/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/CreateJob/main.go +++ b/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/CreateJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/DeleteJob/main.go b/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/DeleteJob/main.go index 1342854d2ee8..b74f6aeb6a5f 100644 --- a/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/DeleteJob/main.go +++ b/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/DeleteJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/GetJob/main.go b/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/GetJob/main.go index 5193bc5c4620..5aeaf13ef672 100644 --- a/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/GetJob/main.go +++ b/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/GetJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/GetLocation/main.go b/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/GetLocation/main.go index 74c9fde45efa..a9da6e76b99b 100644 --- a/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/GetLocation/main.go +++ b/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/ListJobs/main.go b/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/ListJobs/main.go index ea8929d140fd..f173f61c7edb 100644 --- a/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/ListJobs/main.go +++ b/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/ListJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/ListLocations/main.go b/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/ListLocations/main.go index 995e7caccb0d..e86049824ba7 100644 --- a/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/ListLocations/main.go +++ b/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/PauseJob/main.go b/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/PauseJob/main.go index be9146b2733c..b7c3ef858344 100644 --- a/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/PauseJob/main.go +++ b/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/PauseJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/ResumeJob/main.go b/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/ResumeJob/main.go index 45ab13e47916..4e6b886a8977 100644 --- a/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/ResumeJob/main.go +++ b/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/ResumeJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/RunJob/main.go b/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/RunJob/main.go index 0c2a65dd55c0..332167e5eeee 100644 --- a/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/RunJob/main.go +++ b/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/RunJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/UpdateJob/main.go b/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/UpdateJob/main.go index faaef44a6786..67dfd2ddec70 100644 --- a/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/UpdateJob/main.go +++ b/internal/generated/snippets/scheduler/apiv1beta1/CloudSchedulerClient/UpdateJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1/Client/AccessSecretVersion/main.go b/internal/generated/snippets/secretmanager/apiv1/Client/AccessSecretVersion/main.go index 677974d5a22a..2769ae038c50 100644 --- a/internal/generated/snippets/secretmanager/apiv1/Client/AccessSecretVersion/main.go +++ b/internal/generated/snippets/secretmanager/apiv1/Client/AccessSecretVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1/Client/AddSecretVersion/main.go b/internal/generated/snippets/secretmanager/apiv1/Client/AddSecretVersion/main.go index ae321e972c1d..56e2576531aa 100644 --- a/internal/generated/snippets/secretmanager/apiv1/Client/AddSecretVersion/main.go +++ b/internal/generated/snippets/secretmanager/apiv1/Client/AddSecretVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1/Client/CreateSecret/main.go b/internal/generated/snippets/secretmanager/apiv1/Client/CreateSecret/main.go index ba2a9e8f8fb9..885ca98903bc 100644 --- a/internal/generated/snippets/secretmanager/apiv1/Client/CreateSecret/main.go +++ b/internal/generated/snippets/secretmanager/apiv1/Client/CreateSecret/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1/Client/DeleteSecret/main.go b/internal/generated/snippets/secretmanager/apiv1/Client/DeleteSecret/main.go index 813127fc0bef..f6f00c254298 100644 --- a/internal/generated/snippets/secretmanager/apiv1/Client/DeleteSecret/main.go +++ b/internal/generated/snippets/secretmanager/apiv1/Client/DeleteSecret/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1/Client/DestroySecretVersion/main.go b/internal/generated/snippets/secretmanager/apiv1/Client/DestroySecretVersion/main.go index ab9c3aed89c8..45de0edc3234 100644 --- a/internal/generated/snippets/secretmanager/apiv1/Client/DestroySecretVersion/main.go +++ b/internal/generated/snippets/secretmanager/apiv1/Client/DestroySecretVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1/Client/DisableSecretVersion/main.go b/internal/generated/snippets/secretmanager/apiv1/Client/DisableSecretVersion/main.go index c2b5bfec2fe2..f6a378f87a1a 100644 --- a/internal/generated/snippets/secretmanager/apiv1/Client/DisableSecretVersion/main.go +++ b/internal/generated/snippets/secretmanager/apiv1/Client/DisableSecretVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1/Client/EnableSecretVersion/main.go b/internal/generated/snippets/secretmanager/apiv1/Client/EnableSecretVersion/main.go index 5609b3195e97..f25b8bfe5b5e 100644 --- a/internal/generated/snippets/secretmanager/apiv1/Client/EnableSecretVersion/main.go +++ b/internal/generated/snippets/secretmanager/apiv1/Client/EnableSecretVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1/Client/GetIamPolicy/main.go b/internal/generated/snippets/secretmanager/apiv1/Client/GetIamPolicy/main.go index b3c1bdb132b0..57d0e45518dc 100644 --- a/internal/generated/snippets/secretmanager/apiv1/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/secretmanager/apiv1/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/secretmanager/apiv1/Client/GetLocation/main.go index 95a844c5e680..fd99a4a178fc 100644 --- a/internal/generated/snippets/secretmanager/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/secretmanager/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1/Client/GetSecret/main.go b/internal/generated/snippets/secretmanager/apiv1/Client/GetSecret/main.go index 2ac770ec0cd6..ce654b6f0c9b 100644 --- a/internal/generated/snippets/secretmanager/apiv1/Client/GetSecret/main.go +++ b/internal/generated/snippets/secretmanager/apiv1/Client/GetSecret/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1/Client/GetSecretVersion/main.go b/internal/generated/snippets/secretmanager/apiv1/Client/GetSecretVersion/main.go index 9a3dcaf53a25..acafb5cceeab 100644 --- a/internal/generated/snippets/secretmanager/apiv1/Client/GetSecretVersion/main.go +++ b/internal/generated/snippets/secretmanager/apiv1/Client/GetSecretVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/secretmanager/apiv1/Client/ListLocations/main.go index 37f4a04c844f..1b94cf76ab3f 100644 --- a/internal/generated/snippets/secretmanager/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/secretmanager/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1/Client/ListSecretVersions/main.go b/internal/generated/snippets/secretmanager/apiv1/Client/ListSecretVersions/main.go index f86877e3916e..50a63388b9d4 100644 --- a/internal/generated/snippets/secretmanager/apiv1/Client/ListSecretVersions/main.go +++ b/internal/generated/snippets/secretmanager/apiv1/Client/ListSecretVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1/Client/ListSecrets/main.go b/internal/generated/snippets/secretmanager/apiv1/Client/ListSecrets/main.go index 2e83ec4b0c41..2f31385bcfea 100644 --- a/internal/generated/snippets/secretmanager/apiv1/Client/ListSecrets/main.go +++ b/internal/generated/snippets/secretmanager/apiv1/Client/ListSecrets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1/Client/SetIamPolicy/main.go b/internal/generated/snippets/secretmanager/apiv1/Client/SetIamPolicy/main.go index 52f5c621dfda..bdfb653719e7 100644 --- a/internal/generated/snippets/secretmanager/apiv1/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/secretmanager/apiv1/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1/Client/TestIamPermissions/main.go b/internal/generated/snippets/secretmanager/apiv1/Client/TestIamPermissions/main.go index cbc111da9d33..1626c9e4a08f 100644 --- a/internal/generated/snippets/secretmanager/apiv1/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/secretmanager/apiv1/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1/Client/UpdateSecret/main.go b/internal/generated/snippets/secretmanager/apiv1/Client/UpdateSecret/main.go index 9c4e46fa93f2..006b856764d2 100644 --- a/internal/generated/snippets/secretmanager/apiv1/Client/UpdateSecret/main.go +++ b/internal/generated/snippets/secretmanager/apiv1/Client/UpdateSecret/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1/snippet_metadata.google.cloud.secretmanager.v1.json b/internal/generated/snippets/secretmanager/apiv1/snippet_metadata.google.cloud.secretmanager.v1.json index 8e8ffa8c87ca..f3bb03edbe4e 100644 --- a/internal/generated/snippets/secretmanager/apiv1/snippet_metadata.google.cloud.secretmanager.v1.json +++ b/internal/generated/snippets/secretmanager/apiv1/snippet_metadata.google.cloud.secretmanager.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/secretmanager/apiv1", - "version": "1.14.2", + "version": "1.14.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/secretmanager/apiv1beta2/Client/AccessSecretVersion/main.go b/internal/generated/snippets/secretmanager/apiv1beta2/Client/AccessSecretVersion/main.go index 785d315ffbd2..59be95d50cbe 100644 --- a/internal/generated/snippets/secretmanager/apiv1beta2/Client/AccessSecretVersion/main.go +++ b/internal/generated/snippets/secretmanager/apiv1beta2/Client/AccessSecretVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1beta2/Client/AddSecretVersion/main.go b/internal/generated/snippets/secretmanager/apiv1beta2/Client/AddSecretVersion/main.go index 9bb953d2a1e0..93a9099b4c4c 100644 --- a/internal/generated/snippets/secretmanager/apiv1beta2/Client/AddSecretVersion/main.go +++ b/internal/generated/snippets/secretmanager/apiv1beta2/Client/AddSecretVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1beta2/Client/CreateSecret/main.go b/internal/generated/snippets/secretmanager/apiv1beta2/Client/CreateSecret/main.go index 26a148a6cb62..6ce0a8934494 100644 --- a/internal/generated/snippets/secretmanager/apiv1beta2/Client/CreateSecret/main.go +++ b/internal/generated/snippets/secretmanager/apiv1beta2/Client/CreateSecret/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1beta2/Client/DeleteSecret/main.go b/internal/generated/snippets/secretmanager/apiv1beta2/Client/DeleteSecret/main.go index 3a14f4bbfe8f..d5285203a521 100644 --- a/internal/generated/snippets/secretmanager/apiv1beta2/Client/DeleteSecret/main.go +++ b/internal/generated/snippets/secretmanager/apiv1beta2/Client/DeleteSecret/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1beta2/Client/DestroySecretVersion/main.go b/internal/generated/snippets/secretmanager/apiv1beta2/Client/DestroySecretVersion/main.go index 1dd3e30c9b6e..35ac79f7ba63 100644 --- a/internal/generated/snippets/secretmanager/apiv1beta2/Client/DestroySecretVersion/main.go +++ b/internal/generated/snippets/secretmanager/apiv1beta2/Client/DestroySecretVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1beta2/Client/DisableSecretVersion/main.go b/internal/generated/snippets/secretmanager/apiv1beta2/Client/DisableSecretVersion/main.go index dabedefd1b1c..ae5c856d0067 100644 --- a/internal/generated/snippets/secretmanager/apiv1beta2/Client/DisableSecretVersion/main.go +++ b/internal/generated/snippets/secretmanager/apiv1beta2/Client/DisableSecretVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1beta2/Client/EnableSecretVersion/main.go b/internal/generated/snippets/secretmanager/apiv1beta2/Client/EnableSecretVersion/main.go index 2dbb49eb2646..9b795b0dfe08 100644 --- a/internal/generated/snippets/secretmanager/apiv1beta2/Client/EnableSecretVersion/main.go +++ b/internal/generated/snippets/secretmanager/apiv1beta2/Client/EnableSecretVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1beta2/Client/GetIamPolicy/main.go b/internal/generated/snippets/secretmanager/apiv1beta2/Client/GetIamPolicy/main.go index 2e2719f1ceb4..2b6ebe313ea8 100644 --- a/internal/generated/snippets/secretmanager/apiv1beta2/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/secretmanager/apiv1beta2/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1beta2/Client/GetLocation/main.go b/internal/generated/snippets/secretmanager/apiv1beta2/Client/GetLocation/main.go index f3ca73c6de6a..9170c81e703f 100644 --- a/internal/generated/snippets/secretmanager/apiv1beta2/Client/GetLocation/main.go +++ b/internal/generated/snippets/secretmanager/apiv1beta2/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1beta2/Client/GetSecret/main.go b/internal/generated/snippets/secretmanager/apiv1beta2/Client/GetSecret/main.go index a89891ff3396..fd998755e2d7 100644 --- a/internal/generated/snippets/secretmanager/apiv1beta2/Client/GetSecret/main.go +++ b/internal/generated/snippets/secretmanager/apiv1beta2/Client/GetSecret/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1beta2/Client/GetSecretVersion/main.go b/internal/generated/snippets/secretmanager/apiv1beta2/Client/GetSecretVersion/main.go index 64c31f5da18b..1a38b1ed908a 100644 --- a/internal/generated/snippets/secretmanager/apiv1beta2/Client/GetSecretVersion/main.go +++ b/internal/generated/snippets/secretmanager/apiv1beta2/Client/GetSecretVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1beta2/Client/ListLocations/main.go b/internal/generated/snippets/secretmanager/apiv1beta2/Client/ListLocations/main.go index 18a576656626..1246c1d0d102 100644 --- a/internal/generated/snippets/secretmanager/apiv1beta2/Client/ListLocations/main.go +++ b/internal/generated/snippets/secretmanager/apiv1beta2/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1beta2/Client/ListSecretVersions/main.go b/internal/generated/snippets/secretmanager/apiv1beta2/Client/ListSecretVersions/main.go index 4e45ec56d91e..12f495fcd698 100644 --- a/internal/generated/snippets/secretmanager/apiv1beta2/Client/ListSecretVersions/main.go +++ b/internal/generated/snippets/secretmanager/apiv1beta2/Client/ListSecretVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1beta2/Client/ListSecrets/main.go b/internal/generated/snippets/secretmanager/apiv1beta2/Client/ListSecrets/main.go index a933f935d89e..74bd912ea660 100644 --- a/internal/generated/snippets/secretmanager/apiv1beta2/Client/ListSecrets/main.go +++ b/internal/generated/snippets/secretmanager/apiv1beta2/Client/ListSecrets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1beta2/Client/SetIamPolicy/main.go b/internal/generated/snippets/secretmanager/apiv1beta2/Client/SetIamPolicy/main.go index 8f829c650cf3..e93898451d88 100644 --- a/internal/generated/snippets/secretmanager/apiv1beta2/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/secretmanager/apiv1beta2/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1beta2/Client/TestIamPermissions/main.go b/internal/generated/snippets/secretmanager/apiv1beta2/Client/TestIamPermissions/main.go index ef8b2a834a6e..f13d3eff3cff 100644 --- a/internal/generated/snippets/secretmanager/apiv1beta2/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/secretmanager/apiv1beta2/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1beta2/Client/UpdateSecret/main.go b/internal/generated/snippets/secretmanager/apiv1beta2/Client/UpdateSecret/main.go index 540779f68669..8d757619c16c 100644 --- a/internal/generated/snippets/secretmanager/apiv1beta2/Client/UpdateSecret/main.go +++ b/internal/generated/snippets/secretmanager/apiv1beta2/Client/UpdateSecret/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/secretmanager/apiv1beta2/snippet_metadata.google.cloud.secretmanager.v1beta2.json b/internal/generated/snippets/secretmanager/apiv1beta2/snippet_metadata.google.cloud.secretmanager.v1beta2.json index 6b1ac54d9276..0a3dc84f5308 100644 --- a/internal/generated/snippets/secretmanager/apiv1beta2/snippet_metadata.google.cloud.secretmanager.v1beta2.json +++ b/internal/generated/snippets/secretmanager/apiv1beta2/snippet_metadata.google.cloud.secretmanager.v1beta2.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/secretmanager/apiv1beta2", - "version": "1.14.2", + "version": "1.14.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/securesourcemanager/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/securesourcemanager/apiv1/Client/CancelOperation/main.go index 0f9a9dcb72bb..d76350d36dc4 100644 --- a/internal/generated/snippets/securesourcemanager/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/securesourcemanager/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securesourcemanager/apiv1/Client/CreateBranchRule/main.go b/internal/generated/snippets/securesourcemanager/apiv1/Client/CreateBranchRule/main.go index a6f4aeed44f3..8cf75b2e43a0 100644 --- a/internal/generated/snippets/securesourcemanager/apiv1/Client/CreateBranchRule/main.go +++ b/internal/generated/snippets/securesourcemanager/apiv1/Client/CreateBranchRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securesourcemanager/apiv1/Client/CreateInstance/main.go b/internal/generated/snippets/securesourcemanager/apiv1/Client/CreateInstance/main.go index 2c22fda1217f..5acd9404b677 100644 --- a/internal/generated/snippets/securesourcemanager/apiv1/Client/CreateInstance/main.go +++ b/internal/generated/snippets/securesourcemanager/apiv1/Client/CreateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securesourcemanager/apiv1/Client/CreateRepository/main.go b/internal/generated/snippets/securesourcemanager/apiv1/Client/CreateRepository/main.go index 14603738a601..75203de13595 100644 --- a/internal/generated/snippets/securesourcemanager/apiv1/Client/CreateRepository/main.go +++ b/internal/generated/snippets/securesourcemanager/apiv1/Client/CreateRepository/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securesourcemanager/apiv1/Client/DeleteBranchRule/main.go b/internal/generated/snippets/securesourcemanager/apiv1/Client/DeleteBranchRule/main.go index 275c6a87953c..ffd264ea5edd 100644 --- a/internal/generated/snippets/securesourcemanager/apiv1/Client/DeleteBranchRule/main.go +++ b/internal/generated/snippets/securesourcemanager/apiv1/Client/DeleteBranchRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securesourcemanager/apiv1/Client/DeleteInstance/main.go b/internal/generated/snippets/securesourcemanager/apiv1/Client/DeleteInstance/main.go index 683b9f9261de..19f42bf41ec0 100644 --- a/internal/generated/snippets/securesourcemanager/apiv1/Client/DeleteInstance/main.go +++ b/internal/generated/snippets/securesourcemanager/apiv1/Client/DeleteInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securesourcemanager/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/securesourcemanager/apiv1/Client/DeleteOperation/main.go index 289795caa2e8..c76c87ba8b1c 100644 --- a/internal/generated/snippets/securesourcemanager/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/securesourcemanager/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securesourcemanager/apiv1/Client/DeleteRepository/main.go b/internal/generated/snippets/securesourcemanager/apiv1/Client/DeleteRepository/main.go index 4ef9523b599a..0e1cc23031d6 100644 --- a/internal/generated/snippets/securesourcemanager/apiv1/Client/DeleteRepository/main.go +++ b/internal/generated/snippets/securesourcemanager/apiv1/Client/DeleteRepository/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securesourcemanager/apiv1/Client/GetBranchRule/main.go b/internal/generated/snippets/securesourcemanager/apiv1/Client/GetBranchRule/main.go index 7ef0a052767b..bfc8295241a0 100644 --- a/internal/generated/snippets/securesourcemanager/apiv1/Client/GetBranchRule/main.go +++ b/internal/generated/snippets/securesourcemanager/apiv1/Client/GetBranchRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securesourcemanager/apiv1/Client/GetIamPolicy/main.go b/internal/generated/snippets/securesourcemanager/apiv1/Client/GetIamPolicy/main.go index 4b5d9ccf225d..0d167a6f6b1c 100644 --- a/internal/generated/snippets/securesourcemanager/apiv1/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/securesourcemanager/apiv1/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securesourcemanager/apiv1/Client/GetIamPolicyRepo/main.go b/internal/generated/snippets/securesourcemanager/apiv1/Client/GetIamPolicyRepo/main.go index 292196bc4e82..57f64f2bcabf 100644 --- a/internal/generated/snippets/securesourcemanager/apiv1/Client/GetIamPolicyRepo/main.go +++ b/internal/generated/snippets/securesourcemanager/apiv1/Client/GetIamPolicyRepo/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securesourcemanager/apiv1/Client/GetInstance/main.go b/internal/generated/snippets/securesourcemanager/apiv1/Client/GetInstance/main.go index fc2136b4e92d..2455d62211cd 100644 --- a/internal/generated/snippets/securesourcemanager/apiv1/Client/GetInstance/main.go +++ b/internal/generated/snippets/securesourcemanager/apiv1/Client/GetInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securesourcemanager/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/securesourcemanager/apiv1/Client/GetLocation/main.go index bbe9d319181d..96819a175a9e 100644 --- a/internal/generated/snippets/securesourcemanager/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/securesourcemanager/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securesourcemanager/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/securesourcemanager/apiv1/Client/GetOperation/main.go index b63d267da50f..b954c2768fd0 100644 --- a/internal/generated/snippets/securesourcemanager/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/securesourcemanager/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securesourcemanager/apiv1/Client/GetRepository/main.go b/internal/generated/snippets/securesourcemanager/apiv1/Client/GetRepository/main.go index 216cdde3f77a..d0130c7c8412 100644 --- a/internal/generated/snippets/securesourcemanager/apiv1/Client/GetRepository/main.go +++ b/internal/generated/snippets/securesourcemanager/apiv1/Client/GetRepository/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securesourcemanager/apiv1/Client/ListBranchRules/main.go b/internal/generated/snippets/securesourcemanager/apiv1/Client/ListBranchRules/main.go index 1adbab090170..a1a1d4a1ad4a 100644 --- a/internal/generated/snippets/securesourcemanager/apiv1/Client/ListBranchRules/main.go +++ b/internal/generated/snippets/securesourcemanager/apiv1/Client/ListBranchRules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securesourcemanager/apiv1/Client/ListInstances/main.go b/internal/generated/snippets/securesourcemanager/apiv1/Client/ListInstances/main.go index 9735ca59b894..4e141aa6ad59 100644 --- a/internal/generated/snippets/securesourcemanager/apiv1/Client/ListInstances/main.go +++ b/internal/generated/snippets/securesourcemanager/apiv1/Client/ListInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securesourcemanager/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/securesourcemanager/apiv1/Client/ListLocations/main.go index 541cc225a0a9..7dc9889ecf10 100644 --- a/internal/generated/snippets/securesourcemanager/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/securesourcemanager/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securesourcemanager/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/securesourcemanager/apiv1/Client/ListOperations/main.go index 74c709280dee..93002a2713b4 100644 --- a/internal/generated/snippets/securesourcemanager/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/securesourcemanager/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securesourcemanager/apiv1/Client/ListRepositories/main.go b/internal/generated/snippets/securesourcemanager/apiv1/Client/ListRepositories/main.go index b658db440505..e7142f91379a 100644 --- a/internal/generated/snippets/securesourcemanager/apiv1/Client/ListRepositories/main.go +++ b/internal/generated/snippets/securesourcemanager/apiv1/Client/ListRepositories/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securesourcemanager/apiv1/Client/SetIamPolicy/main.go b/internal/generated/snippets/securesourcemanager/apiv1/Client/SetIamPolicy/main.go index 2ad914bdc33f..a3e231de4626 100644 --- a/internal/generated/snippets/securesourcemanager/apiv1/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/securesourcemanager/apiv1/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securesourcemanager/apiv1/Client/SetIamPolicyRepo/main.go b/internal/generated/snippets/securesourcemanager/apiv1/Client/SetIamPolicyRepo/main.go index b86ee388cdb2..7d7b99bce6d3 100644 --- a/internal/generated/snippets/securesourcemanager/apiv1/Client/SetIamPolicyRepo/main.go +++ b/internal/generated/snippets/securesourcemanager/apiv1/Client/SetIamPolicyRepo/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securesourcemanager/apiv1/Client/TestIamPermissions/main.go b/internal/generated/snippets/securesourcemanager/apiv1/Client/TestIamPermissions/main.go index 2a0aa3d4dfc1..3d810a1af41b 100644 --- a/internal/generated/snippets/securesourcemanager/apiv1/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/securesourcemanager/apiv1/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securesourcemanager/apiv1/Client/TestIamPermissionsRepo/main.go b/internal/generated/snippets/securesourcemanager/apiv1/Client/TestIamPermissionsRepo/main.go index 7c7e302505f6..e58d381949f3 100644 --- a/internal/generated/snippets/securesourcemanager/apiv1/Client/TestIamPermissionsRepo/main.go +++ b/internal/generated/snippets/securesourcemanager/apiv1/Client/TestIamPermissionsRepo/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securesourcemanager/apiv1/Client/UpdateBranchRule/main.go b/internal/generated/snippets/securesourcemanager/apiv1/Client/UpdateBranchRule/main.go index 321d6f2678c6..e8aa27a16931 100644 --- a/internal/generated/snippets/securesourcemanager/apiv1/Client/UpdateBranchRule/main.go +++ b/internal/generated/snippets/securesourcemanager/apiv1/Client/UpdateBranchRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securesourcemanager/apiv1/snippet_metadata.google.cloud.securesourcemanager.v1.json b/internal/generated/snippets/securesourcemanager/apiv1/snippet_metadata.google.cloud.securesourcemanager.v1.json index 92a10ccfde0a..cdc75ce33bfe 100644 --- a/internal/generated/snippets/securesourcemanager/apiv1/snippet_metadata.google.cloud.securesourcemanager.v1.json +++ b/internal/generated/snippets/securesourcemanager/apiv1/snippet_metadata.google.cloud.securesourcemanager.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/securesourcemanager/apiv1", - "version": "1.3.0", + "version": "1.3.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ActivateCertificateAuthority/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ActivateCertificateAuthority/main.go index 17558979064d..041cabb6671f 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ActivateCertificateAuthority/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ActivateCertificateAuthority/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/CancelOperation/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/CancelOperation/main.go index 112872560fed..35a31bc86470 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/CancelOperation/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/CreateCaPool/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/CreateCaPool/main.go index f57c0086dacc..0565ef2fa868 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/CreateCaPool/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/CreateCaPool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/CreateCertificate/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/CreateCertificate/main.go index 08902f227715..e36872054471 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/CreateCertificate/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/CreateCertificate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/CreateCertificateAuthority/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/CreateCertificateAuthority/main.go index 6adae0ee70a0..af3ee918eb9a 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/CreateCertificateAuthority/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/CreateCertificateAuthority/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/CreateCertificateTemplate/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/CreateCertificateTemplate/main.go index ccc54c00cea9..0459acc974d0 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/CreateCertificateTemplate/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/CreateCertificateTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/DeleteCaPool/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/DeleteCaPool/main.go index 06f9d2118a9d..5b2ce8a556a1 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/DeleteCaPool/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/DeleteCaPool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/DeleteCertificateAuthority/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/DeleteCertificateAuthority/main.go index 4e0c9ed8c0db..5a11e3e85bac 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/DeleteCertificateAuthority/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/DeleteCertificateAuthority/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/DeleteCertificateTemplate/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/DeleteCertificateTemplate/main.go index 7faceda960f8..774dc55543d4 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/DeleteCertificateTemplate/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/DeleteCertificateTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/DeleteOperation/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/DeleteOperation/main.go index 90cebfacdddf..90961613ec09 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/DeleteOperation/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/DisableCertificateAuthority/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/DisableCertificateAuthority/main.go index efe99a9cb938..00d83fe9d84b 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/DisableCertificateAuthority/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/DisableCertificateAuthority/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/EnableCertificateAuthority/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/EnableCertificateAuthority/main.go index f0e6ceec876e..a600799978f1 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/EnableCertificateAuthority/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/EnableCertificateAuthority/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/FetchCaCerts/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/FetchCaCerts/main.go index 8295ec094b6b..31bd6772f95f 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/FetchCaCerts/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/FetchCaCerts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/FetchCertificateAuthorityCsr/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/FetchCertificateAuthorityCsr/main.go index 20f5b1aa099c..e6e258a74be6 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/FetchCertificateAuthorityCsr/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/FetchCertificateAuthorityCsr/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetCaPool/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetCaPool/main.go index e2cf63146e71..e00cc7a31006 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetCaPool/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetCaPool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetCertificate/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetCertificate/main.go index b398624bf380..90be12a4bbca 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetCertificate/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetCertificate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetCertificateAuthority/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetCertificateAuthority/main.go index 370f02e1d918..5d095febc780 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetCertificateAuthority/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetCertificateAuthority/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetCertificateRevocationList/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetCertificateRevocationList/main.go index 533809a06503..19586fdb8db7 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetCertificateRevocationList/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetCertificateRevocationList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetCertificateTemplate/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetCertificateTemplate/main.go index 5b587763b38b..757cf153bcff 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetCertificateTemplate/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetCertificateTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetIamPolicy/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetIamPolicy/main.go index 8949dc03cde2..f25578d0ef59 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetLocation/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetLocation/main.go index 02f0825f1da0..f4dc4bdd18b9 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetLocation/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetOperation/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetOperation/main.go index 1e43a71f6337..ad4eb9bacc93 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetOperation/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ListCaPools/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ListCaPools/main.go index 35f11f2e861e..410150bb6dcf 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ListCaPools/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ListCaPools/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ListCertificateAuthorities/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ListCertificateAuthorities/main.go index 301e749e4a28..9ed77b3eb817 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ListCertificateAuthorities/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ListCertificateAuthorities/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ListCertificateRevocationLists/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ListCertificateRevocationLists/main.go index d94d9d4c74e4..70cd01593fcd 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ListCertificateRevocationLists/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ListCertificateRevocationLists/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ListCertificateTemplates/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ListCertificateTemplates/main.go index 636873b415c8..0633d04b8e17 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ListCertificateTemplates/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ListCertificateTemplates/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ListCertificates/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ListCertificates/main.go index f07b410dd103..058975782628 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ListCertificates/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ListCertificates/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ListLocations/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ListLocations/main.go index 1d4c828b0bca..3295bb5ff6aa 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ListLocations/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ListOperations/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ListOperations/main.go index 7d1246214a99..dc91fa72f7e4 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ListOperations/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/RevokeCertificate/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/RevokeCertificate/main.go index adf5c64916a3..b502160f59cb 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/RevokeCertificate/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/RevokeCertificate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/SetIamPolicy/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/SetIamPolicy/main.go index 7d3e9fa90a85..16c68055ab16 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/TestIamPermissions/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/TestIamPermissions/main.go index 0287d326883b..b016335a388a 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/UndeleteCertificateAuthority/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/UndeleteCertificateAuthority/main.go index 2a6b945c3e26..a5cb64136084 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/UndeleteCertificateAuthority/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/UndeleteCertificateAuthority/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/UpdateCaPool/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/UpdateCaPool/main.go index 8cd124a378dc..e6e7c4316bdd 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/UpdateCaPool/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/UpdateCaPool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/UpdateCertificate/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/UpdateCertificate/main.go index a93e05196eb4..6e835f0f1555 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/UpdateCertificate/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/UpdateCertificate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/UpdateCertificateAuthority/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/UpdateCertificateAuthority/main.go index c78b87298fbe..4c7d46e86fd6 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/UpdateCertificateAuthority/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/UpdateCertificateAuthority/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/UpdateCertificateRevocationList/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/UpdateCertificateRevocationList/main.go index 99f902a9d76c..60cfebe1cfce 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/UpdateCertificateRevocationList/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/UpdateCertificateRevocationList/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/UpdateCertificateTemplate/main.go b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/UpdateCertificateTemplate/main.go index f1827853c2a2..4bcce4bbecea 100644 --- a/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/UpdateCertificateTemplate/main.go +++ b/internal/generated/snippets/security/privateca/apiv1/CertificateAuthorityClient/UpdateCertificateTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/privateca/apiv1/snippet_metadata.google.cloud.security.privateca.v1.json b/internal/generated/snippets/security/privateca/apiv1/snippet_metadata.google.cloud.security.privateca.v1.json index 0c1c5b386143..003d9b4e8a0d 100644 --- a/internal/generated/snippets/security/privateca/apiv1/snippet_metadata.google.cloud.security.privateca.v1.json +++ b/internal/generated/snippets/security/privateca/apiv1/snippet_metadata.google.cloud.security.privateca.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/security/privateca/apiv1", - "version": "1.18.2", + "version": "1.18.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/security/publicca/apiv1/PublicCertificateAuthorityClient/CreateExternalAccountKey/main.go b/internal/generated/snippets/security/publicca/apiv1/PublicCertificateAuthorityClient/CreateExternalAccountKey/main.go index f351f989810f..69ca3630a71d 100644 --- a/internal/generated/snippets/security/publicca/apiv1/PublicCertificateAuthorityClient/CreateExternalAccountKey/main.go +++ b/internal/generated/snippets/security/publicca/apiv1/PublicCertificateAuthorityClient/CreateExternalAccountKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/publicca/apiv1/snippet_metadata.google.cloud.security.publicca.v1.json b/internal/generated/snippets/security/publicca/apiv1/snippet_metadata.google.cloud.security.publicca.v1.json index 3e0356922e32..249bffa8d026 100644 --- a/internal/generated/snippets/security/publicca/apiv1/snippet_metadata.google.cloud.security.publicca.v1.json +++ b/internal/generated/snippets/security/publicca/apiv1/snippet_metadata.google.cloud.security.publicca.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/security/publicca/apiv1", - "version": "1.18.2", + "version": "1.18.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/security/publicca/apiv1beta1/PublicCertificateAuthorityClient/CreateExternalAccountKey/main.go b/internal/generated/snippets/security/publicca/apiv1beta1/PublicCertificateAuthorityClient/CreateExternalAccountKey/main.go index ec8588ac06a4..59041e0d915a 100644 --- a/internal/generated/snippets/security/publicca/apiv1beta1/PublicCertificateAuthorityClient/CreateExternalAccountKey/main.go +++ b/internal/generated/snippets/security/publicca/apiv1beta1/PublicCertificateAuthorityClient/CreateExternalAccountKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/security/publicca/apiv1beta1/snippet_metadata.google.cloud.security.publicca.v1beta1.json b/internal/generated/snippets/security/publicca/apiv1beta1/snippet_metadata.google.cloud.security.publicca.v1beta1.json index 95c1010d3840..ac9be7981ced 100644 --- a/internal/generated/snippets/security/publicca/apiv1beta1/snippet_metadata.google.cloud.security.publicca.v1beta1.json +++ b/internal/generated/snippets/security/publicca/apiv1beta1/snippet_metadata.google.cloud.security.publicca.v1beta1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/security/publicca/apiv1beta1", - "version": "1.18.2", + "version": "1.18.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/BatchCreateResourceValueConfigs/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/BatchCreateResourceValueConfigs/main.go index 51e86ed6a727..8d5b7bbfccf0 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/BatchCreateResourceValueConfigs/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/BatchCreateResourceValueConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/BulkMuteFindings/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/BulkMuteFindings/main.go index a128630f4c54..39e2041a8c5c 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/BulkMuteFindings/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/BulkMuteFindings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/CancelOperation/main.go index af0f474bf31a..924736a6e2e5 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/CreateBigQueryExport/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/CreateBigQueryExport/main.go index a9dca9666240..03e959986622 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/CreateBigQueryExport/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/CreateBigQueryExport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/CreateEventThreatDetectionCustomModule/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/CreateEventThreatDetectionCustomModule/main.go index d12c9c4a6f59..746494a7c7d2 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/CreateEventThreatDetectionCustomModule/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/CreateEventThreatDetectionCustomModule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/CreateFinding/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/CreateFinding/main.go index e9410fbe622a..4ab57c226471 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/CreateFinding/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/CreateFinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/CreateMuteConfig/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/CreateMuteConfig/main.go index 457de241dd06..d23efaf01b9a 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/CreateMuteConfig/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/CreateMuteConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/CreateNotificationConfig/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/CreateNotificationConfig/main.go index 66c0c38d713e..d7a726c63e07 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/CreateNotificationConfig/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/CreateNotificationConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/CreateSecurityHealthAnalyticsCustomModule/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/CreateSecurityHealthAnalyticsCustomModule/main.go index 1a62db352945..39def817be27 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/CreateSecurityHealthAnalyticsCustomModule/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/CreateSecurityHealthAnalyticsCustomModule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/CreateSource/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/CreateSource/main.go index ea6bb264adfe..6d9d71177f32 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/CreateSource/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/CreateSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/DeleteBigQueryExport/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/DeleteBigQueryExport/main.go index 57aa7f376c0b..941219660a65 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/DeleteBigQueryExport/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/DeleteBigQueryExport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/DeleteEventThreatDetectionCustomModule/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/DeleteEventThreatDetectionCustomModule/main.go index 298275c30313..9ee6b7a12097 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/DeleteEventThreatDetectionCustomModule/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/DeleteEventThreatDetectionCustomModule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/DeleteMuteConfig/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/DeleteMuteConfig/main.go index e564b22d9fdd..2f648daf631a 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/DeleteMuteConfig/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/DeleteMuteConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/DeleteNotificationConfig/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/DeleteNotificationConfig/main.go index 380226aab6c7..d6ac87a8f5f4 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/DeleteNotificationConfig/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/DeleteNotificationConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/DeleteOperation/main.go index 0f3aea0e60be..f0ee95d2963b 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/DeleteResourceValueConfig/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/DeleteResourceValueConfig/main.go index df8f30b25f00..270ecff57ac1 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/DeleteResourceValueConfig/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/DeleteResourceValueConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/DeleteSecurityHealthAnalyticsCustomModule/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/DeleteSecurityHealthAnalyticsCustomModule/main.go index 06cc6a5fd3cb..ade30ac30f4a 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/DeleteSecurityHealthAnalyticsCustomModule/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/DeleteSecurityHealthAnalyticsCustomModule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/GetBigQueryExport/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/GetBigQueryExport/main.go index f1273a692fb0..372a0bbf64cc 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/GetBigQueryExport/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/GetBigQueryExport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/GetEffectiveEventThreatDetectionCustomModule/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/GetEffectiveEventThreatDetectionCustomModule/main.go index 17da36b90a7b..6ba0485423ee 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/GetEffectiveEventThreatDetectionCustomModule/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/GetEffectiveEventThreatDetectionCustomModule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/GetEffectiveSecurityHealthAnalyticsCustomModule/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/GetEffectiveSecurityHealthAnalyticsCustomModule/main.go index 1d75fa0d25e4..2b5a62181166 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/GetEffectiveSecurityHealthAnalyticsCustomModule/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/GetEffectiveSecurityHealthAnalyticsCustomModule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/GetEventThreatDetectionCustomModule/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/GetEventThreatDetectionCustomModule/main.go index a2c67b26be69..c451526d9cc9 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/GetEventThreatDetectionCustomModule/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/GetEventThreatDetectionCustomModule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/GetIamPolicy/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/GetIamPolicy/main.go index 7fbada0acc9e..37be2bff54bd 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/GetMuteConfig/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/GetMuteConfig/main.go index fc52627e06e7..324cc139bc5e 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/GetMuteConfig/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/GetMuteConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/GetNotificationConfig/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/GetNotificationConfig/main.go index d9807d7a03ec..9afa4efaddb2 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/GetNotificationConfig/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/GetNotificationConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/GetOperation/main.go index a0ff2e7b2bd1..e6b06a37e6dd 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/GetOrganizationSettings/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/GetOrganizationSettings/main.go index 2d09d8401d70..d74d9b04d116 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/GetOrganizationSettings/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/GetOrganizationSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/GetResourceValueConfig/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/GetResourceValueConfig/main.go index 1dc464786f47..c8e9efaac9f9 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/GetResourceValueConfig/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/GetResourceValueConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/GetSecurityHealthAnalyticsCustomModule/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/GetSecurityHealthAnalyticsCustomModule/main.go index a6d31adb6dcf..f65dbe4ed75e 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/GetSecurityHealthAnalyticsCustomModule/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/GetSecurityHealthAnalyticsCustomModule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/GetSimulation/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/GetSimulation/main.go index a953e0269ed2..1b0ddb087490 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/GetSimulation/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/GetSimulation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/GetSource/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/GetSource/main.go index b84a1164e449..dbf20275dbad 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/GetSource/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/GetSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/GetValuedResource/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/GetValuedResource/main.go index aaa234d011d0..5263381de81e 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/GetValuedResource/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/GetValuedResource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/GroupAssets/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/GroupAssets/main.go index de82e98e1730..97047a3a8b43 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/GroupAssets/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/GroupAssets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/GroupFindings/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/GroupFindings/main.go index 5f5b1c4a6b01..54a47f0897c6 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/GroupFindings/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/GroupFindings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/ListAssets/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/ListAssets/main.go index fa58f6c99022..fac4e1a1f787 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/ListAssets/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/ListAssets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/ListAttackPaths/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/ListAttackPaths/main.go index 94e80209c044..8a3eb7de96e0 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/ListAttackPaths/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/ListAttackPaths/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/ListBigQueryExports/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/ListBigQueryExports/main.go index fa697e62c7e2..ceac71979242 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/ListBigQueryExports/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/ListBigQueryExports/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/ListDescendantEventThreatDetectionCustomModules/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/ListDescendantEventThreatDetectionCustomModules/main.go index 9a97e1035539..c09390d415dd 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/ListDescendantEventThreatDetectionCustomModules/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/ListDescendantEventThreatDetectionCustomModules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/ListDescendantSecurityHealthAnalyticsCustomModules/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/ListDescendantSecurityHealthAnalyticsCustomModules/main.go index 8be06dcac4f5..6b0cb02f2f35 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/ListDescendantSecurityHealthAnalyticsCustomModules/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/ListDescendantSecurityHealthAnalyticsCustomModules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/ListEffectiveEventThreatDetectionCustomModules/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/ListEffectiveEventThreatDetectionCustomModules/main.go index 55215a194b85..a8c12889e379 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/ListEffectiveEventThreatDetectionCustomModules/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/ListEffectiveEventThreatDetectionCustomModules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/ListEffectiveSecurityHealthAnalyticsCustomModules/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/ListEffectiveSecurityHealthAnalyticsCustomModules/main.go index a4d232fd5f3c..d9235b62e589 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/ListEffectiveSecurityHealthAnalyticsCustomModules/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/ListEffectiveSecurityHealthAnalyticsCustomModules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/ListEventThreatDetectionCustomModules/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/ListEventThreatDetectionCustomModules/main.go index 9b7fccd26424..acc80ea80299 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/ListEventThreatDetectionCustomModules/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/ListEventThreatDetectionCustomModules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/ListFindings/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/ListFindings/main.go index bacb92881556..31103fd13911 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/ListFindings/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/ListFindings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/ListMuteConfigs/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/ListMuteConfigs/main.go index fa93d6f0215a..ba9676764a28 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/ListMuteConfigs/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/ListMuteConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/ListNotificationConfigs/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/ListNotificationConfigs/main.go index 780a0fb7fb3d..293224ff4e64 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/ListNotificationConfigs/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/ListNotificationConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/ListOperations/main.go index d9105d0f4fc2..3989cd0a73f2 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/ListResourceValueConfigs/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/ListResourceValueConfigs/main.go index 6f8287701195..3f4213a1f353 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/ListResourceValueConfigs/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/ListResourceValueConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/ListSecurityHealthAnalyticsCustomModules/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/ListSecurityHealthAnalyticsCustomModules/main.go index 27d0128a9bcd..a4b111b4dde6 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/ListSecurityHealthAnalyticsCustomModules/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/ListSecurityHealthAnalyticsCustomModules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/ListSources/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/ListSources/main.go index 35b0a8879892..f8913e2cfc12 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/ListSources/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/ListSources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/ListValuedResources/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/ListValuedResources/main.go index fa8bca79af7c..dff46eaeb36c 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/ListValuedResources/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/ListValuedResources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/RunAssetDiscovery/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/RunAssetDiscovery/main.go index 06dea832e525..fe27b690cc64 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/RunAssetDiscovery/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/RunAssetDiscovery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/SetFindingState/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/SetFindingState/main.go index ff0e037e0b96..e38bc7b3b770 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/SetFindingState/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/SetFindingState/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/SetIamPolicy/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/SetIamPolicy/main.go index 3d825c4dfd70..d57b51793659 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/SetMute/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/SetMute/main.go index c05ab9978f15..f1a94eb6c0b3 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/SetMute/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/SetMute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/SimulateSecurityHealthAnalyticsCustomModule/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/SimulateSecurityHealthAnalyticsCustomModule/main.go index 3491c737f3bb..966b665825b8 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/SimulateSecurityHealthAnalyticsCustomModule/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/SimulateSecurityHealthAnalyticsCustomModule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/TestIamPermissions/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/TestIamPermissions/main.go index adfcd19ecb78..1a68c57347f2 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/UpdateBigQueryExport/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/UpdateBigQueryExport/main.go index 211841c080c9..93a58872712b 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/UpdateBigQueryExport/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/UpdateBigQueryExport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/UpdateEventThreatDetectionCustomModule/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/UpdateEventThreatDetectionCustomModule/main.go index 01275b28188d..f553c348f754 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/UpdateEventThreatDetectionCustomModule/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/UpdateEventThreatDetectionCustomModule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/UpdateExternalSystem/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/UpdateExternalSystem/main.go index f552fa0b8fe6..52852262f041 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/UpdateExternalSystem/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/UpdateExternalSystem/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/UpdateFinding/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/UpdateFinding/main.go index 874a2bc2a9c3..aadbc387c405 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/UpdateFinding/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/UpdateFinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/UpdateMuteConfig/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/UpdateMuteConfig/main.go index aceb0fee1ceb..aa95a3568569 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/UpdateMuteConfig/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/UpdateMuteConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/UpdateNotificationConfig/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/UpdateNotificationConfig/main.go index 548926b9f32f..c7c4b0475a8b 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/UpdateNotificationConfig/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/UpdateNotificationConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/UpdateOrganizationSettings/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/UpdateOrganizationSettings/main.go index 0ca098ff2632..8b83189f59e7 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/UpdateOrganizationSettings/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/UpdateOrganizationSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/UpdateResourceValueConfig/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/UpdateResourceValueConfig/main.go index 3ea0a757520d..e0bbd721c14b 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/UpdateResourceValueConfig/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/UpdateResourceValueConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/UpdateSecurityHealthAnalyticsCustomModule/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/UpdateSecurityHealthAnalyticsCustomModule/main.go index b44f2cafed2c..52ded68d2f57 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/UpdateSecurityHealthAnalyticsCustomModule/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/UpdateSecurityHealthAnalyticsCustomModule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/UpdateSecurityMarks/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/UpdateSecurityMarks/main.go index 5e690b49b91c..94a93541a8b0 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/UpdateSecurityMarks/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/UpdateSecurityMarks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/UpdateSource/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/UpdateSource/main.go index 94ecd8c8f95d..170c05abc87d 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/UpdateSource/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/UpdateSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/Client/ValidateEventThreatDetectionCustomModule/main.go b/internal/generated/snippets/securitycenter/apiv1/Client/ValidateEventThreatDetectionCustomModule/main.go index 5d9bc0113b63..be517949273f 100644 --- a/internal/generated/snippets/securitycenter/apiv1/Client/ValidateEventThreatDetectionCustomModule/main.go +++ b/internal/generated/snippets/securitycenter/apiv1/Client/ValidateEventThreatDetectionCustomModule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1/snippet_metadata.google.cloud.securitycenter.v1.json b/internal/generated/snippets/securitycenter/apiv1/snippet_metadata.google.cloud.securitycenter.v1.json index 92ff038ed228..bf25ed1a6b48 100644 --- a/internal/generated/snippets/securitycenter/apiv1/snippet_metadata.google.cloud.securitycenter.v1.json +++ b/internal/generated/snippets/securitycenter/apiv1/snippet_metadata.google.cloud.securitycenter.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/securitycenter/apiv1", - "version": "1.35.2", + "version": "1.35.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/securitycenter/apiv1beta1/Client/CreateFinding/main.go b/internal/generated/snippets/securitycenter/apiv1beta1/Client/CreateFinding/main.go index d6bc39c269ef..e888cc90c3c5 100644 --- a/internal/generated/snippets/securitycenter/apiv1beta1/Client/CreateFinding/main.go +++ b/internal/generated/snippets/securitycenter/apiv1beta1/Client/CreateFinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1beta1/Client/CreateSource/main.go b/internal/generated/snippets/securitycenter/apiv1beta1/Client/CreateSource/main.go index c8a0cf8186d4..abf71fed9a89 100644 --- a/internal/generated/snippets/securitycenter/apiv1beta1/Client/CreateSource/main.go +++ b/internal/generated/snippets/securitycenter/apiv1beta1/Client/CreateSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1beta1/Client/GetIamPolicy/main.go b/internal/generated/snippets/securitycenter/apiv1beta1/Client/GetIamPolicy/main.go index 2669a6166efe..36f6bf72ec71 100644 --- a/internal/generated/snippets/securitycenter/apiv1beta1/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/securitycenter/apiv1beta1/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1beta1/Client/GetOrganizationSettings/main.go b/internal/generated/snippets/securitycenter/apiv1beta1/Client/GetOrganizationSettings/main.go index 69f953515165..e180a40d0329 100644 --- a/internal/generated/snippets/securitycenter/apiv1beta1/Client/GetOrganizationSettings/main.go +++ b/internal/generated/snippets/securitycenter/apiv1beta1/Client/GetOrganizationSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1beta1/Client/GetSource/main.go b/internal/generated/snippets/securitycenter/apiv1beta1/Client/GetSource/main.go index b5afc9801b21..89cff78e78c7 100644 --- a/internal/generated/snippets/securitycenter/apiv1beta1/Client/GetSource/main.go +++ b/internal/generated/snippets/securitycenter/apiv1beta1/Client/GetSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1beta1/Client/GroupAssets/main.go b/internal/generated/snippets/securitycenter/apiv1beta1/Client/GroupAssets/main.go index aabd149d906a..f15d60a316a3 100644 --- a/internal/generated/snippets/securitycenter/apiv1beta1/Client/GroupAssets/main.go +++ b/internal/generated/snippets/securitycenter/apiv1beta1/Client/GroupAssets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1beta1/Client/GroupFindings/main.go b/internal/generated/snippets/securitycenter/apiv1beta1/Client/GroupFindings/main.go index bb3186bae080..dd1747088911 100644 --- a/internal/generated/snippets/securitycenter/apiv1beta1/Client/GroupFindings/main.go +++ b/internal/generated/snippets/securitycenter/apiv1beta1/Client/GroupFindings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1beta1/Client/ListAssets/main.go b/internal/generated/snippets/securitycenter/apiv1beta1/Client/ListAssets/main.go index 9c9de50de9e8..0c55cb7e196c 100644 --- a/internal/generated/snippets/securitycenter/apiv1beta1/Client/ListAssets/main.go +++ b/internal/generated/snippets/securitycenter/apiv1beta1/Client/ListAssets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1beta1/Client/ListFindings/main.go b/internal/generated/snippets/securitycenter/apiv1beta1/Client/ListFindings/main.go index 33757ea5157a..37ed4b386356 100644 --- a/internal/generated/snippets/securitycenter/apiv1beta1/Client/ListFindings/main.go +++ b/internal/generated/snippets/securitycenter/apiv1beta1/Client/ListFindings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1beta1/Client/ListSources/main.go b/internal/generated/snippets/securitycenter/apiv1beta1/Client/ListSources/main.go index a4a598484c0c..0dd0160cb8db 100644 --- a/internal/generated/snippets/securitycenter/apiv1beta1/Client/ListSources/main.go +++ b/internal/generated/snippets/securitycenter/apiv1beta1/Client/ListSources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1beta1/Client/RunAssetDiscovery/main.go b/internal/generated/snippets/securitycenter/apiv1beta1/Client/RunAssetDiscovery/main.go index 0657d71f90ba..9bc7332ed949 100644 --- a/internal/generated/snippets/securitycenter/apiv1beta1/Client/RunAssetDiscovery/main.go +++ b/internal/generated/snippets/securitycenter/apiv1beta1/Client/RunAssetDiscovery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1beta1/Client/SetFindingState/main.go b/internal/generated/snippets/securitycenter/apiv1beta1/Client/SetFindingState/main.go index 3035932d77a4..3d34b8193e03 100644 --- a/internal/generated/snippets/securitycenter/apiv1beta1/Client/SetFindingState/main.go +++ b/internal/generated/snippets/securitycenter/apiv1beta1/Client/SetFindingState/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1beta1/Client/SetIamPolicy/main.go b/internal/generated/snippets/securitycenter/apiv1beta1/Client/SetIamPolicy/main.go index 465a8a32814f..1984ac2f4935 100644 --- a/internal/generated/snippets/securitycenter/apiv1beta1/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/securitycenter/apiv1beta1/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1beta1/Client/TestIamPermissions/main.go b/internal/generated/snippets/securitycenter/apiv1beta1/Client/TestIamPermissions/main.go index 6f7a4fac563e..6d7aead5448a 100644 --- a/internal/generated/snippets/securitycenter/apiv1beta1/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/securitycenter/apiv1beta1/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1beta1/Client/UpdateFinding/main.go b/internal/generated/snippets/securitycenter/apiv1beta1/Client/UpdateFinding/main.go index 8212ca70086a..abb9de7531f0 100644 --- a/internal/generated/snippets/securitycenter/apiv1beta1/Client/UpdateFinding/main.go +++ b/internal/generated/snippets/securitycenter/apiv1beta1/Client/UpdateFinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1beta1/Client/UpdateOrganizationSettings/main.go b/internal/generated/snippets/securitycenter/apiv1beta1/Client/UpdateOrganizationSettings/main.go index 9b34f868da7d..acb1fe8d27be 100644 --- a/internal/generated/snippets/securitycenter/apiv1beta1/Client/UpdateOrganizationSettings/main.go +++ b/internal/generated/snippets/securitycenter/apiv1beta1/Client/UpdateOrganizationSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1beta1/Client/UpdateSecurityMarks/main.go b/internal/generated/snippets/securitycenter/apiv1beta1/Client/UpdateSecurityMarks/main.go index ec9ad306c1f7..2bd97c7c7d62 100644 --- a/internal/generated/snippets/securitycenter/apiv1beta1/Client/UpdateSecurityMarks/main.go +++ b/internal/generated/snippets/securitycenter/apiv1beta1/Client/UpdateSecurityMarks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1beta1/Client/UpdateSource/main.go b/internal/generated/snippets/securitycenter/apiv1beta1/Client/UpdateSource/main.go index ff26aad0f024..c6f17eccf133 100644 --- a/internal/generated/snippets/securitycenter/apiv1beta1/Client/UpdateSource/main.go +++ b/internal/generated/snippets/securitycenter/apiv1beta1/Client/UpdateSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1beta1/snippet_metadata.google.cloud.securitycenter.v1beta1.json b/internal/generated/snippets/securitycenter/apiv1beta1/snippet_metadata.google.cloud.securitycenter.v1beta1.json index db4f8cc86302..674a6a42db63 100644 --- a/internal/generated/snippets/securitycenter/apiv1beta1/snippet_metadata.google.cloud.securitycenter.v1beta1.json +++ b/internal/generated/snippets/securitycenter/apiv1beta1/snippet_metadata.google.cloud.securitycenter.v1beta1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/securitycenter/apiv1beta1", - "version": "1.35.2", + "version": "1.35.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/CreateFinding/main.go b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/CreateFinding/main.go index 7653465dc095..77e99621d89c 100644 --- a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/CreateFinding/main.go +++ b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/CreateFinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/CreateNotificationConfig/main.go b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/CreateNotificationConfig/main.go index 5b8efd9f5cc3..d5e22b6e8572 100644 --- a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/CreateNotificationConfig/main.go +++ b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/CreateNotificationConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/CreateSource/main.go b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/CreateSource/main.go index 4632131246eb..49f5741f732a 100644 --- a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/CreateSource/main.go +++ b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/CreateSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/DeleteNotificationConfig/main.go b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/DeleteNotificationConfig/main.go index cf4475487878..29cdd61b7641 100644 --- a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/DeleteNotificationConfig/main.go +++ b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/DeleteNotificationConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/GetIamPolicy/main.go b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/GetIamPolicy/main.go index 2c054897e8c5..3a6b17b236d2 100644 --- a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/GetNotificationConfig/main.go b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/GetNotificationConfig/main.go index d777a58457a2..98676babcc3b 100644 --- a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/GetNotificationConfig/main.go +++ b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/GetNotificationConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/GetOrganizationSettings/main.go b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/GetOrganizationSettings/main.go index 336ffdf9ec32..487daad257cd 100644 --- a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/GetOrganizationSettings/main.go +++ b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/GetOrganizationSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/GetSource/main.go b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/GetSource/main.go index ef59f3bc3add..b03ac9ab23e7 100644 --- a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/GetSource/main.go +++ b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/GetSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/GroupAssets/main.go b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/GroupAssets/main.go index 6d8ad7e228f8..34dd85670fea 100644 --- a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/GroupAssets/main.go +++ b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/GroupAssets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/GroupFindings/main.go b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/GroupFindings/main.go index 97332b285516..0f60b3f1ad80 100644 --- a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/GroupFindings/main.go +++ b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/GroupFindings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/ListAssets/main.go b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/ListAssets/main.go index 933a8deb28e7..8d8529e00dd1 100644 --- a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/ListAssets/main.go +++ b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/ListAssets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/ListFindings/main.go b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/ListFindings/main.go index 714ffbed57f3..1d40548b6497 100644 --- a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/ListFindings/main.go +++ b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/ListFindings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/ListNotificationConfigs/main.go b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/ListNotificationConfigs/main.go index e2bb94204d28..e31aa72e5a0d 100644 --- a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/ListNotificationConfigs/main.go +++ b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/ListNotificationConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/ListSources/main.go b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/ListSources/main.go index 0d852ba2c6c0..a68f046b9768 100644 --- a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/ListSources/main.go +++ b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/ListSources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/RunAssetDiscovery/main.go b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/RunAssetDiscovery/main.go index 76462345ef71..214f57fe1a62 100644 --- a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/RunAssetDiscovery/main.go +++ b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/RunAssetDiscovery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/SetFindingState/main.go b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/SetFindingState/main.go index 4e35c4beb877..6c72a62f7397 100644 --- a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/SetFindingState/main.go +++ b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/SetFindingState/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/SetIamPolicy/main.go b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/SetIamPolicy/main.go index 13a4072a02e6..693ff9d68e7e 100644 --- a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/TestIamPermissions/main.go b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/TestIamPermissions/main.go index f576b92c283a..b765568df76a 100644 --- a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/UpdateFinding/main.go b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/UpdateFinding/main.go index 13206f4f08ea..1ea820d99504 100644 --- a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/UpdateFinding/main.go +++ b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/UpdateFinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/UpdateNotificationConfig/main.go b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/UpdateNotificationConfig/main.go index 8a8bf9112a65..26b535fd3355 100644 --- a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/UpdateNotificationConfig/main.go +++ b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/UpdateNotificationConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/UpdateOrganizationSettings/main.go b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/UpdateOrganizationSettings/main.go index f1e37f307520..9ff6a81a91e6 100644 --- a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/UpdateOrganizationSettings/main.go +++ b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/UpdateOrganizationSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/UpdateSecurityMarks/main.go b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/UpdateSecurityMarks/main.go index d3c85e3eec44..7124b6f84d8e 100644 --- a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/UpdateSecurityMarks/main.go +++ b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/UpdateSecurityMarks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/UpdateSource/main.go b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/UpdateSource/main.go index 5d6c8d855da3..b50e06735232 100644 --- a/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/UpdateSource/main.go +++ b/internal/generated/snippets/securitycenter/apiv1p1beta1/Client/UpdateSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv1p1beta1/snippet_metadata.google.cloud.securitycenter.v1p1beta1.json b/internal/generated/snippets/securitycenter/apiv1p1beta1/snippet_metadata.google.cloud.securitycenter.v1p1beta1.json index 2d2ded17f477..c9f70084c913 100644 --- a/internal/generated/snippets/securitycenter/apiv1p1beta1/snippet_metadata.google.cloud.securitycenter.v1p1beta1.json +++ b/internal/generated/snippets/securitycenter/apiv1p1beta1/snippet_metadata.google.cloud.securitycenter.v1p1beta1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/securitycenter/apiv1p1beta1", - "version": "1.35.2", + "version": "1.35.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/BatchCreateResourceValueConfigs/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/BatchCreateResourceValueConfigs/main.go index b4b4495b5cfc..1469e259fe00 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/BatchCreateResourceValueConfigs/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/BatchCreateResourceValueConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/BulkMuteFindings/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/BulkMuteFindings/main.go index 00a62edff2bd..ddd998d78842 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/BulkMuteFindings/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/BulkMuteFindings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/CancelOperation/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/CancelOperation/main.go index db78c597cd9a..4f556d7f45c5 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/CancelOperation/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/CreateBigQueryExport/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/CreateBigQueryExport/main.go index 543fa72bc478..d038d2f5e9ac 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/CreateBigQueryExport/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/CreateBigQueryExport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/CreateFinding/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/CreateFinding/main.go index 88838ff70156..0e700585e013 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/CreateFinding/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/CreateFinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/CreateMuteConfig/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/CreateMuteConfig/main.go index 93ee123850fc..08b0d86efa2a 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/CreateMuteConfig/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/CreateMuteConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/CreateNotificationConfig/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/CreateNotificationConfig/main.go index 57b345b497d6..6515110f3e82 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/CreateNotificationConfig/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/CreateNotificationConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/CreateSource/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/CreateSource/main.go index 2f8a9b20f773..256dcce72d59 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/CreateSource/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/CreateSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/DeleteBigQueryExport/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/DeleteBigQueryExport/main.go index 7dc8e139cb6c..94c76edb69de 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/DeleteBigQueryExport/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/DeleteBigQueryExport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/DeleteMuteConfig/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/DeleteMuteConfig/main.go index 4ea833ba06dc..24491252da0c 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/DeleteMuteConfig/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/DeleteMuteConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/DeleteNotificationConfig/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/DeleteNotificationConfig/main.go index 9d368fffb8c3..430f1233ac6e 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/DeleteNotificationConfig/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/DeleteNotificationConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/DeleteOperation/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/DeleteOperation/main.go index ad224ec7bb25..b92861138599 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/DeleteResourceValueConfig/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/DeleteResourceValueConfig/main.go index 22e0bc0e11c6..fe040a0ba15d 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/DeleteResourceValueConfig/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/DeleteResourceValueConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/GetBigQueryExport/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/GetBigQueryExport/main.go index 57574d8596e8..3a75cfff2aa4 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/GetBigQueryExport/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/GetBigQueryExport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/GetIamPolicy/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/GetIamPolicy/main.go index 29ad6a3fd3ca..2ea8bb454832 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/GetMuteConfig/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/GetMuteConfig/main.go index 7eb8e21cd6af..d6697015b955 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/GetMuteConfig/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/GetMuteConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/GetNotificationConfig/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/GetNotificationConfig/main.go index f5ed9dfcfbf3..ef048b29fac2 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/GetNotificationConfig/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/GetNotificationConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/GetOperation/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/GetOperation/main.go index 2daa157bfc4c..f533f6411755 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/GetOperation/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/GetResourceValueConfig/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/GetResourceValueConfig/main.go index cfd9c8ab26f0..ca857805b881 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/GetResourceValueConfig/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/GetResourceValueConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/GetSimulation/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/GetSimulation/main.go index bb69d7d37fe5..f7237fadf683 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/GetSimulation/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/GetSimulation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/GetSource/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/GetSource/main.go index c45f3a2251d0..b97e457f642a 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/GetSource/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/GetSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/GetValuedResource/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/GetValuedResource/main.go index dd501b37d567..3d42d9a4b9f0 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/GetValuedResource/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/GetValuedResource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/GroupFindings/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/GroupFindings/main.go index e051622a81dd..0bb26ef943fe 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/GroupFindings/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/GroupFindings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/ListAttackPaths/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/ListAttackPaths/main.go index 35783e141daf..141139de475d 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/ListAttackPaths/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/ListAttackPaths/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/ListBigQueryExports/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/ListBigQueryExports/main.go index 4fa08fd38a4b..916b41f72217 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/ListBigQueryExports/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/ListBigQueryExports/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/ListFindings/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/ListFindings/main.go index 67a0ca4c2e07..4028d0890782 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/ListFindings/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/ListFindings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/ListMuteConfigs/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/ListMuteConfigs/main.go index fa205e1b8c19..7798b137d449 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/ListMuteConfigs/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/ListMuteConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/ListNotificationConfigs/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/ListNotificationConfigs/main.go index 9b3c126b9880..a15f0bff85f4 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/ListNotificationConfigs/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/ListNotificationConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/ListOperations/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/ListOperations/main.go index 8f9ba7079554..e5e8141d5d56 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/ListOperations/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/ListResourceValueConfigs/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/ListResourceValueConfigs/main.go index bbead52bda9f..748579745f2e 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/ListResourceValueConfigs/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/ListResourceValueConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/ListSources/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/ListSources/main.go index 2d465be2e113..12a7b5972fd6 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/ListSources/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/ListSources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/ListValuedResources/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/ListValuedResources/main.go index 3c1cc7d9e1e6..c37499199e88 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/ListValuedResources/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/ListValuedResources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/SetFindingState/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/SetFindingState/main.go index 1677118967d8..49622247ef4c 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/SetFindingState/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/SetFindingState/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/SetIamPolicy/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/SetIamPolicy/main.go index 2d821b062e3e..33cf6cb7b93c 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/SetMute/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/SetMute/main.go index 9046d8856faa..a29b70fd0fc8 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/SetMute/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/SetMute/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/TestIamPermissions/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/TestIamPermissions/main.go index 2272107c3d87..e8d730f203c9 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/UpdateBigQueryExport/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/UpdateBigQueryExport/main.go index 1c829a0c2963..fe00ffe881bf 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/UpdateBigQueryExport/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/UpdateBigQueryExport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/UpdateExternalSystem/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/UpdateExternalSystem/main.go index 5f7b627d51a8..e5a0692a3fc3 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/UpdateExternalSystem/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/UpdateExternalSystem/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/UpdateFinding/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/UpdateFinding/main.go index 81a34644d5db..93a52f72cd66 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/UpdateFinding/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/UpdateFinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/UpdateMuteConfig/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/UpdateMuteConfig/main.go index 91a112606e37..6d2f21cdc0a7 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/UpdateMuteConfig/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/UpdateMuteConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/UpdateNotificationConfig/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/UpdateNotificationConfig/main.go index 6f9789a2dd62..32dab7ebbbee 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/UpdateNotificationConfig/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/UpdateNotificationConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/UpdateResourceValueConfig/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/UpdateResourceValueConfig/main.go index 3850edaabeda..5f334fc729c8 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/UpdateResourceValueConfig/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/UpdateResourceValueConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/UpdateSecurityMarks/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/UpdateSecurityMarks/main.go index cb49ca5121ae..9ca2ade486e2 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/UpdateSecurityMarks/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/UpdateSecurityMarks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/Client/UpdateSource/main.go b/internal/generated/snippets/securitycenter/apiv2/Client/UpdateSource/main.go index a96e64dc8003..2cb39a1ab13b 100644 --- a/internal/generated/snippets/securitycenter/apiv2/Client/UpdateSource/main.go +++ b/internal/generated/snippets/securitycenter/apiv2/Client/UpdateSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/apiv2/snippet_metadata.google.cloud.securitycenter.v2.json b/internal/generated/snippets/securitycenter/apiv2/snippet_metadata.google.cloud.securitycenter.v2.json index 6982c6d831b2..f68af8b2bf83 100644 --- a/internal/generated/snippets/securitycenter/apiv2/snippet_metadata.google.cloud.securitycenter.v2.json +++ b/internal/generated/snippets/securitycenter/apiv2/snippet_metadata.google.cloud.securitycenter.v2.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/securitycenter/apiv2", - "version": "1.35.2", + "version": "1.35.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/BatchCalculateEffectiveSettings/main.go b/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/BatchCalculateEffectiveSettings/main.go index 7d0b74aad7ec..c110a4f3ef61 100644 --- a/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/BatchCalculateEffectiveSettings/main.go +++ b/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/BatchCalculateEffectiveSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/BatchGetSettings/main.go b/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/BatchGetSettings/main.go index 4e778e11956a..9d508f6c070a 100644 --- a/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/BatchGetSettings/main.go +++ b/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/BatchGetSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/CalculateEffectiveComponentSettings/main.go b/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/CalculateEffectiveComponentSettings/main.go index 1ebce22ea7f5..888ba03a432d 100644 --- a/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/CalculateEffectiveComponentSettings/main.go +++ b/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/CalculateEffectiveComponentSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/CalculateEffectiveSettings/main.go b/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/CalculateEffectiveSettings/main.go index 4efe713ddbc6..41b348fad2d0 100644 --- a/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/CalculateEffectiveSettings/main.go +++ b/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/CalculateEffectiveSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/GetComponentSettings/main.go b/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/GetComponentSettings/main.go index 54306d4336c4..00f44b28e9c3 100644 --- a/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/GetComponentSettings/main.go +++ b/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/GetComponentSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/GetServiceAccount/main.go b/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/GetServiceAccount/main.go index 073b7e8ef401..3f9565649f31 100644 --- a/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/GetServiceAccount/main.go +++ b/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/GetServiceAccount/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/GetSettings/main.go b/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/GetSettings/main.go index 12a82fbc1e20..daefc125ea39 100644 --- a/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/GetSettings/main.go +++ b/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/GetSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/ListComponents/main.go b/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/ListComponents/main.go index 44ac654d5d38..6f9427561cdf 100644 --- a/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/ListComponents/main.go +++ b/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/ListComponents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/ListDetectors/main.go b/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/ListDetectors/main.go index 2238f9f353f8..b740b632347f 100644 --- a/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/ListDetectors/main.go +++ b/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/ListDetectors/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/ResetComponentSettings/main.go b/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/ResetComponentSettings/main.go index 16d5fd4543ef..b6f4254c2b20 100644 --- a/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/ResetComponentSettings/main.go +++ b/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/ResetComponentSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/ResetSettings/main.go b/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/ResetSettings/main.go index 9f868833a062..ddf45c591b92 100644 --- a/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/ResetSettings/main.go +++ b/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/ResetSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/UpdateComponentSettings/main.go b/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/UpdateComponentSettings/main.go index 3cca06013704..01c379fe2ec6 100644 --- a/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/UpdateComponentSettings/main.go +++ b/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/UpdateComponentSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/UpdateSettings/main.go b/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/UpdateSettings/main.go index 2649500a571d..994896558938 100644 --- a/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/UpdateSettings/main.go +++ b/internal/generated/snippets/securitycenter/settings/apiv1beta1/SecurityCenterSettingsClient/UpdateSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycenter/settings/apiv1beta1/snippet_metadata.google.cloud.securitycenter.settings.v1beta1.json b/internal/generated/snippets/securitycenter/settings/apiv1beta1/snippet_metadata.google.cloud.securitycenter.settings.v1beta1.json index a92a31222220..02ca1b45a8ac 100644 --- a/internal/generated/snippets/securitycenter/settings/apiv1beta1/snippet_metadata.google.cloud.securitycenter.settings.v1beta1.json +++ b/internal/generated/snippets/securitycenter/settings/apiv1beta1/snippet_metadata.google.cloud.securitycenter.settings.v1beta1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/securitycenter/settings/apiv1beta1", - "version": "1.35.2", + "version": "1.35.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/securitycentermanagement/apiv1/Client/CreateEventThreatDetectionCustomModule/main.go b/internal/generated/snippets/securitycentermanagement/apiv1/Client/CreateEventThreatDetectionCustomModule/main.go index 82084a2e00c0..04f2a7159b3c 100644 --- a/internal/generated/snippets/securitycentermanagement/apiv1/Client/CreateEventThreatDetectionCustomModule/main.go +++ b/internal/generated/snippets/securitycentermanagement/apiv1/Client/CreateEventThreatDetectionCustomModule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycentermanagement/apiv1/Client/CreateSecurityHealthAnalyticsCustomModule/main.go b/internal/generated/snippets/securitycentermanagement/apiv1/Client/CreateSecurityHealthAnalyticsCustomModule/main.go index 8584977bdade..87c3059ed573 100644 --- a/internal/generated/snippets/securitycentermanagement/apiv1/Client/CreateSecurityHealthAnalyticsCustomModule/main.go +++ b/internal/generated/snippets/securitycentermanagement/apiv1/Client/CreateSecurityHealthAnalyticsCustomModule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycentermanagement/apiv1/Client/DeleteEventThreatDetectionCustomModule/main.go b/internal/generated/snippets/securitycentermanagement/apiv1/Client/DeleteEventThreatDetectionCustomModule/main.go index 7df04a1bd357..c2f273f9d1dd 100644 --- a/internal/generated/snippets/securitycentermanagement/apiv1/Client/DeleteEventThreatDetectionCustomModule/main.go +++ b/internal/generated/snippets/securitycentermanagement/apiv1/Client/DeleteEventThreatDetectionCustomModule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycentermanagement/apiv1/Client/DeleteSecurityHealthAnalyticsCustomModule/main.go b/internal/generated/snippets/securitycentermanagement/apiv1/Client/DeleteSecurityHealthAnalyticsCustomModule/main.go index 98396b8b5393..1978e682620f 100644 --- a/internal/generated/snippets/securitycentermanagement/apiv1/Client/DeleteSecurityHealthAnalyticsCustomModule/main.go +++ b/internal/generated/snippets/securitycentermanagement/apiv1/Client/DeleteSecurityHealthAnalyticsCustomModule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycentermanagement/apiv1/Client/GetEffectiveEventThreatDetectionCustomModule/main.go b/internal/generated/snippets/securitycentermanagement/apiv1/Client/GetEffectiveEventThreatDetectionCustomModule/main.go index 1e8fa3b58d81..46b69019d5d3 100644 --- a/internal/generated/snippets/securitycentermanagement/apiv1/Client/GetEffectiveEventThreatDetectionCustomModule/main.go +++ b/internal/generated/snippets/securitycentermanagement/apiv1/Client/GetEffectiveEventThreatDetectionCustomModule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycentermanagement/apiv1/Client/GetEffectiveSecurityHealthAnalyticsCustomModule/main.go b/internal/generated/snippets/securitycentermanagement/apiv1/Client/GetEffectiveSecurityHealthAnalyticsCustomModule/main.go index c90bd2e3742d..d14cccc52694 100644 --- a/internal/generated/snippets/securitycentermanagement/apiv1/Client/GetEffectiveSecurityHealthAnalyticsCustomModule/main.go +++ b/internal/generated/snippets/securitycentermanagement/apiv1/Client/GetEffectiveSecurityHealthAnalyticsCustomModule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycentermanagement/apiv1/Client/GetEventThreatDetectionCustomModule/main.go b/internal/generated/snippets/securitycentermanagement/apiv1/Client/GetEventThreatDetectionCustomModule/main.go index 965bb2b940bd..a5b2bee9660f 100644 --- a/internal/generated/snippets/securitycentermanagement/apiv1/Client/GetEventThreatDetectionCustomModule/main.go +++ b/internal/generated/snippets/securitycentermanagement/apiv1/Client/GetEventThreatDetectionCustomModule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycentermanagement/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/securitycentermanagement/apiv1/Client/GetLocation/main.go index 08b4f2ac1f12..74e12a3dc052 100644 --- a/internal/generated/snippets/securitycentermanagement/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/securitycentermanagement/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycentermanagement/apiv1/Client/GetSecurityCenterService/main.go b/internal/generated/snippets/securitycentermanagement/apiv1/Client/GetSecurityCenterService/main.go index f26e08f2ff10..484027526614 100644 --- a/internal/generated/snippets/securitycentermanagement/apiv1/Client/GetSecurityCenterService/main.go +++ b/internal/generated/snippets/securitycentermanagement/apiv1/Client/GetSecurityCenterService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycentermanagement/apiv1/Client/GetSecurityHealthAnalyticsCustomModule/main.go b/internal/generated/snippets/securitycentermanagement/apiv1/Client/GetSecurityHealthAnalyticsCustomModule/main.go index 993007906c39..f2d1ed7ac7db 100644 --- a/internal/generated/snippets/securitycentermanagement/apiv1/Client/GetSecurityHealthAnalyticsCustomModule/main.go +++ b/internal/generated/snippets/securitycentermanagement/apiv1/Client/GetSecurityHealthAnalyticsCustomModule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListDescendantEventThreatDetectionCustomModules/main.go b/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListDescendantEventThreatDetectionCustomModules/main.go index a0adbb4f077b..f73606f7f18d 100644 --- a/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListDescendantEventThreatDetectionCustomModules/main.go +++ b/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListDescendantEventThreatDetectionCustomModules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListDescendantSecurityHealthAnalyticsCustomModules/main.go b/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListDescendantSecurityHealthAnalyticsCustomModules/main.go index 89b5fbb4f18a..554084602175 100644 --- a/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListDescendantSecurityHealthAnalyticsCustomModules/main.go +++ b/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListDescendantSecurityHealthAnalyticsCustomModules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListEffectiveEventThreatDetectionCustomModules/main.go b/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListEffectiveEventThreatDetectionCustomModules/main.go index 5c78fd0cdd20..34e9da6496fd 100644 --- a/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListEffectiveEventThreatDetectionCustomModules/main.go +++ b/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListEffectiveEventThreatDetectionCustomModules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListEffectiveSecurityHealthAnalyticsCustomModules/main.go b/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListEffectiveSecurityHealthAnalyticsCustomModules/main.go index f865f846b564..5cef21ef19f6 100644 --- a/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListEffectiveSecurityHealthAnalyticsCustomModules/main.go +++ b/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListEffectiveSecurityHealthAnalyticsCustomModules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListEventThreatDetectionCustomModules/main.go b/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListEventThreatDetectionCustomModules/main.go index ea8a4c2bae0c..b03500a4d687 100644 --- a/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListEventThreatDetectionCustomModules/main.go +++ b/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListEventThreatDetectionCustomModules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListLocations/main.go index 271a7c6ea862..cccbda09e580 100644 --- a/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListSecurityCenterServices/main.go b/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListSecurityCenterServices/main.go index 3e926cde485d..5c11c66f0313 100644 --- a/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListSecurityCenterServices/main.go +++ b/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListSecurityCenterServices/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListSecurityHealthAnalyticsCustomModules/main.go b/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListSecurityHealthAnalyticsCustomModules/main.go index a32d6f3bf583..498bdd8bf40d 100644 --- a/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListSecurityHealthAnalyticsCustomModules/main.go +++ b/internal/generated/snippets/securitycentermanagement/apiv1/Client/ListSecurityHealthAnalyticsCustomModules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycentermanagement/apiv1/Client/SimulateSecurityHealthAnalyticsCustomModule/main.go b/internal/generated/snippets/securitycentermanagement/apiv1/Client/SimulateSecurityHealthAnalyticsCustomModule/main.go index 6320971a4a7f..c11af1e0421d 100644 --- a/internal/generated/snippets/securitycentermanagement/apiv1/Client/SimulateSecurityHealthAnalyticsCustomModule/main.go +++ b/internal/generated/snippets/securitycentermanagement/apiv1/Client/SimulateSecurityHealthAnalyticsCustomModule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycentermanagement/apiv1/Client/UpdateEventThreatDetectionCustomModule/main.go b/internal/generated/snippets/securitycentermanagement/apiv1/Client/UpdateEventThreatDetectionCustomModule/main.go index 895eac5cc195..8696ab91c529 100644 --- a/internal/generated/snippets/securitycentermanagement/apiv1/Client/UpdateEventThreatDetectionCustomModule/main.go +++ b/internal/generated/snippets/securitycentermanagement/apiv1/Client/UpdateEventThreatDetectionCustomModule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycentermanagement/apiv1/Client/UpdateSecurityCenterService/main.go b/internal/generated/snippets/securitycentermanagement/apiv1/Client/UpdateSecurityCenterService/main.go index 06300ffb02a1..5af35b484c96 100644 --- a/internal/generated/snippets/securitycentermanagement/apiv1/Client/UpdateSecurityCenterService/main.go +++ b/internal/generated/snippets/securitycentermanagement/apiv1/Client/UpdateSecurityCenterService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycentermanagement/apiv1/Client/UpdateSecurityHealthAnalyticsCustomModule/main.go b/internal/generated/snippets/securitycentermanagement/apiv1/Client/UpdateSecurityHealthAnalyticsCustomModule/main.go index ea6e5e0a3676..aa85d0f6639a 100644 --- a/internal/generated/snippets/securitycentermanagement/apiv1/Client/UpdateSecurityHealthAnalyticsCustomModule/main.go +++ b/internal/generated/snippets/securitycentermanagement/apiv1/Client/UpdateSecurityHealthAnalyticsCustomModule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycentermanagement/apiv1/Client/ValidateEventThreatDetectionCustomModule/main.go b/internal/generated/snippets/securitycentermanagement/apiv1/Client/ValidateEventThreatDetectionCustomModule/main.go index 3f8128b9226e..d8baa660f1bc 100644 --- a/internal/generated/snippets/securitycentermanagement/apiv1/Client/ValidateEventThreatDetectionCustomModule/main.go +++ b/internal/generated/snippets/securitycentermanagement/apiv1/Client/ValidateEventThreatDetectionCustomModule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securitycentermanagement/apiv1/snippet_metadata.google.cloud.securitycentermanagement.v1.json b/internal/generated/snippets/securitycentermanagement/apiv1/snippet_metadata.google.cloud.securitycentermanagement.v1.json index 3958664edd2c..7a742aa8e73d 100644 --- a/internal/generated/snippets/securitycentermanagement/apiv1/snippet_metadata.google.cloud.securitycentermanagement.v1.json +++ b/internal/generated/snippets/securitycentermanagement/apiv1/snippet_metadata.google.cloud.securitycentermanagement.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/securitycentermanagement/apiv1", - "version": "1.1.2", + "version": "1.1.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/securityposture/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/securityposture/apiv1/Client/CancelOperation/main.go index 2a56e153d7ec..3d421b3a802e 100644 --- a/internal/generated/snippets/securityposture/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/securityposture/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securityposture/apiv1/Client/CreatePosture/main.go b/internal/generated/snippets/securityposture/apiv1/Client/CreatePosture/main.go index 399bea20dcb1..0f64a48db12a 100644 --- a/internal/generated/snippets/securityposture/apiv1/Client/CreatePosture/main.go +++ b/internal/generated/snippets/securityposture/apiv1/Client/CreatePosture/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securityposture/apiv1/Client/CreatePostureDeployment/main.go b/internal/generated/snippets/securityposture/apiv1/Client/CreatePostureDeployment/main.go index ab95b2731827..b544e6157348 100644 --- a/internal/generated/snippets/securityposture/apiv1/Client/CreatePostureDeployment/main.go +++ b/internal/generated/snippets/securityposture/apiv1/Client/CreatePostureDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securityposture/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/securityposture/apiv1/Client/DeleteOperation/main.go index 916e52ec63d6..5f93c703c07f 100644 --- a/internal/generated/snippets/securityposture/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/securityposture/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securityposture/apiv1/Client/DeletePosture/main.go b/internal/generated/snippets/securityposture/apiv1/Client/DeletePosture/main.go index 3903ceabd96a..ff223fd12fca 100644 --- a/internal/generated/snippets/securityposture/apiv1/Client/DeletePosture/main.go +++ b/internal/generated/snippets/securityposture/apiv1/Client/DeletePosture/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securityposture/apiv1/Client/DeletePostureDeployment/main.go b/internal/generated/snippets/securityposture/apiv1/Client/DeletePostureDeployment/main.go index 6777fa0cfa53..6a43f193bbca 100644 --- a/internal/generated/snippets/securityposture/apiv1/Client/DeletePostureDeployment/main.go +++ b/internal/generated/snippets/securityposture/apiv1/Client/DeletePostureDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securityposture/apiv1/Client/ExtractPosture/main.go b/internal/generated/snippets/securityposture/apiv1/Client/ExtractPosture/main.go index 626285e41663..55befdefd803 100644 --- a/internal/generated/snippets/securityposture/apiv1/Client/ExtractPosture/main.go +++ b/internal/generated/snippets/securityposture/apiv1/Client/ExtractPosture/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securityposture/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/securityposture/apiv1/Client/GetLocation/main.go index 42fbaa7362aa..fbde911134d6 100644 --- a/internal/generated/snippets/securityposture/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/securityposture/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securityposture/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/securityposture/apiv1/Client/GetOperation/main.go index ee20e4de61b3..b744078ff73b 100644 --- a/internal/generated/snippets/securityposture/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/securityposture/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securityposture/apiv1/Client/GetPosture/main.go b/internal/generated/snippets/securityposture/apiv1/Client/GetPosture/main.go index 317299e7e140..9f82b1de8ac0 100644 --- a/internal/generated/snippets/securityposture/apiv1/Client/GetPosture/main.go +++ b/internal/generated/snippets/securityposture/apiv1/Client/GetPosture/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securityposture/apiv1/Client/GetPostureDeployment/main.go b/internal/generated/snippets/securityposture/apiv1/Client/GetPostureDeployment/main.go index 8e0ac80944cc..6ea58de20070 100644 --- a/internal/generated/snippets/securityposture/apiv1/Client/GetPostureDeployment/main.go +++ b/internal/generated/snippets/securityposture/apiv1/Client/GetPostureDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securityposture/apiv1/Client/GetPostureTemplate/main.go b/internal/generated/snippets/securityposture/apiv1/Client/GetPostureTemplate/main.go index 40cae58901db..780e020c6af4 100644 --- a/internal/generated/snippets/securityposture/apiv1/Client/GetPostureTemplate/main.go +++ b/internal/generated/snippets/securityposture/apiv1/Client/GetPostureTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securityposture/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/securityposture/apiv1/Client/ListLocations/main.go index 8815de9eceb5..cab2052e1058 100644 --- a/internal/generated/snippets/securityposture/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/securityposture/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securityposture/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/securityposture/apiv1/Client/ListOperations/main.go index b0ca89a5bcaa..dd0d07b8fd94 100644 --- a/internal/generated/snippets/securityposture/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/securityposture/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securityposture/apiv1/Client/ListPostureDeployments/main.go b/internal/generated/snippets/securityposture/apiv1/Client/ListPostureDeployments/main.go index c89dcf3881c1..3be7be161bbb 100644 --- a/internal/generated/snippets/securityposture/apiv1/Client/ListPostureDeployments/main.go +++ b/internal/generated/snippets/securityposture/apiv1/Client/ListPostureDeployments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securityposture/apiv1/Client/ListPostureRevisions/main.go b/internal/generated/snippets/securityposture/apiv1/Client/ListPostureRevisions/main.go index fe7801c6217b..2f3a4bee75fb 100644 --- a/internal/generated/snippets/securityposture/apiv1/Client/ListPostureRevisions/main.go +++ b/internal/generated/snippets/securityposture/apiv1/Client/ListPostureRevisions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securityposture/apiv1/Client/ListPostureTemplates/main.go b/internal/generated/snippets/securityposture/apiv1/Client/ListPostureTemplates/main.go index 739f5cc801b2..c943d1d5790c 100644 --- a/internal/generated/snippets/securityposture/apiv1/Client/ListPostureTemplates/main.go +++ b/internal/generated/snippets/securityposture/apiv1/Client/ListPostureTemplates/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securityposture/apiv1/Client/ListPostures/main.go b/internal/generated/snippets/securityposture/apiv1/Client/ListPostures/main.go index d30f0c58c158..a9e199349a48 100644 --- a/internal/generated/snippets/securityposture/apiv1/Client/ListPostures/main.go +++ b/internal/generated/snippets/securityposture/apiv1/Client/ListPostures/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securityposture/apiv1/Client/UpdatePosture/main.go b/internal/generated/snippets/securityposture/apiv1/Client/UpdatePosture/main.go index c3755519b567..b5ab7c88fcaa 100644 --- a/internal/generated/snippets/securityposture/apiv1/Client/UpdatePosture/main.go +++ b/internal/generated/snippets/securityposture/apiv1/Client/UpdatePosture/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securityposture/apiv1/Client/UpdatePostureDeployment/main.go b/internal/generated/snippets/securityposture/apiv1/Client/UpdatePostureDeployment/main.go index 7c9d4f3a5a8a..fb82d4e31162 100644 --- a/internal/generated/snippets/securityposture/apiv1/Client/UpdatePostureDeployment/main.go +++ b/internal/generated/snippets/securityposture/apiv1/Client/UpdatePostureDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/securityposture/apiv1/snippet_metadata.google.cloud.securityposture.v1.json b/internal/generated/snippets/securityposture/apiv1/snippet_metadata.google.cloud.securityposture.v1.json index 81dcdec928a7..7ba255c2f3a6 100644 --- a/internal/generated/snippets/securityposture/apiv1/snippet_metadata.google.cloud.securityposture.v1.json +++ b/internal/generated/snippets/securityposture/apiv1/snippet_metadata.google.cloud.securityposture.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/securityposture/apiv1", - "version": "0.2.2", + "version": "0.2.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/servicecontrol/apiv1/QuotaControllerClient/AllocateQuota/main.go b/internal/generated/snippets/servicecontrol/apiv1/QuotaControllerClient/AllocateQuota/main.go index ea132843ce36..345612f5b1f3 100644 --- a/internal/generated/snippets/servicecontrol/apiv1/QuotaControllerClient/AllocateQuota/main.go +++ b/internal/generated/snippets/servicecontrol/apiv1/QuotaControllerClient/AllocateQuota/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicecontrol/apiv1/ServiceControllerClient/Check/main.go b/internal/generated/snippets/servicecontrol/apiv1/ServiceControllerClient/Check/main.go index cb10b7d14656..52b4a945b2ae 100644 --- a/internal/generated/snippets/servicecontrol/apiv1/ServiceControllerClient/Check/main.go +++ b/internal/generated/snippets/servicecontrol/apiv1/ServiceControllerClient/Check/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicecontrol/apiv1/ServiceControllerClient/Report/main.go b/internal/generated/snippets/servicecontrol/apiv1/ServiceControllerClient/Report/main.go index 229c8f414fb1..61b9f4ca0cf5 100644 --- a/internal/generated/snippets/servicecontrol/apiv1/ServiceControllerClient/Report/main.go +++ b/internal/generated/snippets/servicecontrol/apiv1/ServiceControllerClient/Report/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicecontrol/apiv1/snippet_metadata.google.api.servicecontrol.v1.json b/internal/generated/snippets/servicecontrol/apiv1/snippet_metadata.google.api.servicecontrol.v1.json index a936512528d4..a64c8d2e44f5 100644 --- a/internal/generated/snippets/servicecontrol/apiv1/snippet_metadata.google.api.servicecontrol.v1.json +++ b/internal/generated/snippets/servicecontrol/apiv1/snippet_metadata.google.api.servicecontrol.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/servicecontrol/apiv1", - "version": "1.14.2", + "version": "1.14.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/servicedirectory/apiv1/LookupClient/GetLocation/main.go b/internal/generated/snippets/servicedirectory/apiv1/LookupClient/GetLocation/main.go index 27854f5f1098..5e7af7d07590 100644 --- a/internal/generated/snippets/servicedirectory/apiv1/LookupClient/GetLocation/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1/LookupClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1/LookupClient/ListLocations/main.go b/internal/generated/snippets/servicedirectory/apiv1/LookupClient/ListLocations/main.go index 77202d9fcd38..4298c672a777 100644 --- a/internal/generated/snippets/servicedirectory/apiv1/LookupClient/ListLocations/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1/LookupClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1/LookupClient/ResolveService/main.go b/internal/generated/snippets/servicedirectory/apiv1/LookupClient/ResolveService/main.go index 6d9a87754e02..d31953653116 100644 --- a/internal/generated/snippets/servicedirectory/apiv1/LookupClient/ResolveService/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1/LookupClient/ResolveService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/CreateEndpoint/main.go b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/CreateEndpoint/main.go index af6f604adcbb..24d443c06657 100644 --- a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/CreateEndpoint/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/CreateEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/CreateNamespace/main.go b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/CreateNamespace/main.go index 2102357bc665..bd3a004d965c 100644 --- a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/CreateNamespace/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/CreateNamespace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/CreateService/main.go b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/CreateService/main.go index 09bc89844e12..0cb4f7658496 100644 --- a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/CreateService/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/CreateService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/DeleteEndpoint/main.go b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/DeleteEndpoint/main.go index dfb2b9e530e4..0c17ef1b3f02 100644 --- a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/DeleteEndpoint/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/DeleteEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/DeleteNamespace/main.go b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/DeleteNamespace/main.go index 175e572cdea1..640e9290436e 100644 --- a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/DeleteNamespace/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/DeleteNamespace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/DeleteService/main.go b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/DeleteService/main.go index a22297cf7448..9be24f36700a 100644 --- a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/DeleteService/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/DeleteService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/GetEndpoint/main.go b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/GetEndpoint/main.go index e1dcd1b929c2..d8ef3c7ffc7c 100644 --- a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/GetEndpoint/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/GetEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/GetIamPolicy/main.go b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/GetIamPolicy/main.go index e1a88517513d..43f23ef6b868 100644 --- a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/GetLocation/main.go b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/GetLocation/main.go index 8fc91389bc15..39baa91a3b28 100644 --- a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/GetLocation/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/GetNamespace/main.go b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/GetNamespace/main.go index 0f2383de991a..557f4fbc5866 100644 --- a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/GetNamespace/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/GetNamespace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/GetService/main.go b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/GetService/main.go index 5ecb3431035b..23f9fcad532b 100644 --- a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/GetService/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/GetService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/ListEndpoints/main.go b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/ListEndpoints/main.go index 7cf8d0e7cdec..31006ef44f74 100644 --- a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/ListEndpoints/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/ListEndpoints/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/ListLocations/main.go b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/ListLocations/main.go index 16d7936cc8db..3f7204336256 100644 --- a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/ListLocations/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/ListNamespaces/main.go b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/ListNamespaces/main.go index b16be2c0279e..2e5c3985f367 100644 --- a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/ListNamespaces/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/ListNamespaces/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/ListServices/main.go b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/ListServices/main.go index 37ee22634b6c..b29d3c3e1d39 100644 --- a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/ListServices/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/ListServices/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/SetIamPolicy/main.go b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/SetIamPolicy/main.go index a03994c40e86..bc1cb7c0c420 100644 --- a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/TestIamPermissions/main.go b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/TestIamPermissions/main.go index bf0e33a1deaa..119eda546861 100644 --- a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/UpdateEndpoint/main.go b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/UpdateEndpoint/main.go index ebc07433128a..5caa507bdd3d 100644 --- a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/UpdateEndpoint/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/UpdateEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/UpdateNamespace/main.go b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/UpdateNamespace/main.go index 44c42f896ee7..e54b53e21426 100644 --- a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/UpdateNamespace/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/UpdateNamespace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/UpdateService/main.go b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/UpdateService/main.go index 375b9d20567e..ded7fc5a95ed 100644 --- a/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/UpdateService/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1/RegistrationClient/UpdateService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1beta1/LookupClient/GetLocation/main.go b/internal/generated/snippets/servicedirectory/apiv1beta1/LookupClient/GetLocation/main.go index d3e7c88dd23e..489031079f39 100644 --- a/internal/generated/snippets/servicedirectory/apiv1beta1/LookupClient/GetLocation/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1beta1/LookupClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1beta1/LookupClient/ListLocations/main.go b/internal/generated/snippets/servicedirectory/apiv1beta1/LookupClient/ListLocations/main.go index 60d887794b74..6b46f5aefd8b 100644 --- a/internal/generated/snippets/servicedirectory/apiv1beta1/LookupClient/ListLocations/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1beta1/LookupClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1beta1/LookupClient/ResolveService/main.go b/internal/generated/snippets/servicedirectory/apiv1beta1/LookupClient/ResolveService/main.go index 64c8ef3ca973..646250c10a1d 100644 --- a/internal/generated/snippets/servicedirectory/apiv1beta1/LookupClient/ResolveService/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1beta1/LookupClient/ResolveService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/CreateEndpoint/main.go b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/CreateEndpoint/main.go index aa93d35e5874..b8b95cff6a7a 100644 --- a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/CreateEndpoint/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/CreateEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/CreateNamespace/main.go b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/CreateNamespace/main.go index 9b903b1f5111..1a7a997dc7a6 100644 --- a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/CreateNamespace/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/CreateNamespace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/CreateService/main.go b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/CreateService/main.go index 7ae1383376d8..43ae950f4e46 100644 --- a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/CreateService/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/CreateService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/DeleteEndpoint/main.go b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/DeleteEndpoint/main.go index 67bb68ad0426..19bcdc779509 100644 --- a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/DeleteEndpoint/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/DeleteEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/DeleteNamespace/main.go b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/DeleteNamespace/main.go index b2bf93b9d810..ad7b4f6d4d17 100644 --- a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/DeleteNamespace/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/DeleteNamespace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/DeleteService/main.go b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/DeleteService/main.go index 2f9f6859b28a..25bfcb8e489b 100644 --- a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/DeleteService/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/DeleteService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/GetEndpoint/main.go b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/GetEndpoint/main.go index 86c2981bef14..1630e59529f8 100644 --- a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/GetEndpoint/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/GetEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/GetIamPolicy/main.go b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/GetIamPolicy/main.go index 4a1e7ca87936..32964f728601 100644 --- a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/GetLocation/main.go b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/GetLocation/main.go index 46a40cc1c583..4f61da769aa6 100644 --- a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/GetLocation/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/GetNamespace/main.go b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/GetNamespace/main.go index 2ad7f4b4b5c3..dcc03c80092d 100644 --- a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/GetNamespace/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/GetNamespace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/GetService/main.go b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/GetService/main.go index 0b3cc405b27c..60edd9bac150 100644 --- a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/GetService/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/GetService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/ListEndpoints/main.go b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/ListEndpoints/main.go index 0a8319485ba7..64d6ce926106 100644 --- a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/ListEndpoints/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/ListEndpoints/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/ListLocations/main.go b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/ListLocations/main.go index 4a6548ec9a06..4f9d02a54068 100644 --- a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/ListLocations/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/ListNamespaces/main.go b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/ListNamespaces/main.go index 23d98caf3c78..2abc26df90e2 100644 --- a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/ListNamespaces/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/ListNamespaces/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/ListServices/main.go b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/ListServices/main.go index f091570da53c..b53d87f1f2d8 100644 --- a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/ListServices/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/ListServices/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/SetIamPolicy/main.go b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/SetIamPolicy/main.go index 3bc23e407fb8..223bdde6314a 100644 --- a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/TestIamPermissions/main.go b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/TestIamPermissions/main.go index fe958d001d04..8815a167da9f 100644 --- a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/UpdateEndpoint/main.go b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/UpdateEndpoint/main.go index 75dae89df485..b14bbcd4b372 100644 --- a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/UpdateEndpoint/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/UpdateEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/UpdateNamespace/main.go b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/UpdateNamespace/main.go index 3028b05649c6..d1c5f805832e 100644 --- a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/UpdateNamespace/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/UpdateNamespace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/UpdateService/main.go b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/UpdateService/main.go index f5cb6d5a890d..d88e720c63ac 100644 --- a/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/UpdateService/main.go +++ b/internal/generated/snippets/servicedirectory/apiv1beta1/RegistrationClient/UpdateService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicehealth/apiv1/Client/GetEvent/main.go b/internal/generated/snippets/servicehealth/apiv1/Client/GetEvent/main.go index 5c7a37af919e..4c71d774e56c 100644 --- a/internal/generated/snippets/servicehealth/apiv1/Client/GetEvent/main.go +++ b/internal/generated/snippets/servicehealth/apiv1/Client/GetEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicehealth/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/servicehealth/apiv1/Client/GetLocation/main.go index e87ae751b025..6f7f30b1250c 100644 --- a/internal/generated/snippets/servicehealth/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/servicehealth/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicehealth/apiv1/Client/GetOrganizationEvent/main.go b/internal/generated/snippets/servicehealth/apiv1/Client/GetOrganizationEvent/main.go index a2531f0195c0..967a1e7de2d8 100644 --- a/internal/generated/snippets/servicehealth/apiv1/Client/GetOrganizationEvent/main.go +++ b/internal/generated/snippets/servicehealth/apiv1/Client/GetOrganizationEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicehealth/apiv1/Client/GetOrganizationImpact/main.go b/internal/generated/snippets/servicehealth/apiv1/Client/GetOrganizationImpact/main.go index 433f0bf89778..69a4b601718c 100644 --- a/internal/generated/snippets/servicehealth/apiv1/Client/GetOrganizationImpact/main.go +++ b/internal/generated/snippets/servicehealth/apiv1/Client/GetOrganizationImpact/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicehealth/apiv1/Client/ListEvents/main.go b/internal/generated/snippets/servicehealth/apiv1/Client/ListEvents/main.go index 372ecbf0b3a9..40a4ecb02e9c 100644 --- a/internal/generated/snippets/servicehealth/apiv1/Client/ListEvents/main.go +++ b/internal/generated/snippets/servicehealth/apiv1/Client/ListEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicehealth/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/servicehealth/apiv1/Client/ListLocations/main.go index c9467e081a06..6f578e20a596 100644 --- a/internal/generated/snippets/servicehealth/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/servicehealth/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicehealth/apiv1/Client/ListOrganizationEvents/main.go b/internal/generated/snippets/servicehealth/apiv1/Client/ListOrganizationEvents/main.go index ae46f690f128..1e801785ab47 100644 --- a/internal/generated/snippets/servicehealth/apiv1/Client/ListOrganizationEvents/main.go +++ b/internal/generated/snippets/servicehealth/apiv1/Client/ListOrganizationEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicehealth/apiv1/Client/ListOrganizationImpacts/main.go b/internal/generated/snippets/servicehealth/apiv1/Client/ListOrganizationImpacts/main.go index 964d87320fd9..811528c1ae33 100644 --- a/internal/generated/snippets/servicehealth/apiv1/Client/ListOrganizationImpacts/main.go +++ b/internal/generated/snippets/servicehealth/apiv1/Client/ListOrganizationImpacts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicehealth/apiv1/snippet_metadata.google.cloud.servicehealth.v1.json b/internal/generated/snippets/servicehealth/apiv1/snippet_metadata.google.cloud.servicehealth.v1.json index fef6662bb25b..c4346b90a394 100644 --- a/internal/generated/snippets/servicehealth/apiv1/snippet_metadata.google.cloud.servicehealth.v1.json +++ b/internal/generated/snippets/servicehealth/apiv1/snippet_metadata.google.cloud.servicehealth.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/servicehealth/apiv1", - "version": "1.2.0", + "version": "1.2.1", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/CreateService/main.go b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/CreateService/main.go index 77951c0ed7d7..f2f45cc4edc5 100644 --- a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/CreateService/main.go +++ b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/CreateService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/CreateServiceConfig/main.go b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/CreateServiceConfig/main.go index 829f205d3eb3..49487da968eb 100644 --- a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/CreateServiceConfig/main.go +++ b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/CreateServiceConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/CreateServiceRollout/main.go b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/CreateServiceRollout/main.go index 9e3a0d08836d..0c9be3b7cfd5 100644 --- a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/CreateServiceRollout/main.go +++ b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/CreateServiceRollout/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/DeleteService/main.go b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/DeleteService/main.go index 250acec9725a..79e50237b8ad 100644 --- a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/DeleteService/main.go +++ b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/DeleteService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/GenerateConfigReport/main.go b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/GenerateConfigReport/main.go index 4538742871fc..a8258864f103 100644 --- a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/GenerateConfigReport/main.go +++ b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/GenerateConfigReport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/GetIamPolicy/main.go b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/GetIamPolicy/main.go index d41792fba1d7..6ba290f8675d 100644 --- a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/GetService/main.go b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/GetService/main.go index 3ee23094fc10..1b5be6cf0959 100644 --- a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/GetService/main.go +++ b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/GetService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/GetServiceConfig/main.go b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/GetServiceConfig/main.go index 73513b30569d..4ecacc69f94f 100644 --- a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/GetServiceConfig/main.go +++ b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/GetServiceConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/GetServiceRollout/main.go b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/GetServiceRollout/main.go index 24c12fb537fa..dd4af02ed1bb 100644 --- a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/GetServiceRollout/main.go +++ b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/GetServiceRollout/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/ListOperations/main.go b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/ListOperations/main.go index b4c2e5b6afba..ec714d5c58d5 100644 --- a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/ListOperations/main.go +++ b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/ListServiceConfigs/main.go b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/ListServiceConfigs/main.go index a6792c05ae19..096ac5d339d1 100644 --- a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/ListServiceConfigs/main.go +++ b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/ListServiceConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/ListServiceRollouts/main.go b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/ListServiceRollouts/main.go index 60744edbc0be..791f010e6c98 100644 --- a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/ListServiceRollouts/main.go +++ b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/ListServiceRollouts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/ListServices/main.go b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/ListServices/main.go index d809e52feec9..50b77863953f 100644 --- a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/ListServices/main.go +++ b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/ListServices/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/SetIamPolicy/main.go b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/SetIamPolicy/main.go index 0d81da56f053..f0a054330fd5 100644 --- a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/SubmitConfigSource/main.go b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/SubmitConfigSource/main.go index 8ee17c444399..e92de93d74e4 100644 --- a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/SubmitConfigSource/main.go +++ b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/SubmitConfigSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/TestIamPermissions/main.go b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/TestIamPermissions/main.go index fc14683c6e16..1181029df3c4 100644 --- a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/UndeleteService/main.go b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/UndeleteService/main.go index 115d29a96039..e3fb1cbcf8fc 100644 --- a/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/UndeleteService/main.go +++ b/internal/generated/snippets/servicemanagement/apiv1/ServiceManagerClient/UndeleteService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/serviceusage/apiv1/Client/BatchEnableServices/main.go b/internal/generated/snippets/serviceusage/apiv1/Client/BatchEnableServices/main.go index 552ab0fa29cb..1c24345886f8 100644 --- a/internal/generated/snippets/serviceusage/apiv1/Client/BatchEnableServices/main.go +++ b/internal/generated/snippets/serviceusage/apiv1/Client/BatchEnableServices/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/serviceusage/apiv1/Client/BatchGetServices/main.go b/internal/generated/snippets/serviceusage/apiv1/Client/BatchGetServices/main.go index db7e52827d02..e98fca707f52 100644 --- a/internal/generated/snippets/serviceusage/apiv1/Client/BatchGetServices/main.go +++ b/internal/generated/snippets/serviceusage/apiv1/Client/BatchGetServices/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/serviceusage/apiv1/Client/DisableService/main.go b/internal/generated/snippets/serviceusage/apiv1/Client/DisableService/main.go index b6a516f57173..8047a2e4409f 100644 --- a/internal/generated/snippets/serviceusage/apiv1/Client/DisableService/main.go +++ b/internal/generated/snippets/serviceusage/apiv1/Client/DisableService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/serviceusage/apiv1/Client/EnableService/main.go b/internal/generated/snippets/serviceusage/apiv1/Client/EnableService/main.go index e52d0555dd26..659ab9581140 100644 --- a/internal/generated/snippets/serviceusage/apiv1/Client/EnableService/main.go +++ b/internal/generated/snippets/serviceusage/apiv1/Client/EnableService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/serviceusage/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/serviceusage/apiv1/Client/GetOperation/main.go index f14d5f31e5b4..a4b8bc692ae1 100644 --- a/internal/generated/snippets/serviceusage/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/serviceusage/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/serviceusage/apiv1/Client/GetService/main.go b/internal/generated/snippets/serviceusage/apiv1/Client/GetService/main.go index ab11ff06ca04..683beb6888d3 100644 --- a/internal/generated/snippets/serviceusage/apiv1/Client/GetService/main.go +++ b/internal/generated/snippets/serviceusage/apiv1/Client/GetService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/serviceusage/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/serviceusage/apiv1/Client/ListOperations/main.go index 32b5905432db..ad14151de7de 100644 --- a/internal/generated/snippets/serviceusage/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/serviceusage/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/serviceusage/apiv1/Client/ListServices/main.go b/internal/generated/snippets/serviceusage/apiv1/Client/ListServices/main.go index 5aeb726c145d..8bdf961b9b40 100644 --- a/internal/generated/snippets/serviceusage/apiv1/Client/ListServices/main.go +++ b/internal/generated/snippets/serviceusage/apiv1/Client/ListServices/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shell/apiv1/CloudShellClient/AddPublicKey/main.go b/internal/generated/snippets/shell/apiv1/CloudShellClient/AddPublicKey/main.go index da9a634cab5c..5757b2585396 100644 --- a/internal/generated/snippets/shell/apiv1/CloudShellClient/AddPublicKey/main.go +++ b/internal/generated/snippets/shell/apiv1/CloudShellClient/AddPublicKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shell/apiv1/CloudShellClient/AuthorizeEnvironment/main.go b/internal/generated/snippets/shell/apiv1/CloudShellClient/AuthorizeEnvironment/main.go index 91c25ead9b5c..7f35c2b0c74b 100644 --- a/internal/generated/snippets/shell/apiv1/CloudShellClient/AuthorizeEnvironment/main.go +++ b/internal/generated/snippets/shell/apiv1/CloudShellClient/AuthorizeEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shell/apiv1/CloudShellClient/GetEnvironment/main.go b/internal/generated/snippets/shell/apiv1/CloudShellClient/GetEnvironment/main.go index 94f02861e05b..e3727656a3db 100644 --- a/internal/generated/snippets/shell/apiv1/CloudShellClient/GetEnvironment/main.go +++ b/internal/generated/snippets/shell/apiv1/CloudShellClient/GetEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shell/apiv1/CloudShellClient/RemovePublicKey/main.go b/internal/generated/snippets/shell/apiv1/CloudShellClient/RemovePublicKey/main.go index b110f1018d30..a6f90512769c 100644 --- a/internal/generated/snippets/shell/apiv1/CloudShellClient/RemovePublicKey/main.go +++ b/internal/generated/snippets/shell/apiv1/CloudShellClient/RemovePublicKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shell/apiv1/CloudShellClient/StartEnvironment/main.go b/internal/generated/snippets/shell/apiv1/CloudShellClient/StartEnvironment/main.go index 60dff2f6c363..90f226c69f9e 100644 --- a/internal/generated/snippets/shell/apiv1/CloudShellClient/StartEnvironment/main.go +++ b/internal/generated/snippets/shell/apiv1/CloudShellClient/StartEnvironment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/css/apiv1/AccountLabelsClient/CreateAccountLabel/main.go b/internal/generated/snippets/shopping/css/apiv1/AccountLabelsClient/CreateAccountLabel/main.go index 4c8ac338c659..5d0bb78be4a2 100644 --- a/internal/generated/snippets/shopping/css/apiv1/AccountLabelsClient/CreateAccountLabel/main.go +++ b/internal/generated/snippets/shopping/css/apiv1/AccountLabelsClient/CreateAccountLabel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/css/apiv1/AccountLabelsClient/DeleteAccountLabel/main.go b/internal/generated/snippets/shopping/css/apiv1/AccountLabelsClient/DeleteAccountLabel/main.go index 21b188e7cb03..4c1651659ad8 100644 --- a/internal/generated/snippets/shopping/css/apiv1/AccountLabelsClient/DeleteAccountLabel/main.go +++ b/internal/generated/snippets/shopping/css/apiv1/AccountLabelsClient/DeleteAccountLabel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/css/apiv1/AccountLabelsClient/ListAccountLabels/main.go b/internal/generated/snippets/shopping/css/apiv1/AccountLabelsClient/ListAccountLabels/main.go index 7751e1ca0148..b89416c5308a 100644 --- a/internal/generated/snippets/shopping/css/apiv1/AccountLabelsClient/ListAccountLabels/main.go +++ b/internal/generated/snippets/shopping/css/apiv1/AccountLabelsClient/ListAccountLabels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/css/apiv1/AccountLabelsClient/UpdateAccountLabel/main.go b/internal/generated/snippets/shopping/css/apiv1/AccountLabelsClient/UpdateAccountLabel/main.go index cf8d871d5acf..d63d618e628e 100644 --- a/internal/generated/snippets/shopping/css/apiv1/AccountLabelsClient/UpdateAccountLabel/main.go +++ b/internal/generated/snippets/shopping/css/apiv1/AccountLabelsClient/UpdateAccountLabel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/css/apiv1/AccountsClient/GetAccount/main.go b/internal/generated/snippets/shopping/css/apiv1/AccountsClient/GetAccount/main.go index dc297944059a..3a1ec6cab955 100644 --- a/internal/generated/snippets/shopping/css/apiv1/AccountsClient/GetAccount/main.go +++ b/internal/generated/snippets/shopping/css/apiv1/AccountsClient/GetAccount/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/css/apiv1/AccountsClient/ListChildAccounts/main.go b/internal/generated/snippets/shopping/css/apiv1/AccountsClient/ListChildAccounts/main.go index 758e3da322ba..6a1ec1d5990b 100644 --- a/internal/generated/snippets/shopping/css/apiv1/AccountsClient/ListChildAccounts/main.go +++ b/internal/generated/snippets/shopping/css/apiv1/AccountsClient/ListChildAccounts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/css/apiv1/AccountsClient/UpdateLabels/main.go b/internal/generated/snippets/shopping/css/apiv1/AccountsClient/UpdateLabels/main.go index b811af279589..bdbf900e7da0 100644 --- a/internal/generated/snippets/shopping/css/apiv1/AccountsClient/UpdateLabels/main.go +++ b/internal/generated/snippets/shopping/css/apiv1/AccountsClient/UpdateLabels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/css/apiv1/CssProductInputsClient/DeleteCssProductInput/main.go b/internal/generated/snippets/shopping/css/apiv1/CssProductInputsClient/DeleteCssProductInput/main.go index 55f05fdd00bd..fa81e2151c05 100644 --- a/internal/generated/snippets/shopping/css/apiv1/CssProductInputsClient/DeleteCssProductInput/main.go +++ b/internal/generated/snippets/shopping/css/apiv1/CssProductInputsClient/DeleteCssProductInput/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/css/apiv1/CssProductInputsClient/InsertCssProductInput/main.go b/internal/generated/snippets/shopping/css/apiv1/CssProductInputsClient/InsertCssProductInput/main.go index aaa194018721..b4eed013a23d 100644 --- a/internal/generated/snippets/shopping/css/apiv1/CssProductInputsClient/InsertCssProductInput/main.go +++ b/internal/generated/snippets/shopping/css/apiv1/CssProductInputsClient/InsertCssProductInput/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/css/apiv1/CssProductInputsClient/UpdateCssProductInput/main.go b/internal/generated/snippets/shopping/css/apiv1/CssProductInputsClient/UpdateCssProductInput/main.go index 20cf9fa8c5e2..0f43b4c77937 100644 --- a/internal/generated/snippets/shopping/css/apiv1/CssProductInputsClient/UpdateCssProductInput/main.go +++ b/internal/generated/snippets/shopping/css/apiv1/CssProductInputsClient/UpdateCssProductInput/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/css/apiv1/CssProductsClient/GetCssProduct/main.go b/internal/generated/snippets/shopping/css/apiv1/CssProductsClient/GetCssProduct/main.go index 7fb1e94a1d9e..96a9c43b9da0 100644 --- a/internal/generated/snippets/shopping/css/apiv1/CssProductsClient/GetCssProduct/main.go +++ b/internal/generated/snippets/shopping/css/apiv1/CssProductsClient/GetCssProduct/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/css/apiv1/CssProductsClient/ListCssProducts/main.go b/internal/generated/snippets/shopping/css/apiv1/CssProductsClient/ListCssProducts/main.go index 758e555b9b80..36e58d983eff 100644 --- a/internal/generated/snippets/shopping/css/apiv1/CssProductsClient/ListCssProducts/main.go +++ b/internal/generated/snippets/shopping/css/apiv1/CssProductsClient/ListCssProducts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/css/apiv1/snippet_metadata.google.shopping.css.v1.json b/internal/generated/snippets/shopping/css/apiv1/snippet_metadata.google.shopping.css.v1.json index 9ac603052400..925eeeafeec9 100644 --- a/internal/generated/snippets/shopping/css/apiv1/snippet_metadata.google.shopping.css.v1.json +++ b/internal/generated/snippets/shopping/css/apiv1/snippet_metadata.google.shopping.css.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/shopping/css/apiv1", - "version": "0.14.0", + "version": "0.15.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/AccountIssueClient/ListAccountIssues/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/AccountIssueClient/ListAccountIssues/main.go index f49b4ade1123..2bde22b82d11 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/AccountIssueClient/ListAccountIssues/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/AccountIssueClient/ListAccountIssues/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/AccountTaxClient/GetAccountTax/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/AccountTaxClient/GetAccountTax/main.go index 8e62939d2558..f7e66f1c2c37 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/AccountTaxClient/GetAccountTax/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/AccountTaxClient/GetAccountTax/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/AccountTaxClient/ListAccountTax/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/AccountTaxClient/ListAccountTax/main.go index 7133e7700f37..c9b329b56627 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/AccountTaxClient/ListAccountTax/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/AccountTaxClient/ListAccountTax/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/AccountTaxClient/UpdateAccountTax/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/AccountTaxClient/UpdateAccountTax/main.go index 536a4ce8e28d..788b3f21af43 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/AccountTaxClient/UpdateAccountTax/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/AccountTaxClient/UpdateAccountTax/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/AutofeedSettingsClient/GetAutofeedSettings/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/AutofeedSettingsClient/GetAutofeedSettings/main.go index 6a1abd879533..83795c24ece7 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/AutofeedSettingsClient/GetAutofeedSettings/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/AutofeedSettingsClient/GetAutofeedSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/AutofeedSettingsClient/UpdateAutofeedSettings/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/AutofeedSettingsClient/UpdateAutofeedSettings/main.go index 1abea8e74f27..3bf008c1d472 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/AutofeedSettingsClient/UpdateAutofeedSettings/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/AutofeedSettingsClient/UpdateAutofeedSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/BusinessIdentityClient/GetBusinessIdentity/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/BusinessIdentityClient/GetBusinessIdentity/main.go index 201b49669bef..77b582975103 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/BusinessIdentityClient/GetBusinessIdentity/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/BusinessIdentityClient/GetBusinessIdentity/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/BusinessIdentityClient/UpdateBusinessIdentity/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/BusinessIdentityClient/UpdateBusinessIdentity/main.go index 2e37638c827d..3769678bc411 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/BusinessIdentityClient/UpdateBusinessIdentity/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/BusinessIdentityClient/UpdateBusinessIdentity/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/BusinessInfoClient/GetBusinessInfo/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/BusinessInfoClient/GetBusinessInfo/main.go index 15ba0884b1c1..2de5bafa99c0 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/BusinessInfoClient/GetBusinessInfo/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/BusinessInfoClient/GetBusinessInfo/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/BusinessInfoClient/UpdateBusinessInfo/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/BusinessInfoClient/UpdateBusinessInfo/main.go index 264f169957dc..dd71bcfc2989 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/BusinessInfoClient/UpdateBusinessInfo/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/BusinessInfoClient/UpdateBusinessInfo/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/Client/CreateAndConfigureAccount/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/Client/CreateAndConfigureAccount/main.go index 00488605317d..b3df0c9d24ef 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/Client/CreateAndConfigureAccount/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/Client/CreateAndConfigureAccount/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/Client/DeleteAccount/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/Client/DeleteAccount/main.go index 3ce314a3a26d..d592ee7d9eba 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/Client/DeleteAccount/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/Client/DeleteAccount/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/Client/GetAccount/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/Client/GetAccount/main.go index 983d381cb8b7..7a189bd6e0bd 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/Client/GetAccount/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/Client/GetAccount/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/Client/ListAccounts/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/Client/ListAccounts/main.go index d2a28bf63930..5adc1f26524b 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/Client/ListAccounts/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/Client/ListAccounts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/Client/ListSubAccounts/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/Client/ListSubAccounts/main.go index 0009f91e5a1d..2b4588214136 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/Client/ListSubAccounts/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/Client/ListSubAccounts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/Client/UpdateAccount/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/Client/UpdateAccount/main.go index 18f478ea196f..6ecdbf8ad308 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/Client/UpdateAccount/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/Client/UpdateAccount/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/EmailPreferencesClient/GetEmailPreferences/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/EmailPreferencesClient/GetEmailPreferences/main.go index b085f4c18b16..6f6bbe65b490 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/EmailPreferencesClient/GetEmailPreferences/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/EmailPreferencesClient/GetEmailPreferences/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/EmailPreferencesClient/UpdateEmailPreferences/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/EmailPreferencesClient/UpdateEmailPreferences/main.go index 42c9bb54b75f..de4a7ad7eb5a 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/EmailPreferencesClient/UpdateEmailPreferences/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/EmailPreferencesClient/UpdateEmailPreferences/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/HomepageClient/ClaimHomepage/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/HomepageClient/ClaimHomepage/main.go index af9442bedc47..d9cc1dbb16df 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/HomepageClient/ClaimHomepage/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/HomepageClient/ClaimHomepage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/HomepageClient/GetHomepage/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/HomepageClient/GetHomepage/main.go index 46262ef07974..9d4107c89eb0 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/HomepageClient/GetHomepage/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/HomepageClient/GetHomepage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/HomepageClient/UnclaimHomepage/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/HomepageClient/UnclaimHomepage/main.go index b3a8c28f5215..cfda14946997 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/HomepageClient/UnclaimHomepage/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/HomepageClient/UnclaimHomepage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/HomepageClient/UpdateHomepage/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/HomepageClient/UpdateHomepage/main.go index 8a00af1e3543..083cc1327858 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/HomepageClient/UpdateHomepage/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/HomepageClient/UpdateHomepage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/OnlineReturnPolicyClient/GetOnlineReturnPolicy/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/OnlineReturnPolicyClient/GetOnlineReturnPolicy/main.go index 96a19fa037e8..d6186c7e6ed5 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/OnlineReturnPolicyClient/GetOnlineReturnPolicy/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/OnlineReturnPolicyClient/GetOnlineReturnPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/OnlineReturnPolicyClient/ListOnlineReturnPolicies/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/OnlineReturnPolicyClient/ListOnlineReturnPolicies/main.go index dc824afe8168..25ef0857c0c7 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/OnlineReturnPolicyClient/ListOnlineReturnPolicies/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/OnlineReturnPolicyClient/ListOnlineReturnPolicies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/ProgramsClient/DisableProgram/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/ProgramsClient/DisableProgram/main.go index 2eb49f441807..279bf0e3940d 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/ProgramsClient/DisableProgram/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/ProgramsClient/DisableProgram/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/ProgramsClient/EnableProgram/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/ProgramsClient/EnableProgram/main.go index 94339d8906fc..753901150e04 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/ProgramsClient/EnableProgram/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/ProgramsClient/EnableProgram/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/ProgramsClient/GetProgram/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/ProgramsClient/GetProgram/main.go index 06a7cb0d75d3..2344bc0019ce 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/ProgramsClient/GetProgram/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/ProgramsClient/GetProgram/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/ProgramsClient/ListPrograms/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/ProgramsClient/ListPrograms/main.go index da91a6931778..05a592e261c8 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/ProgramsClient/ListPrograms/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/ProgramsClient/ListPrograms/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/RegionsClient/CreateRegion/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/RegionsClient/CreateRegion/main.go index 5a5794500bfd..04e53d611322 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/RegionsClient/CreateRegion/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/RegionsClient/CreateRegion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/RegionsClient/DeleteRegion/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/RegionsClient/DeleteRegion/main.go index 27d2662cef7a..43c1fde1d4ae 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/RegionsClient/DeleteRegion/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/RegionsClient/DeleteRegion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/RegionsClient/GetRegion/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/RegionsClient/GetRegion/main.go index 4eef9ca1c6b9..615a4fa3bd16 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/RegionsClient/GetRegion/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/RegionsClient/GetRegion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/RegionsClient/ListRegions/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/RegionsClient/ListRegions/main.go index 1a646dfcad5e..92e67436e59e 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/RegionsClient/ListRegions/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/RegionsClient/ListRegions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/RegionsClient/UpdateRegion/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/RegionsClient/UpdateRegion/main.go index 545eab550095..482ce8c52352 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/RegionsClient/UpdateRegion/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/RegionsClient/UpdateRegion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/ShippingSettingsClient/GetShippingSettings/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/ShippingSettingsClient/GetShippingSettings/main.go index 34cc1f3b9702..3ad12a23aeb2 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/ShippingSettingsClient/GetShippingSettings/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/ShippingSettingsClient/GetShippingSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/ShippingSettingsClient/InsertShippingSettings/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/ShippingSettingsClient/InsertShippingSettings/main.go index b2063cac7892..bf31f1c7433a 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/ShippingSettingsClient/InsertShippingSettings/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/ShippingSettingsClient/InsertShippingSettings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/TermsOfServiceAgreementStateClient/GetTermsOfServiceAgreementState/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/TermsOfServiceAgreementStateClient/GetTermsOfServiceAgreementState/main.go index 30d3abc79d48..3201d475e9dd 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/TermsOfServiceAgreementStateClient/GetTermsOfServiceAgreementState/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/TermsOfServiceAgreementStateClient/GetTermsOfServiceAgreementState/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/TermsOfServiceAgreementStateClient/RetrieveForApplicationTermsOfServiceAgreementState/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/TermsOfServiceAgreementStateClient/RetrieveForApplicationTermsOfServiceAgreementState/main.go index 7ca93afe742f..c534360254f9 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/TermsOfServiceAgreementStateClient/RetrieveForApplicationTermsOfServiceAgreementState/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/TermsOfServiceAgreementStateClient/RetrieveForApplicationTermsOfServiceAgreementState/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/TermsOfServiceClient/AcceptTermsOfService/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/TermsOfServiceClient/AcceptTermsOfService/main.go index f3a6ad1dcae2..1a0a48b09ed1 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/TermsOfServiceClient/AcceptTermsOfService/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/TermsOfServiceClient/AcceptTermsOfService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/TermsOfServiceClient/GetTermsOfService/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/TermsOfServiceClient/GetTermsOfService/main.go index 8db535a66dfc..658ef5de30a7 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/TermsOfServiceClient/GetTermsOfService/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/TermsOfServiceClient/GetTermsOfService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/TermsOfServiceClient/RetrieveLatestTermsOfService/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/TermsOfServiceClient/RetrieveLatestTermsOfService/main.go index 1a4dd8e87c69..70aeb928f606 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/TermsOfServiceClient/RetrieveLatestTermsOfService/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/TermsOfServiceClient/RetrieveLatestTermsOfService/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/UserClient/CreateUser/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/UserClient/CreateUser/main.go index c971c9ffce3f..d47e6116e270 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/UserClient/CreateUser/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/UserClient/CreateUser/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/UserClient/DeleteUser/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/UserClient/DeleteUser/main.go index 6ad7de1c03c3..d7582eaa4b22 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/UserClient/DeleteUser/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/UserClient/DeleteUser/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/UserClient/GetUser/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/UserClient/GetUser/main.go index bf39609d248a..2a54ba74c0e6 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/UserClient/GetUser/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/UserClient/GetUser/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/UserClient/ListUsers/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/UserClient/ListUsers/main.go index 346f070a33e2..d7b327a05d86 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/UserClient/ListUsers/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/UserClient/ListUsers/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/UserClient/UpdateUser/main.go b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/UserClient/UpdateUser/main.go index d694d7d634e9..65ee9b30b6b2 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/UserClient/UpdateUser/main.go +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/UserClient/UpdateUser/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/snippet_metadata.google.shopping.merchant.accounts.v1beta.json b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/snippet_metadata.google.shopping.merchant.accounts.v1beta.json index bd4da6d17fa5..87f8cd8a311a 100644 --- a/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/snippet_metadata.google.shopping.merchant.accounts.v1beta.json +++ b/internal/generated/snippets/shopping/merchant/accounts/apiv1beta/snippet_metadata.google.shopping.merchant.accounts.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/shopping/merchant/accounts/apiv1beta", - "version": "0.14.0", + "version": "0.15.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/ConversionSourcesClient/CreateConversionSource/main.go b/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/ConversionSourcesClient/CreateConversionSource/main.go index 1f9680e32b3f..ad2cdd77999e 100644 --- a/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/ConversionSourcesClient/CreateConversionSource/main.go +++ b/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/ConversionSourcesClient/CreateConversionSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/ConversionSourcesClient/DeleteConversionSource/main.go b/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/ConversionSourcesClient/DeleteConversionSource/main.go index 1ce1fa317ee6..a75c6d1a4ccc 100644 --- a/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/ConversionSourcesClient/DeleteConversionSource/main.go +++ b/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/ConversionSourcesClient/DeleteConversionSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/ConversionSourcesClient/GetConversionSource/main.go b/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/ConversionSourcesClient/GetConversionSource/main.go index d63a4a6b0446..3961df27b79b 100644 --- a/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/ConversionSourcesClient/GetConversionSource/main.go +++ b/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/ConversionSourcesClient/GetConversionSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/ConversionSourcesClient/ListConversionSources/main.go b/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/ConversionSourcesClient/ListConversionSources/main.go index 17063fc3f3c5..a0a8f89cf89d 100644 --- a/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/ConversionSourcesClient/ListConversionSources/main.go +++ b/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/ConversionSourcesClient/ListConversionSources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/ConversionSourcesClient/UndeleteConversionSource/main.go b/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/ConversionSourcesClient/UndeleteConversionSource/main.go index f076e7a86da5..0b0ef7759f49 100644 --- a/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/ConversionSourcesClient/UndeleteConversionSource/main.go +++ b/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/ConversionSourcesClient/UndeleteConversionSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/ConversionSourcesClient/UpdateConversionSource/main.go b/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/ConversionSourcesClient/UpdateConversionSource/main.go index ca6c2c935c78..181f5915c47e 100644 --- a/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/ConversionSourcesClient/UpdateConversionSource/main.go +++ b/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/ConversionSourcesClient/UpdateConversionSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/snippet_metadata.google.shopping.merchant.conversions.v1beta.json b/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/snippet_metadata.google.shopping.merchant.conversions.v1beta.json index 4e9edbec6b28..651c74098294 100644 --- a/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/snippet_metadata.google.shopping.merchant.conversions.v1beta.json +++ b/internal/generated/snippets/shopping/merchant/conversions/apiv1beta/snippet_metadata.google.shopping.merchant.conversions.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/shopping/merchant/conversions/apiv1beta", - "version": "0.14.0", + "version": "0.15.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/Client/CreateDataSource/main.go b/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/Client/CreateDataSource/main.go index e54f9bf9376d..ded854cc4211 100644 --- a/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/Client/CreateDataSource/main.go +++ b/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/Client/CreateDataSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/Client/DeleteDataSource/main.go b/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/Client/DeleteDataSource/main.go index e17e04e9cf0b..9219e7b86809 100644 --- a/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/Client/DeleteDataSource/main.go +++ b/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/Client/DeleteDataSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/Client/FetchDataSource/main.go b/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/Client/FetchDataSource/main.go index 4fc9e1f10a71..bc58ddcc2e99 100644 --- a/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/Client/FetchDataSource/main.go +++ b/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/Client/FetchDataSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/Client/GetDataSource/main.go b/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/Client/GetDataSource/main.go index 8cd1b3dcfd64..7e37c9b4df0c 100644 --- a/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/Client/GetDataSource/main.go +++ b/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/Client/GetDataSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/Client/ListDataSources/main.go b/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/Client/ListDataSources/main.go index 5b5018f36a03..aeda2d025821 100644 --- a/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/Client/ListDataSources/main.go +++ b/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/Client/ListDataSources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/Client/UpdateDataSource/main.go b/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/Client/UpdateDataSource/main.go index ba758438f289..3c665ec27164 100644 --- a/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/Client/UpdateDataSource/main.go +++ b/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/Client/UpdateDataSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/FileUploadsClient/GetFileUpload/main.go b/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/FileUploadsClient/GetFileUpload/main.go index 694012720856..d0d2bbb564a4 100644 --- a/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/FileUploadsClient/GetFileUpload/main.go +++ b/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/FileUploadsClient/GetFileUpload/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/snippet_metadata.google.shopping.merchant.datasources.v1beta.json b/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/snippet_metadata.google.shopping.merchant.datasources.v1beta.json index 3b091c1b9f69..b67f841edd9a 100644 --- a/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/snippet_metadata.google.shopping.merchant.datasources.v1beta.json +++ b/internal/generated/snippets/shopping/merchant/datasources/apiv1beta/snippet_metadata.google.shopping.merchant.datasources.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/shopping/merchant/datasources/apiv1beta", - "version": "0.14.0", + "version": "0.15.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/LocalInventoryClient/DeleteLocalInventory/main.go b/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/LocalInventoryClient/DeleteLocalInventory/main.go index ba8664d67c25..467c83090704 100644 --- a/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/LocalInventoryClient/DeleteLocalInventory/main.go +++ b/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/LocalInventoryClient/DeleteLocalInventory/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/LocalInventoryClient/InsertLocalInventory/main.go b/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/LocalInventoryClient/InsertLocalInventory/main.go index ef676f1c9357..116bb496b436 100644 --- a/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/LocalInventoryClient/InsertLocalInventory/main.go +++ b/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/LocalInventoryClient/InsertLocalInventory/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/LocalInventoryClient/ListLocalInventories/main.go b/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/LocalInventoryClient/ListLocalInventories/main.go index 37bb805fa738..5aefc06d80de 100644 --- a/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/LocalInventoryClient/ListLocalInventories/main.go +++ b/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/LocalInventoryClient/ListLocalInventories/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/RegionalInventoryClient/DeleteRegionalInventory/main.go b/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/RegionalInventoryClient/DeleteRegionalInventory/main.go index 207549cf0bfd..7b19f1ae0425 100644 --- a/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/RegionalInventoryClient/DeleteRegionalInventory/main.go +++ b/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/RegionalInventoryClient/DeleteRegionalInventory/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/RegionalInventoryClient/InsertRegionalInventory/main.go b/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/RegionalInventoryClient/InsertRegionalInventory/main.go index f93ceb50d7e4..54853b05a010 100644 --- a/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/RegionalInventoryClient/InsertRegionalInventory/main.go +++ b/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/RegionalInventoryClient/InsertRegionalInventory/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/RegionalInventoryClient/ListRegionalInventories/main.go b/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/RegionalInventoryClient/ListRegionalInventories/main.go index ab90dde1f113..e3c0b0d45085 100644 --- a/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/RegionalInventoryClient/ListRegionalInventories/main.go +++ b/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/RegionalInventoryClient/ListRegionalInventories/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/snippet_metadata.google.shopping.merchant.inventories.v1beta.json b/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/snippet_metadata.google.shopping.merchant.inventories.v1beta.json index 10c2a54c3ebf..3b079ac16e14 100644 --- a/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/snippet_metadata.google.shopping.merchant.inventories.v1beta.json +++ b/internal/generated/snippets/shopping/merchant/inventories/apiv1beta/snippet_metadata.google.shopping.merchant.inventories.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/shopping/merchant/inventories/apiv1beta", - "version": "0.14.0", + "version": "0.15.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/LfpInventoryClient/InsertLfpInventory/main.go b/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/LfpInventoryClient/InsertLfpInventory/main.go index a62acb4ee55b..0598b4a93595 100644 --- a/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/LfpInventoryClient/InsertLfpInventory/main.go +++ b/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/LfpInventoryClient/InsertLfpInventory/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/LfpSaleClient/InsertLfpSale/main.go b/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/LfpSaleClient/InsertLfpSale/main.go index 7754ce2ba2b4..70944f7aeb87 100644 --- a/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/LfpSaleClient/InsertLfpSale/main.go +++ b/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/LfpSaleClient/InsertLfpSale/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/LfpStoreClient/DeleteLfpStore/main.go b/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/LfpStoreClient/DeleteLfpStore/main.go index baa8942717fa..f85da43b6bce 100644 --- a/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/LfpStoreClient/DeleteLfpStore/main.go +++ b/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/LfpStoreClient/DeleteLfpStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/LfpStoreClient/GetLfpStore/main.go b/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/LfpStoreClient/GetLfpStore/main.go index 6e8ce12840f6..33ee5127cba9 100644 --- a/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/LfpStoreClient/GetLfpStore/main.go +++ b/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/LfpStoreClient/GetLfpStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/LfpStoreClient/InsertLfpStore/main.go b/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/LfpStoreClient/InsertLfpStore/main.go index 6503b4eed0c3..d480834c49a1 100644 --- a/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/LfpStoreClient/InsertLfpStore/main.go +++ b/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/LfpStoreClient/InsertLfpStore/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/LfpStoreClient/ListLfpStores/main.go b/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/LfpStoreClient/ListLfpStores/main.go index 8044b969e7ca..3ca817bcee73 100644 --- a/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/LfpStoreClient/ListLfpStores/main.go +++ b/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/LfpStoreClient/ListLfpStores/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/snippet_metadata.google.shopping.merchant.lfp.v1beta.json b/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/snippet_metadata.google.shopping.merchant.lfp.v1beta.json index 7030d0730588..4bf078720068 100644 --- a/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/snippet_metadata.google.shopping.merchant.lfp.v1beta.json +++ b/internal/generated/snippets/shopping/merchant/lfp/apiv1beta/snippet_metadata.google.shopping.merchant.lfp.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/shopping/merchant/lfp/apiv1beta", - "version": "0.14.0", + "version": "0.15.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/shopping/merchant/notifications/apiv1beta/NotificationsApiClient/CreateNotificationSubscription/main.go b/internal/generated/snippets/shopping/merchant/notifications/apiv1beta/NotificationsApiClient/CreateNotificationSubscription/main.go index 62645b473f6e..15bb8c714b51 100644 --- a/internal/generated/snippets/shopping/merchant/notifications/apiv1beta/NotificationsApiClient/CreateNotificationSubscription/main.go +++ b/internal/generated/snippets/shopping/merchant/notifications/apiv1beta/NotificationsApiClient/CreateNotificationSubscription/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/notifications/apiv1beta/NotificationsApiClient/DeleteNotificationSubscription/main.go b/internal/generated/snippets/shopping/merchant/notifications/apiv1beta/NotificationsApiClient/DeleteNotificationSubscription/main.go index 6439e5f16884..1ae90900ca18 100644 --- a/internal/generated/snippets/shopping/merchant/notifications/apiv1beta/NotificationsApiClient/DeleteNotificationSubscription/main.go +++ b/internal/generated/snippets/shopping/merchant/notifications/apiv1beta/NotificationsApiClient/DeleteNotificationSubscription/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/notifications/apiv1beta/NotificationsApiClient/GetNotificationSubscription/main.go b/internal/generated/snippets/shopping/merchant/notifications/apiv1beta/NotificationsApiClient/GetNotificationSubscription/main.go index 49f3c6c76a28..41a21805dfc3 100644 --- a/internal/generated/snippets/shopping/merchant/notifications/apiv1beta/NotificationsApiClient/GetNotificationSubscription/main.go +++ b/internal/generated/snippets/shopping/merchant/notifications/apiv1beta/NotificationsApiClient/GetNotificationSubscription/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/notifications/apiv1beta/NotificationsApiClient/ListNotificationSubscriptions/main.go b/internal/generated/snippets/shopping/merchant/notifications/apiv1beta/NotificationsApiClient/ListNotificationSubscriptions/main.go index 51680832bac7..3a196223e4f3 100644 --- a/internal/generated/snippets/shopping/merchant/notifications/apiv1beta/NotificationsApiClient/ListNotificationSubscriptions/main.go +++ b/internal/generated/snippets/shopping/merchant/notifications/apiv1beta/NotificationsApiClient/ListNotificationSubscriptions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/notifications/apiv1beta/NotificationsApiClient/UpdateNotificationSubscription/main.go b/internal/generated/snippets/shopping/merchant/notifications/apiv1beta/NotificationsApiClient/UpdateNotificationSubscription/main.go index b8fd6c7d9ee9..526231f8447c 100644 --- a/internal/generated/snippets/shopping/merchant/notifications/apiv1beta/NotificationsApiClient/UpdateNotificationSubscription/main.go +++ b/internal/generated/snippets/shopping/merchant/notifications/apiv1beta/NotificationsApiClient/UpdateNotificationSubscription/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/notifications/apiv1beta/snippet_metadata.google.shopping.merchant.notifications.v1beta.json b/internal/generated/snippets/shopping/merchant/notifications/apiv1beta/snippet_metadata.google.shopping.merchant.notifications.v1beta.json index 753f0ba8b393..e63487ae1796 100644 --- a/internal/generated/snippets/shopping/merchant/notifications/apiv1beta/snippet_metadata.google.shopping.merchant.notifications.v1beta.json +++ b/internal/generated/snippets/shopping/merchant/notifications/apiv1beta/snippet_metadata.google.shopping.merchant.notifications.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/shopping/merchant/notifications/apiv1beta", - "version": "0.14.0", + "version": "0.15.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/shopping/merchant/products/apiv1beta/Client/GetProduct/main.go b/internal/generated/snippets/shopping/merchant/products/apiv1beta/Client/GetProduct/main.go index 38055a8ccfd7..7a3d6be4956c 100644 --- a/internal/generated/snippets/shopping/merchant/products/apiv1beta/Client/GetProduct/main.go +++ b/internal/generated/snippets/shopping/merchant/products/apiv1beta/Client/GetProduct/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/products/apiv1beta/Client/ListProducts/main.go b/internal/generated/snippets/shopping/merchant/products/apiv1beta/Client/ListProducts/main.go index 92b0a3232189..c9a7956ec060 100644 --- a/internal/generated/snippets/shopping/merchant/products/apiv1beta/Client/ListProducts/main.go +++ b/internal/generated/snippets/shopping/merchant/products/apiv1beta/Client/ListProducts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/products/apiv1beta/ProductInputsClient/DeleteProductInput/main.go b/internal/generated/snippets/shopping/merchant/products/apiv1beta/ProductInputsClient/DeleteProductInput/main.go index 59cf695886c8..203e6e9e1814 100644 --- a/internal/generated/snippets/shopping/merchant/products/apiv1beta/ProductInputsClient/DeleteProductInput/main.go +++ b/internal/generated/snippets/shopping/merchant/products/apiv1beta/ProductInputsClient/DeleteProductInput/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/products/apiv1beta/ProductInputsClient/InsertProductInput/main.go b/internal/generated/snippets/shopping/merchant/products/apiv1beta/ProductInputsClient/InsertProductInput/main.go index 04020a514281..adc06dd993df 100644 --- a/internal/generated/snippets/shopping/merchant/products/apiv1beta/ProductInputsClient/InsertProductInput/main.go +++ b/internal/generated/snippets/shopping/merchant/products/apiv1beta/ProductInputsClient/InsertProductInput/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/products/apiv1beta/snippet_metadata.google.shopping.merchant.products.v1beta.json b/internal/generated/snippets/shopping/merchant/products/apiv1beta/snippet_metadata.google.shopping.merchant.products.v1beta.json index f978446e03fc..db29f4600a58 100644 --- a/internal/generated/snippets/shopping/merchant/products/apiv1beta/snippet_metadata.google.shopping.merchant.products.v1beta.json +++ b/internal/generated/snippets/shopping/merchant/products/apiv1beta/snippet_metadata.google.shopping.merchant.products.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/shopping/merchant/products/apiv1beta", - "version": "0.14.0", + "version": "0.15.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/shopping/merchant/promotions/apiv1beta/Client/GetPromotion/main.go b/internal/generated/snippets/shopping/merchant/promotions/apiv1beta/Client/GetPromotion/main.go index 47dec18500d6..5eb043f79eb8 100644 --- a/internal/generated/snippets/shopping/merchant/promotions/apiv1beta/Client/GetPromotion/main.go +++ b/internal/generated/snippets/shopping/merchant/promotions/apiv1beta/Client/GetPromotion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/promotions/apiv1beta/Client/InsertPromotion/main.go b/internal/generated/snippets/shopping/merchant/promotions/apiv1beta/Client/InsertPromotion/main.go index b1ec9e058759..a59169b870f5 100644 --- a/internal/generated/snippets/shopping/merchant/promotions/apiv1beta/Client/InsertPromotion/main.go +++ b/internal/generated/snippets/shopping/merchant/promotions/apiv1beta/Client/InsertPromotion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/promotions/apiv1beta/Client/ListPromotions/main.go b/internal/generated/snippets/shopping/merchant/promotions/apiv1beta/Client/ListPromotions/main.go index d2e22b124db5..569257fcec48 100644 --- a/internal/generated/snippets/shopping/merchant/promotions/apiv1beta/Client/ListPromotions/main.go +++ b/internal/generated/snippets/shopping/merchant/promotions/apiv1beta/Client/ListPromotions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/promotions/apiv1beta/snippet_metadata.google.shopping.merchant.promotions.v1beta.json b/internal/generated/snippets/shopping/merchant/promotions/apiv1beta/snippet_metadata.google.shopping.merchant.promotions.v1beta.json index e5132b00e628..7b88a4fa0934 100644 --- a/internal/generated/snippets/shopping/merchant/promotions/apiv1beta/snippet_metadata.google.shopping.merchant.promotions.v1beta.json +++ b/internal/generated/snippets/shopping/merchant/promotions/apiv1beta/snippet_metadata.google.shopping.merchant.promotions.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/shopping/merchant/promotions/apiv1beta", - "version": "0.14.0", + "version": "0.15.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/shopping/merchant/quota/apiv1beta/Client/ListQuotaGroups/main.go b/internal/generated/snippets/shopping/merchant/quota/apiv1beta/Client/ListQuotaGroups/main.go index eec6ed52eec6..65465a4c440e 100644 --- a/internal/generated/snippets/shopping/merchant/quota/apiv1beta/Client/ListQuotaGroups/main.go +++ b/internal/generated/snippets/shopping/merchant/quota/apiv1beta/Client/ListQuotaGroups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/quota/apiv1beta/snippet_metadata.google.shopping.merchant.quota.v1beta.json b/internal/generated/snippets/shopping/merchant/quota/apiv1beta/snippet_metadata.google.shopping.merchant.quota.v1beta.json index dbdaa55831bb..8ef96f886052 100644 --- a/internal/generated/snippets/shopping/merchant/quota/apiv1beta/snippet_metadata.google.shopping.merchant.quota.v1beta.json +++ b/internal/generated/snippets/shopping/merchant/quota/apiv1beta/snippet_metadata.google.shopping.merchant.quota.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/shopping/merchant/quota/apiv1beta", - "version": "0.14.0", + "version": "0.15.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/shopping/merchant/reports/apiv1beta/ReportClient/Search/main.go b/internal/generated/snippets/shopping/merchant/reports/apiv1beta/ReportClient/Search/main.go index 48d6d09adb57..45cfcd05e91a 100644 --- a/internal/generated/snippets/shopping/merchant/reports/apiv1beta/ReportClient/Search/main.go +++ b/internal/generated/snippets/shopping/merchant/reports/apiv1beta/ReportClient/Search/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/reports/apiv1beta/snippet_metadata.google.shopping.merchant.reports.v1beta.json b/internal/generated/snippets/shopping/merchant/reports/apiv1beta/snippet_metadata.google.shopping.merchant.reports.v1beta.json index ba803529fec3..23e36f913e2c 100644 --- a/internal/generated/snippets/shopping/merchant/reports/apiv1beta/snippet_metadata.google.shopping.merchant.reports.v1beta.json +++ b/internal/generated/snippets/shopping/merchant/reports/apiv1beta/snippet_metadata.google.shopping.merchant.reports.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/shopping/merchant/reports/apiv1beta", - "version": "0.14.0", + "version": "0.15.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/MerchantReviewsClient/DeleteMerchantReview/main.go b/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/MerchantReviewsClient/DeleteMerchantReview/main.go index 40eaa7ae742e..70070adc8469 100644 --- a/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/MerchantReviewsClient/DeleteMerchantReview/main.go +++ b/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/MerchantReviewsClient/DeleteMerchantReview/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/MerchantReviewsClient/GetMerchantReview/main.go b/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/MerchantReviewsClient/GetMerchantReview/main.go index 9d5bef6d75cc..a4eca38f8cec 100644 --- a/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/MerchantReviewsClient/GetMerchantReview/main.go +++ b/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/MerchantReviewsClient/GetMerchantReview/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/MerchantReviewsClient/InsertMerchantReview/main.go b/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/MerchantReviewsClient/InsertMerchantReview/main.go index e37d82a6e5c7..66403248f7c8 100644 --- a/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/MerchantReviewsClient/InsertMerchantReview/main.go +++ b/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/MerchantReviewsClient/InsertMerchantReview/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/MerchantReviewsClient/ListMerchantReviews/main.go b/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/MerchantReviewsClient/ListMerchantReviews/main.go index fb4a58d995c4..4e27b6d58a5a 100644 --- a/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/MerchantReviewsClient/ListMerchantReviews/main.go +++ b/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/MerchantReviewsClient/ListMerchantReviews/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/ProductReviewsClient/DeleteProductReview/main.go b/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/ProductReviewsClient/DeleteProductReview/main.go index d74b28178eca..d9afd5b928a2 100644 --- a/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/ProductReviewsClient/DeleteProductReview/main.go +++ b/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/ProductReviewsClient/DeleteProductReview/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/ProductReviewsClient/GetProductReview/main.go b/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/ProductReviewsClient/GetProductReview/main.go index 70d284201acb..cb53c4b99897 100644 --- a/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/ProductReviewsClient/GetProductReview/main.go +++ b/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/ProductReviewsClient/GetProductReview/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/ProductReviewsClient/InsertProductReview/main.go b/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/ProductReviewsClient/InsertProductReview/main.go index 6baaab5f6fdb..17d8699b6d4a 100644 --- a/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/ProductReviewsClient/InsertProductReview/main.go +++ b/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/ProductReviewsClient/InsertProductReview/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/ProductReviewsClient/ListProductReviews/main.go b/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/ProductReviewsClient/ListProductReviews/main.go index 58509e24e31b..d88d6b1de20f 100644 --- a/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/ProductReviewsClient/ListProductReviews/main.go +++ b/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/ProductReviewsClient/ListProductReviews/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/snippet_metadata.google.shopping.merchant.reviews.v1beta.json b/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/snippet_metadata.google.shopping.merchant.reviews.v1beta.json index 0e5fdb20bfab..c39fa37a003e 100644 --- a/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/snippet_metadata.google.shopping.merchant.reviews.v1beta.json +++ b/internal/generated/snippets/shopping/merchant/reviews/apiv1beta/snippet_metadata.google.shopping.merchant.reviews.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/shopping/merchant/reviews/apiv1beta", - "version": "0.14.0", + "version": "0.15.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/CancelOperation/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/CancelOperation/main.go index 481ee7333161..fc2595e47b14 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/CancelOperation/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/CopyBackup/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/CopyBackup/main.go index a5571762a348..338195d0f1dc 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/CopyBackup/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/CopyBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/CreateBackup/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/CreateBackup/main.go index e693d52b869a..a6c1a08099a0 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/CreateBackup/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/CreateBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/CreateBackupSchedule/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/CreateBackupSchedule/main.go index 3f4a19ddd437..31f23c274db4 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/CreateBackupSchedule/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/CreateBackupSchedule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/CreateDatabase/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/CreateDatabase/main.go index f9ddee0b4358..d0733ed180c0 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/CreateDatabase/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/CreateDatabase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/DeleteBackup/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/DeleteBackup/main.go index c85460624c41..e79508dd723e 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/DeleteBackup/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/DeleteBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/DeleteBackupSchedule/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/DeleteBackupSchedule/main.go index ce0d85bbb88f..fca81d8d73e1 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/DeleteBackupSchedule/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/DeleteBackupSchedule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/DeleteOperation/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/DeleteOperation/main.go index d4b701ffd562..5aa28758eaf2 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/DeleteOperation/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/DropDatabase/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/DropDatabase/main.go index c788b0530aa9..a2fd7c21fbcb 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/DropDatabase/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/DropDatabase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/GetBackup/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/GetBackup/main.go index a3c2e73113a7..2f9b9c13e906 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/GetBackup/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/GetBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/GetBackupSchedule/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/GetBackupSchedule/main.go index 581b8e5a2be7..1303c3caf297 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/GetBackupSchedule/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/GetBackupSchedule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/GetDatabase/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/GetDatabase/main.go index ae913671b2da..1bfb6afd6b5a 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/GetDatabase/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/GetDatabase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/GetDatabaseDdl/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/GetDatabaseDdl/main.go index bc7fc0379d5f..65a3298e70ae 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/GetDatabaseDdl/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/GetDatabaseDdl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/GetIamPolicy/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/GetIamPolicy/main.go index a6a4b3bb0970..9d4ae140b23f 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/GetOperation/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/GetOperation/main.go index 4ec6f611baa9..ac276973af9c 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/GetOperation/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/ListBackupOperations/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/ListBackupOperations/main.go index ec32a20cff93..1854c1efe5c8 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/ListBackupOperations/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/ListBackupOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/ListBackupSchedules/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/ListBackupSchedules/main.go index 277712d5707b..d366a6899e04 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/ListBackupSchedules/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/ListBackupSchedules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/ListBackups/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/ListBackups/main.go index 88ff618cfded..b29f5401e265 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/ListBackups/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/ListBackups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/ListDatabaseOperations/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/ListDatabaseOperations/main.go index ae0319f45f18..f47b6dda9033 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/ListDatabaseOperations/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/ListDatabaseOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/ListDatabaseRoles/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/ListDatabaseRoles/main.go index a4cb460887ac..2d4f95d6a1c7 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/ListDatabaseRoles/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/ListDatabaseRoles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/ListDatabases/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/ListDatabases/main.go index df608ac7e79b..b9eaddc30edd 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/ListDatabases/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/ListDatabases/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/ListOperations/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/ListOperations/main.go index 9da09c4c31aa..f5ad18712806 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/ListOperations/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/RestoreDatabase/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/RestoreDatabase/main.go index 5341404c1709..8ac28d0e33cc 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/RestoreDatabase/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/RestoreDatabase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/SetIamPolicy/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/SetIamPolicy/main.go index 2b9faf396040..791204608bea 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/TestIamPermissions/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/TestIamPermissions/main.go index cc6a868ac723..64a57671fb39 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/UpdateBackup/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/UpdateBackup/main.go index 84ae864a39ef..e9363372ca73 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/UpdateBackup/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/UpdateBackup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/UpdateBackupSchedule/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/UpdateBackupSchedule/main.go index 98569bb9ca7b..01d6b798cb8d 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/UpdateBackupSchedule/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/UpdateBackupSchedule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/UpdateDatabase/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/UpdateDatabase/main.go index a9041657688a..46fc2fe046a6 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/UpdateDatabase/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/UpdateDatabase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/UpdateDatabaseDdl/main.go b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/UpdateDatabaseDdl/main.go index 3794537ec3ef..12b2084b1e2d 100644 --- a/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/UpdateDatabaseDdl/main.go +++ b/internal/generated/snippets/spanner/admin/database/apiv1/DatabaseAdminClient/UpdateDatabaseDdl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/CreateInstance/main.go b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/CreateInstance/main.go index 40984e10ae17..2d86fc5e4cea 100644 --- a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/CreateInstance/main.go +++ b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/CreateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/CreateInstanceConfig/main.go b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/CreateInstanceConfig/main.go index caeaf1066a30..486a07896546 100644 --- a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/CreateInstanceConfig/main.go +++ b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/CreateInstanceConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/CreateInstancePartition/main.go b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/CreateInstancePartition/main.go index ea72ae5ce8fb..755bb6efc442 100644 --- a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/CreateInstancePartition/main.go +++ b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/CreateInstancePartition/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/DeleteInstance/main.go b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/DeleteInstance/main.go index 3dce547b365d..a23c996f00c1 100644 --- a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/DeleteInstance/main.go +++ b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/DeleteInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/DeleteInstanceConfig/main.go b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/DeleteInstanceConfig/main.go index be797c2fcae1..44e0f45cc7b9 100644 --- a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/DeleteInstanceConfig/main.go +++ b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/DeleteInstanceConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/DeleteInstancePartition/main.go b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/DeleteInstancePartition/main.go index de40878a034d..07a611d64e87 100644 --- a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/DeleteInstancePartition/main.go +++ b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/DeleteInstancePartition/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/GetIamPolicy/main.go b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/GetIamPolicy/main.go index 0a975292510c..3a55b7c54013 100644 --- a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/GetIamPolicy/main.go +++ b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/GetInstance/main.go b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/GetInstance/main.go index 3ccf5c11fd0a..a937232f5337 100644 --- a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/GetInstance/main.go +++ b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/GetInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/GetInstanceConfig/main.go b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/GetInstanceConfig/main.go index af63945722d1..071d3eb9e556 100644 --- a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/GetInstanceConfig/main.go +++ b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/GetInstanceConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/GetInstancePartition/main.go b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/GetInstancePartition/main.go index 7611db2d0604..c7dcac13f4d7 100644 --- a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/GetInstancePartition/main.go +++ b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/GetInstancePartition/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/ListInstanceConfigOperations/main.go b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/ListInstanceConfigOperations/main.go index 36e4e61d4979..6f3ab87efada 100644 --- a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/ListInstanceConfigOperations/main.go +++ b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/ListInstanceConfigOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/ListInstanceConfigs/main.go b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/ListInstanceConfigs/main.go index 6120de14f422..e02248bd157b 100644 --- a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/ListInstanceConfigs/main.go +++ b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/ListInstanceConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/ListInstancePartitionOperations/main.go b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/ListInstancePartitionOperations/main.go index fee27550bf0d..40621bc515e8 100644 --- a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/ListInstancePartitionOperations/main.go +++ b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/ListInstancePartitionOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/ListInstancePartitions/main.go b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/ListInstancePartitions/main.go index 62beda10c58a..d282e7eb7ecb 100644 --- a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/ListInstancePartitions/main.go +++ b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/ListInstancePartitions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/ListInstances/main.go b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/ListInstances/main.go index 17f69b73e825..f8de6684d9d7 100644 --- a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/ListInstances/main.go +++ b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/ListInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/MoveInstance/main.go b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/MoveInstance/main.go index c8c9faeaf46d..bf5d53260737 100644 --- a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/MoveInstance/main.go +++ b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/MoveInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/SetIamPolicy/main.go b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/SetIamPolicy/main.go index 33d2e7315fef..68160b26ad9a 100644 --- a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/SetIamPolicy/main.go +++ b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/TestIamPermissions/main.go b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/TestIamPermissions/main.go index 6e6443b05449..b5b652c73016 100644 --- a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/TestIamPermissions/main.go +++ b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/UpdateInstance/main.go b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/UpdateInstance/main.go index 3b9b3c6fad39..2d371d0bb6fc 100644 --- a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/UpdateInstance/main.go +++ b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/UpdateInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/UpdateInstanceConfig/main.go b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/UpdateInstanceConfig/main.go index dd02e553bd46..4619aba75e46 100644 --- a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/UpdateInstanceConfig/main.go +++ b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/UpdateInstanceConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/UpdateInstancePartition/main.go b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/UpdateInstancePartition/main.go index a95108d6a432..1c812bfb400c 100644 --- a/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/UpdateInstancePartition/main.go +++ b/internal/generated/snippets/spanner/admin/instance/apiv1/InstanceAdminClient/UpdateInstancePartition/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/apiv1/Client/BatchCreateSessions/main.go b/internal/generated/snippets/spanner/apiv1/Client/BatchCreateSessions/main.go index d6430b95b346..100b50ddd717 100644 --- a/internal/generated/snippets/spanner/apiv1/Client/BatchCreateSessions/main.go +++ b/internal/generated/snippets/spanner/apiv1/Client/BatchCreateSessions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/apiv1/Client/BeginTransaction/main.go b/internal/generated/snippets/spanner/apiv1/Client/BeginTransaction/main.go index 780818d2b6dd..df67dfd0a65f 100644 --- a/internal/generated/snippets/spanner/apiv1/Client/BeginTransaction/main.go +++ b/internal/generated/snippets/spanner/apiv1/Client/BeginTransaction/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/apiv1/Client/Commit/main.go b/internal/generated/snippets/spanner/apiv1/Client/Commit/main.go index 5cbada238ee7..3031bbd1c185 100644 --- a/internal/generated/snippets/spanner/apiv1/Client/Commit/main.go +++ b/internal/generated/snippets/spanner/apiv1/Client/Commit/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/apiv1/Client/CreateSession/main.go b/internal/generated/snippets/spanner/apiv1/Client/CreateSession/main.go index 4856d70a1a89..7b707a89b1fb 100644 --- a/internal/generated/snippets/spanner/apiv1/Client/CreateSession/main.go +++ b/internal/generated/snippets/spanner/apiv1/Client/CreateSession/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/apiv1/Client/DeleteSession/main.go b/internal/generated/snippets/spanner/apiv1/Client/DeleteSession/main.go index 057141d7a983..73ea0a60ab7b 100644 --- a/internal/generated/snippets/spanner/apiv1/Client/DeleteSession/main.go +++ b/internal/generated/snippets/spanner/apiv1/Client/DeleteSession/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/apiv1/Client/ExecuteBatchDml/main.go b/internal/generated/snippets/spanner/apiv1/Client/ExecuteBatchDml/main.go index 60c18b21673f..bb54728ada66 100644 --- a/internal/generated/snippets/spanner/apiv1/Client/ExecuteBatchDml/main.go +++ b/internal/generated/snippets/spanner/apiv1/Client/ExecuteBatchDml/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/apiv1/Client/ExecuteSql/main.go b/internal/generated/snippets/spanner/apiv1/Client/ExecuteSql/main.go index ba933c0ac3b5..268ebc68a3ba 100644 --- a/internal/generated/snippets/spanner/apiv1/Client/ExecuteSql/main.go +++ b/internal/generated/snippets/spanner/apiv1/Client/ExecuteSql/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/apiv1/Client/GetSession/main.go b/internal/generated/snippets/spanner/apiv1/Client/GetSession/main.go index 90a08a57c89b..5dfaab7c5239 100644 --- a/internal/generated/snippets/spanner/apiv1/Client/GetSession/main.go +++ b/internal/generated/snippets/spanner/apiv1/Client/GetSession/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/apiv1/Client/ListSessions/main.go b/internal/generated/snippets/spanner/apiv1/Client/ListSessions/main.go index 25f64d6ece26..f823d5e9f2a6 100644 --- a/internal/generated/snippets/spanner/apiv1/Client/ListSessions/main.go +++ b/internal/generated/snippets/spanner/apiv1/Client/ListSessions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/apiv1/Client/PartitionQuery/main.go b/internal/generated/snippets/spanner/apiv1/Client/PartitionQuery/main.go index f07502871f05..780f4b5181d7 100644 --- a/internal/generated/snippets/spanner/apiv1/Client/PartitionQuery/main.go +++ b/internal/generated/snippets/spanner/apiv1/Client/PartitionQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/apiv1/Client/PartitionRead/main.go b/internal/generated/snippets/spanner/apiv1/Client/PartitionRead/main.go index 2cc053039e81..320f7b64708e 100644 --- a/internal/generated/snippets/spanner/apiv1/Client/PartitionRead/main.go +++ b/internal/generated/snippets/spanner/apiv1/Client/PartitionRead/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/apiv1/Client/Read/main.go b/internal/generated/snippets/spanner/apiv1/Client/Read/main.go index f36ef9e9bcd4..ab3477ba2294 100644 --- a/internal/generated/snippets/spanner/apiv1/Client/Read/main.go +++ b/internal/generated/snippets/spanner/apiv1/Client/Read/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/apiv1/Client/Rollback/main.go b/internal/generated/snippets/spanner/apiv1/Client/Rollback/main.go index 2c2a12efc8e5..49d780571c00 100644 --- a/internal/generated/snippets/spanner/apiv1/Client/Rollback/main.go +++ b/internal/generated/snippets/spanner/apiv1/Client/Rollback/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/spanner/executor/apiv1/SpannerExecutorProxyClient/ExecuteActionAsync/main.go b/internal/generated/snippets/spanner/executor/apiv1/SpannerExecutorProxyClient/ExecuteActionAsync/main.go index 77e7102f2837..f347e50e72b2 100644 --- a/internal/generated/snippets/spanner/executor/apiv1/SpannerExecutorProxyClient/ExecuteActionAsync/main.go +++ b/internal/generated/snippets/spanner/executor/apiv1/SpannerExecutorProxyClient/ExecuteActionAsync/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1/AdaptationClient/CreateCustomClass/main.go b/internal/generated/snippets/speech/apiv1/AdaptationClient/CreateCustomClass/main.go index 252579f04004..df7be3b5e480 100644 --- a/internal/generated/snippets/speech/apiv1/AdaptationClient/CreateCustomClass/main.go +++ b/internal/generated/snippets/speech/apiv1/AdaptationClient/CreateCustomClass/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1/AdaptationClient/CreatePhraseSet/main.go b/internal/generated/snippets/speech/apiv1/AdaptationClient/CreatePhraseSet/main.go index f6b2a9343bfb..584e91433588 100644 --- a/internal/generated/snippets/speech/apiv1/AdaptationClient/CreatePhraseSet/main.go +++ b/internal/generated/snippets/speech/apiv1/AdaptationClient/CreatePhraseSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1/AdaptationClient/DeleteCustomClass/main.go b/internal/generated/snippets/speech/apiv1/AdaptationClient/DeleteCustomClass/main.go index 2d1c53c043d1..2835b8a469cf 100644 --- a/internal/generated/snippets/speech/apiv1/AdaptationClient/DeleteCustomClass/main.go +++ b/internal/generated/snippets/speech/apiv1/AdaptationClient/DeleteCustomClass/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1/AdaptationClient/DeletePhraseSet/main.go b/internal/generated/snippets/speech/apiv1/AdaptationClient/DeletePhraseSet/main.go index 2fa86175f3f4..f4ac54e98c9a 100644 --- a/internal/generated/snippets/speech/apiv1/AdaptationClient/DeletePhraseSet/main.go +++ b/internal/generated/snippets/speech/apiv1/AdaptationClient/DeletePhraseSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1/AdaptationClient/GetCustomClass/main.go b/internal/generated/snippets/speech/apiv1/AdaptationClient/GetCustomClass/main.go index 58ea62bba940..9a70fb586795 100644 --- a/internal/generated/snippets/speech/apiv1/AdaptationClient/GetCustomClass/main.go +++ b/internal/generated/snippets/speech/apiv1/AdaptationClient/GetCustomClass/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1/AdaptationClient/GetOperation/main.go b/internal/generated/snippets/speech/apiv1/AdaptationClient/GetOperation/main.go index aa2c682fdcf7..cf37a6f9addf 100644 --- a/internal/generated/snippets/speech/apiv1/AdaptationClient/GetOperation/main.go +++ b/internal/generated/snippets/speech/apiv1/AdaptationClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1/AdaptationClient/GetPhraseSet/main.go b/internal/generated/snippets/speech/apiv1/AdaptationClient/GetPhraseSet/main.go index a9d29e9aa162..42ed052d9882 100644 --- a/internal/generated/snippets/speech/apiv1/AdaptationClient/GetPhraseSet/main.go +++ b/internal/generated/snippets/speech/apiv1/AdaptationClient/GetPhraseSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1/AdaptationClient/ListCustomClasses/main.go b/internal/generated/snippets/speech/apiv1/AdaptationClient/ListCustomClasses/main.go index 37eda5ace8ca..90dc21408338 100644 --- a/internal/generated/snippets/speech/apiv1/AdaptationClient/ListCustomClasses/main.go +++ b/internal/generated/snippets/speech/apiv1/AdaptationClient/ListCustomClasses/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1/AdaptationClient/ListOperations/main.go b/internal/generated/snippets/speech/apiv1/AdaptationClient/ListOperations/main.go index 5b03781b3040..8302f4620f99 100644 --- a/internal/generated/snippets/speech/apiv1/AdaptationClient/ListOperations/main.go +++ b/internal/generated/snippets/speech/apiv1/AdaptationClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1/AdaptationClient/ListPhraseSet/main.go b/internal/generated/snippets/speech/apiv1/AdaptationClient/ListPhraseSet/main.go index cad6124971c8..d59899862329 100644 --- a/internal/generated/snippets/speech/apiv1/AdaptationClient/ListPhraseSet/main.go +++ b/internal/generated/snippets/speech/apiv1/AdaptationClient/ListPhraseSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1/AdaptationClient/UpdateCustomClass/main.go b/internal/generated/snippets/speech/apiv1/AdaptationClient/UpdateCustomClass/main.go index e5f0cad20557..0afeb1081165 100644 --- a/internal/generated/snippets/speech/apiv1/AdaptationClient/UpdateCustomClass/main.go +++ b/internal/generated/snippets/speech/apiv1/AdaptationClient/UpdateCustomClass/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1/AdaptationClient/UpdatePhraseSet/main.go b/internal/generated/snippets/speech/apiv1/AdaptationClient/UpdatePhraseSet/main.go index 7ae70d421500..d28ac238cffb 100644 --- a/internal/generated/snippets/speech/apiv1/AdaptationClient/UpdatePhraseSet/main.go +++ b/internal/generated/snippets/speech/apiv1/AdaptationClient/UpdatePhraseSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/speech/apiv1/Client/GetOperation/main.go index ff4d4c0ea1c9..a9124fd90145 100644 --- a/internal/generated/snippets/speech/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/speech/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/speech/apiv1/Client/ListOperations/main.go index d8c9bf0da70e..494b47e2fbb1 100644 --- a/internal/generated/snippets/speech/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/speech/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1/Client/LongRunningRecognize/main.go b/internal/generated/snippets/speech/apiv1/Client/LongRunningRecognize/main.go index dbb64bf47713..4d0a5089996f 100644 --- a/internal/generated/snippets/speech/apiv1/Client/LongRunningRecognize/main.go +++ b/internal/generated/snippets/speech/apiv1/Client/LongRunningRecognize/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1/Client/Recognize/main.go b/internal/generated/snippets/speech/apiv1/Client/Recognize/main.go index 80540ff50473..80b2545b4983 100644 --- a/internal/generated/snippets/speech/apiv1/Client/Recognize/main.go +++ b/internal/generated/snippets/speech/apiv1/Client/Recognize/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1/Client/StreamingRecognize/main.go b/internal/generated/snippets/speech/apiv1/Client/StreamingRecognize/main.go index ad21d197fa76..4b0ae261f020 100644 --- a/internal/generated/snippets/speech/apiv1/Client/StreamingRecognize/main.go +++ b/internal/generated/snippets/speech/apiv1/Client/StreamingRecognize/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1/snippet_metadata.google.cloud.speech.v1.json b/internal/generated/snippets/speech/apiv1/snippet_metadata.google.cloud.speech.v1.json index d9100381ef73..ad416c24ef7e 100644 --- a/internal/generated/snippets/speech/apiv1/snippet_metadata.google.cloud.speech.v1.json +++ b/internal/generated/snippets/speech/apiv1/snippet_metadata.google.cloud.speech.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/speech/apiv1", - "version": "1.25.2", + "version": "1.26.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/CreateCustomClass/main.go b/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/CreateCustomClass/main.go index 2f89fd3914d6..64c9939faede 100644 --- a/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/CreateCustomClass/main.go +++ b/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/CreateCustomClass/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/CreatePhraseSet/main.go b/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/CreatePhraseSet/main.go index 8efa80ef9c27..cd2bc8426a6e 100644 --- a/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/CreatePhraseSet/main.go +++ b/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/CreatePhraseSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/DeleteCustomClass/main.go b/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/DeleteCustomClass/main.go index f489d8d617b8..54cb403aeb9a 100644 --- a/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/DeleteCustomClass/main.go +++ b/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/DeleteCustomClass/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/DeletePhraseSet/main.go b/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/DeletePhraseSet/main.go index 5cd68ecd00ee..ff90a7a0a887 100644 --- a/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/DeletePhraseSet/main.go +++ b/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/DeletePhraseSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/GetCustomClass/main.go b/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/GetCustomClass/main.go index a70693352214..0ec8595c5562 100644 --- a/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/GetCustomClass/main.go +++ b/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/GetCustomClass/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/GetOperation/main.go b/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/GetOperation/main.go index 484e0e7118bc..4f794d05947f 100644 --- a/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/GetOperation/main.go +++ b/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/GetPhraseSet/main.go b/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/GetPhraseSet/main.go index df4519ec844f..145843544eee 100644 --- a/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/GetPhraseSet/main.go +++ b/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/GetPhraseSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/ListCustomClasses/main.go b/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/ListCustomClasses/main.go index 94516f371995..a4482c8ab7c9 100644 --- a/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/ListCustomClasses/main.go +++ b/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/ListCustomClasses/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/ListOperations/main.go b/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/ListOperations/main.go index 4d454076274b..6a84a387b714 100644 --- a/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/ListOperations/main.go +++ b/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/ListPhraseSet/main.go b/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/ListPhraseSet/main.go index de284d1f2105..49ee872a5d28 100644 --- a/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/ListPhraseSet/main.go +++ b/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/ListPhraseSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/UpdateCustomClass/main.go b/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/UpdateCustomClass/main.go index 5162ce7d0e44..d221900a4ba0 100644 --- a/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/UpdateCustomClass/main.go +++ b/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/UpdateCustomClass/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/UpdatePhraseSet/main.go b/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/UpdatePhraseSet/main.go index e92c72b4af44..86ceed8069b0 100644 --- a/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/UpdatePhraseSet/main.go +++ b/internal/generated/snippets/speech/apiv1p1beta1/AdaptationClient/UpdatePhraseSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1p1beta1/Client/GetOperation/main.go b/internal/generated/snippets/speech/apiv1p1beta1/Client/GetOperation/main.go index 98a9e9bcde66..270762bdb08d 100644 --- a/internal/generated/snippets/speech/apiv1p1beta1/Client/GetOperation/main.go +++ b/internal/generated/snippets/speech/apiv1p1beta1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1p1beta1/Client/ListOperations/main.go b/internal/generated/snippets/speech/apiv1p1beta1/Client/ListOperations/main.go index 2f8485e05e33..e9ac84607c3e 100644 --- a/internal/generated/snippets/speech/apiv1p1beta1/Client/ListOperations/main.go +++ b/internal/generated/snippets/speech/apiv1p1beta1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1p1beta1/Client/LongRunningRecognize/main.go b/internal/generated/snippets/speech/apiv1p1beta1/Client/LongRunningRecognize/main.go index 88bb5c769b77..95797d379f92 100644 --- a/internal/generated/snippets/speech/apiv1p1beta1/Client/LongRunningRecognize/main.go +++ b/internal/generated/snippets/speech/apiv1p1beta1/Client/LongRunningRecognize/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1p1beta1/Client/Recognize/main.go b/internal/generated/snippets/speech/apiv1p1beta1/Client/Recognize/main.go index aab6fff2d7e9..73527bdd7020 100644 --- a/internal/generated/snippets/speech/apiv1p1beta1/Client/Recognize/main.go +++ b/internal/generated/snippets/speech/apiv1p1beta1/Client/Recognize/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1p1beta1/Client/StreamingRecognize/main.go b/internal/generated/snippets/speech/apiv1p1beta1/Client/StreamingRecognize/main.go index c6359d933d57..c3adae3334d8 100644 --- a/internal/generated/snippets/speech/apiv1p1beta1/Client/StreamingRecognize/main.go +++ b/internal/generated/snippets/speech/apiv1p1beta1/Client/StreamingRecognize/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv1p1beta1/snippet_metadata.google.cloud.speech.v1p1beta1.json b/internal/generated/snippets/speech/apiv1p1beta1/snippet_metadata.google.cloud.speech.v1p1beta1.json index 6d328c51e691..c82002406929 100644 --- a/internal/generated/snippets/speech/apiv1p1beta1/snippet_metadata.google.cloud.speech.v1p1beta1.json +++ b/internal/generated/snippets/speech/apiv1p1beta1/snippet_metadata.google.cloud.speech.v1p1beta1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/speech/apiv1p1beta1", - "version": "1.25.2", + "version": "1.26.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/speech/apiv2/Client/BatchRecognize/main.go b/internal/generated/snippets/speech/apiv2/Client/BatchRecognize/main.go index 5838fd8780eb..bd84dea1315e 100644 --- a/internal/generated/snippets/speech/apiv2/Client/BatchRecognize/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/BatchRecognize/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/Client/CancelOperation/main.go b/internal/generated/snippets/speech/apiv2/Client/CancelOperation/main.go index 1f464503fc85..7a938a724375 100644 --- a/internal/generated/snippets/speech/apiv2/Client/CancelOperation/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/Client/CreateCustomClass/main.go b/internal/generated/snippets/speech/apiv2/Client/CreateCustomClass/main.go index 565a1678cf7d..61f4d415acac 100644 --- a/internal/generated/snippets/speech/apiv2/Client/CreateCustomClass/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/CreateCustomClass/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/Client/CreatePhraseSet/main.go b/internal/generated/snippets/speech/apiv2/Client/CreatePhraseSet/main.go index 062362e2925a..f61ff54a92bb 100644 --- a/internal/generated/snippets/speech/apiv2/Client/CreatePhraseSet/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/CreatePhraseSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/Client/CreateRecognizer/main.go b/internal/generated/snippets/speech/apiv2/Client/CreateRecognizer/main.go index 6d9851859e5b..e73447325da6 100644 --- a/internal/generated/snippets/speech/apiv2/Client/CreateRecognizer/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/CreateRecognizer/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/Client/DeleteCustomClass/main.go b/internal/generated/snippets/speech/apiv2/Client/DeleteCustomClass/main.go index d837322e17fe..eda9905c15e1 100644 --- a/internal/generated/snippets/speech/apiv2/Client/DeleteCustomClass/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/DeleteCustomClass/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/Client/DeleteOperation/main.go b/internal/generated/snippets/speech/apiv2/Client/DeleteOperation/main.go index f2946c8c23e7..1c4e08941c00 100644 --- a/internal/generated/snippets/speech/apiv2/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/Client/DeletePhraseSet/main.go b/internal/generated/snippets/speech/apiv2/Client/DeletePhraseSet/main.go index ea82534f9d09..075efadbfeda 100644 --- a/internal/generated/snippets/speech/apiv2/Client/DeletePhraseSet/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/DeletePhraseSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/Client/DeleteRecognizer/main.go b/internal/generated/snippets/speech/apiv2/Client/DeleteRecognizer/main.go index 59fe1aaf4db1..cde299c07208 100644 --- a/internal/generated/snippets/speech/apiv2/Client/DeleteRecognizer/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/DeleteRecognizer/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/Client/GetConfig/main.go b/internal/generated/snippets/speech/apiv2/Client/GetConfig/main.go index 5ecc61cee969..c86f2adefd21 100644 --- a/internal/generated/snippets/speech/apiv2/Client/GetConfig/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/GetConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/Client/GetCustomClass/main.go b/internal/generated/snippets/speech/apiv2/Client/GetCustomClass/main.go index 5437c383ca43..141e65e3aee7 100644 --- a/internal/generated/snippets/speech/apiv2/Client/GetCustomClass/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/GetCustomClass/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/Client/GetLocation/main.go b/internal/generated/snippets/speech/apiv2/Client/GetLocation/main.go index a8d24cdece1c..4f8354710727 100644 --- a/internal/generated/snippets/speech/apiv2/Client/GetLocation/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/Client/GetOperation/main.go b/internal/generated/snippets/speech/apiv2/Client/GetOperation/main.go index 59d5b1d21eb4..f0a8ec1bd830 100644 --- a/internal/generated/snippets/speech/apiv2/Client/GetOperation/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/Client/GetPhraseSet/main.go b/internal/generated/snippets/speech/apiv2/Client/GetPhraseSet/main.go index 31f8781252b4..5b3196deeac8 100644 --- a/internal/generated/snippets/speech/apiv2/Client/GetPhraseSet/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/GetPhraseSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/Client/GetRecognizer/main.go b/internal/generated/snippets/speech/apiv2/Client/GetRecognizer/main.go index 93ca0bc2a908..1d4adf357941 100644 --- a/internal/generated/snippets/speech/apiv2/Client/GetRecognizer/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/GetRecognizer/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/Client/ListCustomClasses/main.go b/internal/generated/snippets/speech/apiv2/Client/ListCustomClasses/main.go index 116a7c1e50ba..64a75d22b6ef 100644 --- a/internal/generated/snippets/speech/apiv2/Client/ListCustomClasses/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/ListCustomClasses/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/Client/ListLocations/main.go b/internal/generated/snippets/speech/apiv2/Client/ListLocations/main.go index c291856c8654..91baa7bba567 100644 --- a/internal/generated/snippets/speech/apiv2/Client/ListLocations/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/Client/ListOperations/main.go b/internal/generated/snippets/speech/apiv2/Client/ListOperations/main.go index 352926c56e31..fa1da7d8ee90 100644 --- a/internal/generated/snippets/speech/apiv2/Client/ListOperations/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/Client/ListPhraseSets/main.go b/internal/generated/snippets/speech/apiv2/Client/ListPhraseSets/main.go index 6b81179c0923..7f6cb656dcc3 100644 --- a/internal/generated/snippets/speech/apiv2/Client/ListPhraseSets/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/ListPhraseSets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/Client/ListRecognizers/main.go b/internal/generated/snippets/speech/apiv2/Client/ListRecognizers/main.go index af7c082dc2de..5c5141370429 100644 --- a/internal/generated/snippets/speech/apiv2/Client/ListRecognizers/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/ListRecognizers/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/Client/Recognize/main.go b/internal/generated/snippets/speech/apiv2/Client/Recognize/main.go index 9019bbf8309b..753bbe3b6b03 100644 --- a/internal/generated/snippets/speech/apiv2/Client/Recognize/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/Recognize/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/Client/StreamingRecognize/main.go b/internal/generated/snippets/speech/apiv2/Client/StreamingRecognize/main.go index 2d335c15c0ba..f0f7de9dddab 100644 --- a/internal/generated/snippets/speech/apiv2/Client/StreamingRecognize/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/StreamingRecognize/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/Client/UndeleteCustomClass/main.go b/internal/generated/snippets/speech/apiv2/Client/UndeleteCustomClass/main.go index 4d8244c21ca4..d1465ac5596d 100644 --- a/internal/generated/snippets/speech/apiv2/Client/UndeleteCustomClass/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/UndeleteCustomClass/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/Client/UndeletePhraseSet/main.go b/internal/generated/snippets/speech/apiv2/Client/UndeletePhraseSet/main.go index c4f37164d364..9022b955edb2 100644 --- a/internal/generated/snippets/speech/apiv2/Client/UndeletePhraseSet/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/UndeletePhraseSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/Client/UndeleteRecognizer/main.go b/internal/generated/snippets/speech/apiv2/Client/UndeleteRecognizer/main.go index 7d7c6dbd4490..96ea9df05ead 100644 --- a/internal/generated/snippets/speech/apiv2/Client/UndeleteRecognizer/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/UndeleteRecognizer/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/Client/UpdateConfig/main.go b/internal/generated/snippets/speech/apiv2/Client/UpdateConfig/main.go index aee2a5a07d4b..18919b3084eb 100644 --- a/internal/generated/snippets/speech/apiv2/Client/UpdateConfig/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/UpdateConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/Client/UpdateCustomClass/main.go b/internal/generated/snippets/speech/apiv2/Client/UpdateCustomClass/main.go index 6b7904bca547..6bfe2b198f03 100644 --- a/internal/generated/snippets/speech/apiv2/Client/UpdateCustomClass/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/UpdateCustomClass/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/Client/UpdatePhraseSet/main.go b/internal/generated/snippets/speech/apiv2/Client/UpdatePhraseSet/main.go index 00e5dd03ddf7..e590a553f414 100644 --- a/internal/generated/snippets/speech/apiv2/Client/UpdatePhraseSet/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/UpdatePhraseSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/Client/UpdateRecognizer/main.go b/internal/generated/snippets/speech/apiv2/Client/UpdateRecognizer/main.go index 210964b210dc..18e6396b0782 100644 --- a/internal/generated/snippets/speech/apiv2/Client/UpdateRecognizer/main.go +++ b/internal/generated/snippets/speech/apiv2/Client/UpdateRecognizer/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/speech/apiv2/snippet_metadata.google.cloud.speech.v2.json b/internal/generated/snippets/speech/apiv2/snippet_metadata.google.cloud.speech.v2.json index a5cad2e2e698..9ecd63b5c5df 100644 --- a/internal/generated/snippets/speech/apiv2/snippet_metadata.google.cloud.speech.v2.json +++ b/internal/generated/snippets/speech/apiv2/snippet_metadata.google.cloud.speech.v2.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/speech/apiv2", - "version": "1.25.2", + "version": "1.26.0", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/storage/control/apiv2/StorageControlClient/CreateFolder/main.go b/internal/generated/snippets/storage/control/apiv2/StorageControlClient/CreateFolder/main.go index 831e4171bb6b..8f3993e6f34a 100644 --- a/internal/generated/snippets/storage/control/apiv2/StorageControlClient/CreateFolder/main.go +++ b/internal/generated/snippets/storage/control/apiv2/StorageControlClient/CreateFolder/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storage/control/apiv2/StorageControlClient/CreateManagedFolder/main.go b/internal/generated/snippets/storage/control/apiv2/StorageControlClient/CreateManagedFolder/main.go index 305ce24d928c..585a24b74f9c 100644 --- a/internal/generated/snippets/storage/control/apiv2/StorageControlClient/CreateManagedFolder/main.go +++ b/internal/generated/snippets/storage/control/apiv2/StorageControlClient/CreateManagedFolder/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storage/control/apiv2/StorageControlClient/DeleteFolder/main.go b/internal/generated/snippets/storage/control/apiv2/StorageControlClient/DeleteFolder/main.go index 4fdfcb1b9ca9..37f377d95024 100644 --- a/internal/generated/snippets/storage/control/apiv2/StorageControlClient/DeleteFolder/main.go +++ b/internal/generated/snippets/storage/control/apiv2/StorageControlClient/DeleteFolder/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storage/control/apiv2/StorageControlClient/DeleteManagedFolder/main.go b/internal/generated/snippets/storage/control/apiv2/StorageControlClient/DeleteManagedFolder/main.go index b89e5a64e04d..b60db233b2e5 100644 --- a/internal/generated/snippets/storage/control/apiv2/StorageControlClient/DeleteManagedFolder/main.go +++ b/internal/generated/snippets/storage/control/apiv2/StorageControlClient/DeleteManagedFolder/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storage/control/apiv2/StorageControlClient/GetFolder/main.go b/internal/generated/snippets/storage/control/apiv2/StorageControlClient/GetFolder/main.go index 43892d901f7c..7627c09a7dd5 100644 --- a/internal/generated/snippets/storage/control/apiv2/StorageControlClient/GetFolder/main.go +++ b/internal/generated/snippets/storage/control/apiv2/StorageControlClient/GetFolder/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storage/control/apiv2/StorageControlClient/GetManagedFolder/main.go b/internal/generated/snippets/storage/control/apiv2/StorageControlClient/GetManagedFolder/main.go index f9bfa34fdaad..4307cf1fed43 100644 --- a/internal/generated/snippets/storage/control/apiv2/StorageControlClient/GetManagedFolder/main.go +++ b/internal/generated/snippets/storage/control/apiv2/StorageControlClient/GetManagedFolder/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storage/control/apiv2/StorageControlClient/GetStorageLayout/main.go b/internal/generated/snippets/storage/control/apiv2/StorageControlClient/GetStorageLayout/main.go index 9885fd7b37b3..8d71514ad029 100644 --- a/internal/generated/snippets/storage/control/apiv2/StorageControlClient/GetStorageLayout/main.go +++ b/internal/generated/snippets/storage/control/apiv2/StorageControlClient/GetStorageLayout/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storage/control/apiv2/StorageControlClient/ListFolders/main.go b/internal/generated/snippets/storage/control/apiv2/StorageControlClient/ListFolders/main.go index f72133fa3ceb..fb92641d58a4 100644 --- a/internal/generated/snippets/storage/control/apiv2/StorageControlClient/ListFolders/main.go +++ b/internal/generated/snippets/storage/control/apiv2/StorageControlClient/ListFolders/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storage/control/apiv2/StorageControlClient/ListManagedFolders/main.go b/internal/generated/snippets/storage/control/apiv2/StorageControlClient/ListManagedFolders/main.go index 2a3212c22eb5..0e11c4b8c0e9 100644 --- a/internal/generated/snippets/storage/control/apiv2/StorageControlClient/ListManagedFolders/main.go +++ b/internal/generated/snippets/storage/control/apiv2/StorageControlClient/ListManagedFolders/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storage/control/apiv2/StorageControlClient/RenameFolder/main.go b/internal/generated/snippets/storage/control/apiv2/StorageControlClient/RenameFolder/main.go index ac06bf0cf1da..878c2861f361 100644 --- a/internal/generated/snippets/storage/control/apiv2/StorageControlClient/RenameFolder/main.go +++ b/internal/generated/snippets/storage/control/apiv2/StorageControlClient/RenameFolder/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storageinsights/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/storageinsights/apiv1/Client/CancelOperation/main.go index c0484317d31a..e9d9bf612837 100644 --- a/internal/generated/snippets/storageinsights/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/storageinsights/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storageinsights/apiv1/Client/CreateReportConfig/main.go b/internal/generated/snippets/storageinsights/apiv1/Client/CreateReportConfig/main.go index 9e9b77e9adf5..6f239953369e 100644 --- a/internal/generated/snippets/storageinsights/apiv1/Client/CreateReportConfig/main.go +++ b/internal/generated/snippets/storageinsights/apiv1/Client/CreateReportConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storageinsights/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/storageinsights/apiv1/Client/DeleteOperation/main.go index ed0227638eba..0bacfa45156c 100644 --- a/internal/generated/snippets/storageinsights/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/storageinsights/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storageinsights/apiv1/Client/DeleteReportConfig/main.go b/internal/generated/snippets/storageinsights/apiv1/Client/DeleteReportConfig/main.go index c0abe446130c..65546015977b 100644 --- a/internal/generated/snippets/storageinsights/apiv1/Client/DeleteReportConfig/main.go +++ b/internal/generated/snippets/storageinsights/apiv1/Client/DeleteReportConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storageinsights/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/storageinsights/apiv1/Client/GetLocation/main.go index 4591dc8e4ff1..078256503df2 100644 --- a/internal/generated/snippets/storageinsights/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/storageinsights/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storageinsights/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/storageinsights/apiv1/Client/GetOperation/main.go index 5c18317ad3de..30fcac38b98f 100644 --- a/internal/generated/snippets/storageinsights/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/storageinsights/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storageinsights/apiv1/Client/GetReportConfig/main.go b/internal/generated/snippets/storageinsights/apiv1/Client/GetReportConfig/main.go index 94b2f979efb4..564564bc890c 100644 --- a/internal/generated/snippets/storageinsights/apiv1/Client/GetReportConfig/main.go +++ b/internal/generated/snippets/storageinsights/apiv1/Client/GetReportConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storageinsights/apiv1/Client/GetReportDetail/main.go b/internal/generated/snippets/storageinsights/apiv1/Client/GetReportDetail/main.go index f98f070b509a..4d291d2fa54e 100644 --- a/internal/generated/snippets/storageinsights/apiv1/Client/GetReportDetail/main.go +++ b/internal/generated/snippets/storageinsights/apiv1/Client/GetReportDetail/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storageinsights/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/storageinsights/apiv1/Client/ListLocations/main.go index 51720ebbf444..734d8459d326 100644 --- a/internal/generated/snippets/storageinsights/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/storageinsights/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storageinsights/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/storageinsights/apiv1/Client/ListOperations/main.go index 3f65b2c7f93d..815c491b18f5 100644 --- a/internal/generated/snippets/storageinsights/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/storageinsights/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storageinsights/apiv1/Client/ListReportConfigs/main.go b/internal/generated/snippets/storageinsights/apiv1/Client/ListReportConfigs/main.go index 10013e1fb258..2392ffecf1ac 100644 --- a/internal/generated/snippets/storageinsights/apiv1/Client/ListReportConfigs/main.go +++ b/internal/generated/snippets/storageinsights/apiv1/Client/ListReportConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storageinsights/apiv1/Client/ListReportDetails/main.go b/internal/generated/snippets/storageinsights/apiv1/Client/ListReportDetails/main.go index cd982b58c5c6..3befc0c6add4 100644 --- a/internal/generated/snippets/storageinsights/apiv1/Client/ListReportDetails/main.go +++ b/internal/generated/snippets/storageinsights/apiv1/Client/ListReportDetails/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storageinsights/apiv1/Client/UpdateReportConfig/main.go b/internal/generated/snippets/storageinsights/apiv1/Client/UpdateReportConfig/main.go index ddee76304dbd..711abad07509 100644 --- a/internal/generated/snippets/storageinsights/apiv1/Client/UpdateReportConfig/main.go +++ b/internal/generated/snippets/storageinsights/apiv1/Client/UpdateReportConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storagetransfer/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/storagetransfer/apiv1/Client/CancelOperation/main.go index dc880d903e93..810fed9852c1 100644 --- a/internal/generated/snippets/storagetransfer/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/storagetransfer/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storagetransfer/apiv1/Client/CreateAgentPool/main.go b/internal/generated/snippets/storagetransfer/apiv1/Client/CreateAgentPool/main.go index 7e0f3ae5c3e5..b6ca568e240f 100644 --- a/internal/generated/snippets/storagetransfer/apiv1/Client/CreateAgentPool/main.go +++ b/internal/generated/snippets/storagetransfer/apiv1/Client/CreateAgentPool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storagetransfer/apiv1/Client/CreateTransferJob/main.go b/internal/generated/snippets/storagetransfer/apiv1/Client/CreateTransferJob/main.go index 6cd6654af749..b8e71fd5cb6e 100644 --- a/internal/generated/snippets/storagetransfer/apiv1/Client/CreateTransferJob/main.go +++ b/internal/generated/snippets/storagetransfer/apiv1/Client/CreateTransferJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storagetransfer/apiv1/Client/DeleteAgentPool/main.go b/internal/generated/snippets/storagetransfer/apiv1/Client/DeleteAgentPool/main.go index ad663ca732b6..52344888f93d 100644 --- a/internal/generated/snippets/storagetransfer/apiv1/Client/DeleteAgentPool/main.go +++ b/internal/generated/snippets/storagetransfer/apiv1/Client/DeleteAgentPool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storagetransfer/apiv1/Client/DeleteTransferJob/main.go b/internal/generated/snippets/storagetransfer/apiv1/Client/DeleteTransferJob/main.go index 85808962182e..f9b87bd59052 100644 --- a/internal/generated/snippets/storagetransfer/apiv1/Client/DeleteTransferJob/main.go +++ b/internal/generated/snippets/storagetransfer/apiv1/Client/DeleteTransferJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storagetransfer/apiv1/Client/GetAgentPool/main.go b/internal/generated/snippets/storagetransfer/apiv1/Client/GetAgentPool/main.go index cdf91cf3b973..f8081873a51a 100644 --- a/internal/generated/snippets/storagetransfer/apiv1/Client/GetAgentPool/main.go +++ b/internal/generated/snippets/storagetransfer/apiv1/Client/GetAgentPool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storagetransfer/apiv1/Client/GetGoogleServiceAccount/main.go b/internal/generated/snippets/storagetransfer/apiv1/Client/GetGoogleServiceAccount/main.go index 789c643f8a50..2ec990a89097 100644 --- a/internal/generated/snippets/storagetransfer/apiv1/Client/GetGoogleServiceAccount/main.go +++ b/internal/generated/snippets/storagetransfer/apiv1/Client/GetGoogleServiceAccount/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storagetransfer/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/storagetransfer/apiv1/Client/GetOperation/main.go index 37dcb76864b9..a98b12647b52 100644 --- a/internal/generated/snippets/storagetransfer/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/storagetransfer/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storagetransfer/apiv1/Client/GetTransferJob/main.go b/internal/generated/snippets/storagetransfer/apiv1/Client/GetTransferJob/main.go index d0278a3e2d12..571422494115 100644 --- a/internal/generated/snippets/storagetransfer/apiv1/Client/GetTransferJob/main.go +++ b/internal/generated/snippets/storagetransfer/apiv1/Client/GetTransferJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storagetransfer/apiv1/Client/ListAgentPools/main.go b/internal/generated/snippets/storagetransfer/apiv1/Client/ListAgentPools/main.go index 8e200803d2d5..ebecba4127dc 100644 --- a/internal/generated/snippets/storagetransfer/apiv1/Client/ListAgentPools/main.go +++ b/internal/generated/snippets/storagetransfer/apiv1/Client/ListAgentPools/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storagetransfer/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/storagetransfer/apiv1/Client/ListOperations/main.go index 14fd20e0b0b5..88ee8b42cd75 100644 --- a/internal/generated/snippets/storagetransfer/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/storagetransfer/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storagetransfer/apiv1/Client/ListTransferJobs/main.go b/internal/generated/snippets/storagetransfer/apiv1/Client/ListTransferJobs/main.go index 47f991685808..ec18b0f6c402 100644 --- a/internal/generated/snippets/storagetransfer/apiv1/Client/ListTransferJobs/main.go +++ b/internal/generated/snippets/storagetransfer/apiv1/Client/ListTransferJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storagetransfer/apiv1/Client/PauseTransferOperation/main.go b/internal/generated/snippets/storagetransfer/apiv1/Client/PauseTransferOperation/main.go index 0d8b7257e0dd..cefb6075cdfc 100644 --- a/internal/generated/snippets/storagetransfer/apiv1/Client/PauseTransferOperation/main.go +++ b/internal/generated/snippets/storagetransfer/apiv1/Client/PauseTransferOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storagetransfer/apiv1/Client/ResumeTransferOperation/main.go b/internal/generated/snippets/storagetransfer/apiv1/Client/ResumeTransferOperation/main.go index 5f4c10bc9f91..1667c9307268 100644 --- a/internal/generated/snippets/storagetransfer/apiv1/Client/ResumeTransferOperation/main.go +++ b/internal/generated/snippets/storagetransfer/apiv1/Client/ResumeTransferOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storagetransfer/apiv1/Client/RunTransferJob/main.go b/internal/generated/snippets/storagetransfer/apiv1/Client/RunTransferJob/main.go index d51aafd58370..4ae4de8f9cc8 100644 --- a/internal/generated/snippets/storagetransfer/apiv1/Client/RunTransferJob/main.go +++ b/internal/generated/snippets/storagetransfer/apiv1/Client/RunTransferJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storagetransfer/apiv1/Client/UpdateAgentPool/main.go b/internal/generated/snippets/storagetransfer/apiv1/Client/UpdateAgentPool/main.go index a1c4fdac8385..af780a55bf39 100644 --- a/internal/generated/snippets/storagetransfer/apiv1/Client/UpdateAgentPool/main.go +++ b/internal/generated/snippets/storagetransfer/apiv1/Client/UpdateAgentPool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/storagetransfer/apiv1/Client/UpdateTransferJob/main.go b/internal/generated/snippets/storagetransfer/apiv1/Client/UpdateTransferJob/main.go index 1ec97ad4a851..e8811216df7c 100644 --- a/internal/generated/snippets/storagetransfer/apiv1/Client/UpdateTransferJob/main.go +++ b/internal/generated/snippets/storagetransfer/apiv1/Client/UpdateTransferJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/BatchDeletePhotos/main.go b/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/BatchDeletePhotos/main.go index 623a63dd4680..9d131e7f68d6 100644 --- a/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/BatchDeletePhotos/main.go +++ b/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/BatchDeletePhotos/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/BatchGetPhotos/main.go b/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/BatchGetPhotos/main.go index d367bab4de5a..13e6d0f66691 100644 --- a/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/BatchGetPhotos/main.go +++ b/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/BatchGetPhotos/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/BatchUpdatePhotos/main.go b/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/BatchUpdatePhotos/main.go index e8a05efd0ddf..c738c2537870 100644 --- a/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/BatchUpdatePhotos/main.go +++ b/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/BatchUpdatePhotos/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/CreatePhoto/main.go b/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/CreatePhoto/main.go index 1e23391f7054..f50c8571e567 100644 --- a/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/CreatePhoto/main.go +++ b/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/CreatePhoto/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/CreatePhotoSequence/main.go b/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/CreatePhotoSequence/main.go index 1c3e1c15ce66..91312228132e 100644 --- a/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/CreatePhotoSequence/main.go +++ b/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/CreatePhotoSequence/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/DeletePhoto/main.go b/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/DeletePhoto/main.go index b2be536a758a..100efa62737a 100644 --- a/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/DeletePhoto/main.go +++ b/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/DeletePhoto/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/DeletePhotoSequence/main.go b/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/DeletePhotoSequence/main.go index c713643585ef..6864223fa433 100644 --- a/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/DeletePhotoSequence/main.go +++ b/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/DeletePhotoSequence/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/GetPhoto/main.go b/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/GetPhoto/main.go index 0dfda3ee2878..b23fcb9f1bbb 100644 --- a/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/GetPhoto/main.go +++ b/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/GetPhoto/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/GetPhotoSequence/main.go b/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/GetPhotoSequence/main.go index ba0809ce8074..8e352db105b9 100644 --- a/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/GetPhotoSequence/main.go +++ b/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/GetPhotoSequence/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/ListPhotoSequences/main.go b/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/ListPhotoSequences/main.go index f6549bfa279d..7cc26c2cf4a3 100644 --- a/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/ListPhotoSequences/main.go +++ b/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/ListPhotoSequences/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/ListPhotos/main.go b/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/ListPhotos/main.go index 266067cce320..e8c2f57dd52a 100644 --- a/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/ListPhotos/main.go +++ b/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/ListPhotos/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/StartPhotoSequenceUpload/main.go b/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/StartPhotoSequenceUpload/main.go index 7e152372cfa1..79e523ce4396 100644 --- a/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/StartPhotoSequenceUpload/main.go +++ b/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/StartPhotoSequenceUpload/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/StartUpload/main.go b/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/StartUpload/main.go index cf172a678977..4ab26af88fdc 100644 --- a/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/StartUpload/main.go +++ b/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/StartUpload/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/UpdatePhoto/main.go b/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/UpdatePhoto/main.go index bc2c70c914d2..1422d59cdf70 100644 --- a/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/UpdatePhoto/main.go +++ b/internal/generated/snippets/streetview/publish/apiv1/StreetViewPublishClient/UpdatePhoto/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/streetview/publish/apiv1/snippet_metadata.google.streetview.publish.v1.json b/internal/generated/snippets/streetview/publish/apiv1/snippet_metadata.google.streetview.publish.v1.json index 9cb4436cd72a..26d95b27e63c 100644 --- a/internal/generated/snippets/streetview/publish/apiv1/snippet_metadata.google.streetview.publish.v1.json +++ b/internal/generated/snippets/streetview/publish/apiv1/snippet_metadata.google.streetview.publish.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/streetview/publish/apiv1", - "version": "0.2.2", + "version": "0.2.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/support/apiv2/CaseAttachmentClient/ListAttachments/main.go b/internal/generated/snippets/support/apiv2/CaseAttachmentClient/ListAttachments/main.go index 1f0167c6bbb9..c0c01f39004c 100644 --- a/internal/generated/snippets/support/apiv2/CaseAttachmentClient/ListAttachments/main.go +++ b/internal/generated/snippets/support/apiv2/CaseAttachmentClient/ListAttachments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/support/apiv2/CaseClient/CloseCase/main.go b/internal/generated/snippets/support/apiv2/CaseClient/CloseCase/main.go index 27867686c1c9..4e999f19a1c0 100644 --- a/internal/generated/snippets/support/apiv2/CaseClient/CloseCase/main.go +++ b/internal/generated/snippets/support/apiv2/CaseClient/CloseCase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/support/apiv2/CaseClient/CreateCase/main.go b/internal/generated/snippets/support/apiv2/CaseClient/CreateCase/main.go index 024f56af34e7..19d80b8c4112 100644 --- a/internal/generated/snippets/support/apiv2/CaseClient/CreateCase/main.go +++ b/internal/generated/snippets/support/apiv2/CaseClient/CreateCase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/support/apiv2/CaseClient/EscalateCase/main.go b/internal/generated/snippets/support/apiv2/CaseClient/EscalateCase/main.go index ccac4c954c82..f6d817964889 100644 --- a/internal/generated/snippets/support/apiv2/CaseClient/EscalateCase/main.go +++ b/internal/generated/snippets/support/apiv2/CaseClient/EscalateCase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/support/apiv2/CaseClient/GetCase/main.go b/internal/generated/snippets/support/apiv2/CaseClient/GetCase/main.go index 145382a5242b..7f5a580a1a88 100644 --- a/internal/generated/snippets/support/apiv2/CaseClient/GetCase/main.go +++ b/internal/generated/snippets/support/apiv2/CaseClient/GetCase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/support/apiv2/CaseClient/ListCases/main.go b/internal/generated/snippets/support/apiv2/CaseClient/ListCases/main.go index cb5e2a99a892..ea66a8a078d0 100644 --- a/internal/generated/snippets/support/apiv2/CaseClient/ListCases/main.go +++ b/internal/generated/snippets/support/apiv2/CaseClient/ListCases/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/support/apiv2/CaseClient/SearchCaseClassifications/main.go b/internal/generated/snippets/support/apiv2/CaseClient/SearchCaseClassifications/main.go index 5216607537b3..787048c633fb 100644 --- a/internal/generated/snippets/support/apiv2/CaseClient/SearchCaseClassifications/main.go +++ b/internal/generated/snippets/support/apiv2/CaseClient/SearchCaseClassifications/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/support/apiv2/CaseClient/SearchCases/main.go b/internal/generated/snippets/support/apiv2/CaseClient/SearchCases/main.go index 1d91ade11c32..b8057ee5d940 100644 --- a/internal/generated/snippets/support/apiv2/CaseClient/SearchCases/main.go +++ b/internal/generated/snippets/support/apiv2/CaseClient/SearchCases/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/support/apiv2/CaseClient/UpdateCase/main.go b/internal/generated/snippets/support/apiv2/CaseClient/UpdateCase/main.go index 4bc561219ac0..95a4db02347f 100644 --- a/internal/generated/snippets/support/apiv2/CaseClient/UpdateCase/main.go +++ b/internal/generated/snippets/support/apiv2/CaseClient/UpdateCase/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/support/apiv2/CommentClient/CreateComment/main.go b/internal/generated/snippets/support/apiv2/CommentClient/CreateComment/main.go index 000da76f2e26..6c20eb2478d4 100644 --- a/internal/generated/snippets/support/apiv2/CommentClient/CreateComment/main.go +++ b/internal/generated/snippets/support/apiv2/CommentClient/CreateComment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/support/apiv2/CommentClient/ListComments/main.go b/internal/generated/snippets/support/apiv2/CommentClient/ListComments/main.go index 69948b7d14c5..ce468a4c7e41 100644 --- a/internal/generated/snippets/support/apiv2/CommentClient/ListComments/main.go +++ b/internal/generated/snippets/support/apiv2/CommentClient/ListComments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4/CompanyClient/CreateCompany/main.go b/internal/generated/snippets/talent/apiv4/CompanyClient/CreateCompany/main.go index b54dcbd46ce8..a5cc84ac80a8 100644 --- a/internal/generated/snippets/talent/apiv4/CompanyClient/CreateCompany/main.go +++ b/internal/generated/snippets/talent/apiv4/CompanyClient/CreateCompany/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4/CompanyClient/DeleteCompany/main.go b/internal/generated/snippets/talent/apiv4/CompanyClient/DeleteCompany/main.go index 870399499339..31ce8c95524c 100644 --- a/internal/generated/snippets/talent/apiv4/CompanyClient/DeleteCompany/main.go +++ b/internal/generated/snippets/talent/apiv4/CompanyClient/DeleteCompany/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4/CompanyClient/GetCompany/main.go b/internal/generated/snippets/talent/apiv4/CompanyClient/GetCompany/main.go index b81a5eb467b8..cd28d353fe18 100644 --- a/internal/generated/snippets/talent/apiv4/CompanyClient/GetCompany/main.go +++ b/internal/generated/snippets/talent/apiv4/CompanyClient/GetCompany/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4/CompanyClient/GetOperation/main.go b/internal/generated/snippets/talent/apiv4/CompanyClient/GetOperation/main.go index f898f9793cdc..06bada8f9d29 100644 --- a/internal/generated/snippets/talent/apiv4/CompanyClient/GetOperation/main.go +++ b/internal/generated/snippets/talent/apiv4/CompanyClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4/CompanyClient/ListCompanies/main.go b/internal/generated/snippets/talent/apiv4/CompanyClient/ListCompanies/main.go index e5e4dfe11ccf..db7e6a7fa080 100644 --- a/internal/generated/snippets/talent/apiv4/CompanyClient/ListCompanies/main.go +++ b/internal/generated/snippets/talent/apiv4/CompanyClient/ListCompanies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4/CompanyClient/UpdateCompany/main.go b/internal/generated/snippets/talent/apiv4/CompanyClient/UpdateCompany/main.go index 29b0e6cb9c87..94476f167de0 100644 --- a/internal/generated/snippets/talent/apiv4/CompanyClient/UpdateCompany/main.go +++ b/internal/generated/snippets/talent/apiv4/CompanyClient/UpdateCompany/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4/CompletionClient/CompleteQuery/main.go b/internal/generated/snippets/talent/apiv4/CompletionClient/CompleteQuery/main.go index e1201841ecb9..7ff13afbbcb8 100644 --- a/internal/generated/snippets/talent/apiv4/CompletionClient/CompleteQuery/main.go +++ b/internal/generated/snippets/talent/apiv4/CompletionClient/CompleteQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4/CompletionClient/GetOperation/main.go b/internal/generated/snippets/talent/apiv4/CompletionClient/GetOperation/main.go index d3e7ef392f9e..a6af108355cc 100644 --- a/internal/generated/snippets/talent/apiv4/CompletionClient/GetOperation/main.go +++ b/internal/generated/snippets/talent/apiv4/CompletionClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4/EventClient/CreateClientEvent/main.go b/internal/generated/snippets/talent/apiv4/EventClient/CreateClientEvent/main.go index 4c890d8926d5..1fa55dc8ad3c 100644 --- a/internal/generated/snippets/talent/apiv4/EventClient/CreateClientEvent/main.go +++ b/internal/generated/snippets/talent/apiv4/EventClient/CreateClientEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4/EventClient/GetOperation/main.go b/internal/generated/snippets/talent/apiv4/EventClient/GetOperation/main.go index bd5dae1a238b..6758273c1df2 100644 --- a/internal/generated/snippets/talent/apiv4/EventClient/GetOperation/main.go +++ b/internal/generated/snippets/talent/apiv4/EventClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4/JobClient/BatchCreateJobs/main.go b/internal/generated/snippets/talent/apiv4/JobClient/BatchCreateJobs/main.go index 82c988363b2f..557c48dcd264 100644 --- a/internal/generated/snippets/talent/apiv4/JobClient/BatchCreateJobs/main.go +++ b/internal/generated/snippets/talent/apiv4/JobClient/BatchCreateJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4/JobClient/BatchDeleteJobs/main.go b/internal/generated/snippets/talent/apiv4/JobClient/BatchDeleteJobs/main.go index a393406ea566..4a2aaef58c7c 100644 --- a/internal/generated/snippets/talent/apiv4/JobClient/BatchDeleteJobs/main.go +++ b/internal/generated/snippets/talent/apiv4/JobClient/BatchDeleteJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4/JobClient/BatchUpdateJobs/main.go b/internal/generated/snippets/talent/apiv4/JobClient/BatchUpdateJobs/main.go index b822262d7264..f404ee985ba3 100644 --- a/internal/generated/snippets/talent/apiv4/JobClient/BatchUpdateJobs/main.go +++ b/internal/generated/snippets/talent/apiv4/JobClient/BatchUpdateJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4/JobClient/CreateJob/main.go b/internal/generated/snippets/talent/apiv4/JobClient/CreateJob/main.go index 22c21dbc1052..b048188d1aed 100644 --- a/internal/generated/snippets/talent/apiv4/JobClient/CreateJob/main.go +++ b/internal/generated/snippets/talent/apiv4/JobClient/CreateJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4/JobClient/DeleteJob/main.go b/internal/generated/snippets/talent/apiv4/JobClient/DeleteJob/main.go index f61ca8ab89ec..8093dfc20706 100644 --- a/internal/generated/snippets/talent/apiv4/JobClient/DeleteJob/main.go +++ b/internal/generated/snippets/talent/apiv4/JobClient/DeleteJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4/JobClient/GetJob/main.go b/internal/generated/snippets/talent/apiv4/JobClient/GetJob/main.go index 2608ce184b08..ee3d69a130ee 100644 --- a/internal/generated/snippets/talent/apiv4/JobClient/GetJob/main.go +++ b/internal/generated/snippets/talent/apiv4/JobClient/GetJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4/JobClient/GetOperation/main.go b/internal/generated/snippets/talent/apiv4/JobClient/GetOperation/main.go index 0d13d1e19135..9e1a2201cb37 100644 --- a/internal/generated/snippets/talent/apiv4/JobClient/GetOperation/main.go +++ b/internal/generated/snippets/talent/apiv4/JobClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4/JobClient/ListJobs/main.go b/internal/generated/snippets/talent/apiv4/JobClient/ListJobs/main.go index 6c88e1007a8b..cfe5af978acc 100644 --- a/internal/generated/snippets/talent/apiv4/JobClient/ListJobs/main.go +++ b/internal/generated/snippets/talent/apiv4/JobClient/ListJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4/JobClient/SearchJobs/main.go b/internal/generated/snippets/talent/apiv4/JobClient/SearchJobs/main.go index fe71c3844206..caad119bdaf0 100644 --- a/internal/generated/snippets/talent/apiv4/JobClient/SearchJobs/main.go +++ b/internal/generated/snippets/talent/apiv4/JobClient/SearchJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4/JobClient/SearchJobsForAlert/main.go b/internal/generated/snippets/talent/apiv4/JobClient/SearchJobsForAlert/main.go index 72d703869350..dbe1a3f93b8f 100644 --- a/internal/generated/snippets/talent/apiv4/JobClient/SearchJobsForAlert/main.go +++ b/internal/generated/snippets/talent/apiv4/JobClient/SearchJobsForAlert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4/JobClient/UpdateJob/main.go b/internal/generated/snippets/talent/apiv4/JobClient/UpdateJob/main.go index 0d2695bab4ae..1c3a46f5f53a 100644 --- a/internal/generated/snippets/talent/apiv4/JobClient/UpdateJob/main.go +++ b/internal/generated/snippets/talent/apiv4/JobClient/UpdateJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4/TenantClient/CreateTenant/main.go b/internal/generated/snippets/talent/apiv4/TenantClient/CreateTenant/main.go index ed049ad1f086..43a461136767 100644 --- a/internal/generated/snippets/talent/apiv4/TenantClient/CreateTenant/main.go +++ b/internal/generated/snippets/talent/apiv4/TenantClient/CreateTenant/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4/TenantClient/DeleteTenant/main.go b/internal/generated/snippets/talent/apiv4/TenantClient/DeleteTenant/main.go index d5d4755b348b..22ba73df0382 100644 --- a/internal/generated/snippets/talent/apiv4/TenantClient/DeleteTenant/main.go +++ b/internal/generated/snippets/talent/apiv4/TenantClient/DeleteTenant/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4/TenantClient/GetOperation/main.go b/internal/generated/snippets/talent/apiv4/TenantClient/GetOperation/main.go index c54468118f61..5557231867c0 100644 --- a/internal/generated/snippets/talent/apiv4/TenantClient/GetOperation/main.go +++ b/internal/generated/snippets/talent/apiv4/TenantClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4/TenantClient/GetTenant/main.go b/internal/generated/snippets/talent/apiv4/TenantClient/GetTenant/main.go index 7c5cff0b7c1f..dc9be08eded8 100644 --- a/internal/generated/snippets/talent/apiv4/TenantClient/GetTenant/main.go +++ b/internal/generated/snippets/talent/apiv4/TenantClient/GetTenant/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4/TenantClient/ListTenants/main.go b/internal/generated/snippets/talent/apiv4/TenantClient/ListTenants/main.go index 88065bcf47dc..bbf5b66262ea 100644 --- a/internal/generated/snippets/talent/apiv4/TenantClient/ListTenants/main.go +++ b/internal/generated/snippets/talent/apiv4/TenantClient/ListTenants/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4/TenantClient/UpdateTenant/main.go b/internal/generated/snippets/talent/apiv4/TenantClient/UpdateTenant/main.go index 99452439fc5b..10ef85f083bd 100644 --- a/internal/generated/snippets/talent/apiv4/TenantClient/UpdateTenant/main.go +++ b/internal/generated/snippets/talent/apiv4/TenantClient/UpdateTenant/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4beta1/CompanyClient/CreateCompany/main.go b/internal/generated/snippets/talent/apiv4beta1/CompanyClient/CreateCompany/main.go index e7cd9039a078..5cba54f85baf 100644 --- a/internal/generated/snippets/talent/apiv4beta1/CompanyClient/CreateCompany/main.go +++ b/internal/generated/snippets/talent/apiv4beta1/CompanyClient/CreateCompany/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4beta1/CompanyClient/DeleteCompany/main.go b/internal/generated/snippets/talent/apiv4beta1/CompanyClient/DeleteCompany/main.go index 64485e8969ad..78e450062489 100644 --- a/internal/generated/snippets/talent/apiv4beta1/CompanyClient/DeleteCompany/main.go +++ b/internal/generated/snippets/talent/apiv4beta1/CompanyClient/DeleteCompany/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4beta1/CompanyClient/GetCompany/main.go b/internal/generated/snippets/talent/apiv4beta1/CompanyClient/GetCompany/main.go index 422102409c35..3b91f3fc72c6 100644 --- a/internal/generated/snippets/talent/apiv4beta1/CompanyClient/GetCompany/main.go +++ b/internal/generated/snippets/talent/apiv4beta1/CompanyClient/GetCompany/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4beta1/CompanyClient/GetOperation/main.go b/internal/generated/snippets/talent/apiv4beta1/CompanyClient/GetOperation/main.go index bbb1ce8b5283..64968c25c293 100644 --- a/internal/generated/snippets/talent/apiv4beta1/CompanyClient/GetOperation/main.go +++ b/internal/generated/snippets/talent/apiv4beta1/CompanyClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4beta1/CompanyClient/ListCompanies/main.go b/internal/generated/snippets/talent/apiv4beta1/CompanyClient/ListCompanies/main.go index 50542ecb1d7b..4ecd049b6f73 100644 --- a/internal/generated/snippets/talent/apiv4beta1/CompanyClient/ListCompanies/main.go +++ b/internal/generated/snippets/talent/apiv4beta1/CompanyClient/ListCompanies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4beta1/CompanyClient/UpdateCompany/main.go b/internal/generated/snippets/talent/apiv4beta1/CompanyClient/UpdateCompany/main.go index 3721c26d8fe7..f697fcc0c56e 100644 --- a/internal/generated/snippets/talent/apiv4beta1/CompanyClient/UpdateCompany/main.go +++ b/internal/generated/snippets/talent/apiv4beta1/CompanyClient/UpdateCompany/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4beta1/CompletionClient/CompleteQuery/main.go b/internal/generated/snippets/talent/apiv4beta1/CompletionClient/CompleteQuery/main.go index 9462249f8238..a2b5afb046ba 100644 --- a/internal/generated/snippets/talent/apiv4beta1/CompletionClient/CompleteQuery/main.go +++ b/internal/generated/snippets/talent/apiv4beta1/CompletionClient/CompleteQuery/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4beta1/CompletionClient/GetOperation/main.go b/internal/generated/snippets/talent/apiv4beta1/CompletionClient/GetOperation/main.go index 647d90b4dd5a..a547fa5323fc 100644 --- a/internal/generated/snippets/talent/apiv4beta1/CompletionClient/GetOperation/main.go +++ b/internal/generated/snippets/talent/apiv4beta1/CompletionClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4beta1/EventClient/CreateClientEvent/main.go b/internal/generated/snippets/talent/apiv4beta1/EventClient/CreateClientEvent/main.go index dba7b9473a03..8b6ecd42cca0 100644 --- a/internal/generated/snippets/talent/apiv4beta1/EventClient/CreateClientEvent/main.go +++ b/internal/generated/snippets/talent/apiv4beta1/EventClient/CreateClientEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4beta1/EventClient/GetOperation/main.go b/internal/generated/snippets/talent/apiv4beta1/EventClient/GetOperation/main.go index f327598341f7..9676daa0fab1 100644 --- a/internal/generated/snippets/talent/apiv4beta1/EventClient/GetOperation/main.go +++ b/internal/generated/snippets/talent/apiv4beta1/EventClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4beta1/JobClient/BatchCreateJobs/main.go b/internal/generated/snippets/talent/apiv4beta1/JobClient/BatchCreateJobs/main.go index 50d72abe8b3c..54b763ba0f27 100644 --- a/internal/generated/snippets/talent/apiv4beta1/JobClient/BatchCreateJobs/main.go +++ b/internal/generated/snippets/talent/apiv4beta1/JobClient/BatchCreateJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4beta1/JobClient/BatchDeleteJobs/main.go b/internal/generated/snippets/talent/apiv4beta1/JobClient/BatchDeleteJobs/main.go index 65fc580649a3..770f10c7b4ce 100644 --- a/internal/generated/snippets/talent/apiv4beta1/JobClient/BatchDeleteJobs/main.go +++ b/internal/generated/snippets/talent/apiv4beta1/JobClient/BatchDeleteJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4beta1/JobClient/BatchUpdateJobs/main.go b/internal/generated/snippets/talent/apiv4beta1/JobClient/BatchUpdateJobs/main.go index d7ffbfb4953d..a4e3a5fe23b4 100644 --- a/internal/generated/snippets/talent/apiv4beta1/JobClient/BatchUpdateJobs/main.go +++ b/internal/generated/snippets/talent/apiv4beta1/JobClient/BatchUpdateJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4beta1/JobClient/CreateJob/main.go b/internal/generated/snippets/talent/apiv4beta1/JobClient/CreateJob/main.go index 68a4747bf9ff..6a05618eb711 100644 --- a/internal/generated/snippets/talent/apiv4beta1/JobClient/CreateJob/main.go +++ b/internal/generated/snippets/talent/apiv4beta1/JobClient/CreateJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4beta1/JobClient/DeleteJob/main.go b/internal/generated/snippets/talent/apiv4beta1/JobClient/DeleteJob/main.go index fcebfc770801..c0c2ca589230 100644 --- a/internal/generated/snippets/talent/apiv4beta1/JobClient/DeleteJob/main.go +++ b/internal/generated/snippets/talent/apiv4beta1/JobClient/DeleteJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4beta1/JobClient/GetJob/main.go b/internal/generated/snippets/talent/apiv4beta1/JobClient/GetJob/main.go index 8a0679d8d66a..effcf434eb07 100644 --- a/internal/generated/snippets/talent/apiv4beta1/JobClient/GetJob/main.go +++ b/internal/generated/snippets/talent/apiv4beta1/JobClient/GetJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4beta1/JobClient/GetOperation/main.go b/internal/generated/snippets/talent/apiv4beta1/JobClient/GetOperation/main.go index b9217d697dd8..bfdfadb62516 100644 --- a/internal/generated/snippets/talent/apiv4beta1/JobClient/GetOperation/main.go +++ b/internal/generated/snippets/talent/apiv4beta1/JobClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4beta1/JobClient/ListJobs/main.go b/internal/generated/snippets/talent/apiv4beta1/JobClient/ListJobs/main.go index 2321f73897ba..2dabf6a810e9 100644 --- a/internal/generated/snippets/talent/apiv4beta1/JobClient/ListJobs/main.go +++ b/internal/generated/snippets/talent/apiv4beta1/JobClient/ListJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4beta1/JobClient/SearchJobs/main.go b/internal/generated/snippets/talent/apiv4beta1/JobClient/SearchJobs/main.go index 4918782001dd..91d849265f61 100644 --- a/internal/generated/snippets/talent/apiv4beta1/JobClient/SearchJobs/main.go +++ b/internal/generated/snippets/talent/apiv4beta1/JobClient/SearchJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4beta1/JobClient/SearchJobsForAlert/main.go b/internal/generated/snippets/talent/apiv4beta1/JobClient/SearchJobsForAlert/main.go index 79964a1516b4..ac7c38019156 100644 --- a/internal/generated/snippets/talent/apiv4beta1/JobClient/SearchJobsForAlert/main.go +++ b/internal/generated/snippets/talent/apiv4beta1/JobClient/SearchJobsForAlert/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4beta1/JobClient/UpdateJob/main.go b/internal/generated/snippets/talent/apiv4beta1/JobClient/UpdateJob/main.go index ae636c8c5539..baa85e5b50b8 100644 --- a/internal/generated/snippets/talent/apiv4beta1/JobClient/UpdateJob/main.go +++ b/internal/generated/snippets/talent/apiv4beta1/JobClient/UpdateJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4beta1/TenantClient/CreateTenant/main.go b/internal/generated/snippets/talent/apiv4beta1/TenantClient/CreateTenant/main.go index 19a3922bfd90..c5d590587c97 100644 --- a/internal/generated/snippets/talent/apiv4beta1/TenantClient/CreateTenant/main.go +++ b/internal/generated/snippets/talent/apiv4beta1/TenantClient/CreateTenant/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4beta1/TenantClient/DeleteTenant/main.go b/internal/generated/snippets/talent/apiv4beta1/TenantClient/DeleteTenant/main.go index 2c246f7b4994..28ee73ef91b8 100644 --- a/internal/generated/snippets/talent/apiv4beta1/TenantClient/DeleteTenant/main.go +++ b/internal/generated/snippets/talent/apiv4beta1/TenantClient/DeleteTenant/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4beta1/TenantClient/GetOperation/main.go b/internal/generated/snippets/talent/apiv4beta1/TenantClient/GetOperation/main.go index cf5d0d62360e..6cd2754532b7 100644 --- a/internal/generated/snippets/talent/apiv4beta1/TenantClient/GetOperation/main.go +++ b/internal/generated/snippets/talent/apiv4beta1/TenantClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4beta1/TenantClient/GetTenant/main.go b/internal/generated/snippets/talent/apiv4beta1/TenantClient/GetTenant/main.go index 17890473c821..841304c0c647 100644 --- a/internal/generated/snippets/talent/apiv4beta1/TenantClient/GetTenant/main.go +++ b/internal/generated/snippets/talent/apiv4beta1/TenantClient/GetTenant/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4beta1/TenantClient/ListTenants/main.go b/internal/generated/snippets/talent/apiv4beta1/TenantClient/ListTenants/main.go index de3e865ce4fe..7a815053307f 100644 --- a/internal/generated/snippets/talent/apiv4beta1/TenantClient/ListTenants/main.go +++ b/internal/generated/snippets/talent/apiv4beta1/TenantClient/ListTenants/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/talent/apiv4beta1/TenantClient/UpdateTenant/main.go b/internal/generated/snippets/talent/apiv4beta1/TenantClient/UpdateTenant/main.go index fd626746c91f..bfc68ca234de 100644 --- a/internal/generated/snippets/talent/apiv4beta1/TenantClient/UpdateTenant/main.go +++ b/internal/generated/snippets/talent/apiv4beta1/TenantClient/UpdateTenant/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/ApplyDeployment/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/ApplyDeployment/main.go index 3f942088802f..72817dc7d2ad 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/ApplyDeployment/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/ApplyDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/ApplyHydratedDeployment/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/ApplyHydratedDeployment/main.go index 412ebcbbf9a4..da3c1dce616e 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/ApplyHydratedDeployment/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/ApplyHydratedDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/ApproveBlueprint/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/ApproveBlueprint/main.go index 641668c6973c..ab5490672565 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/ApproveBlueprint/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/ApproveBlueprint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/CancelOperation/main.go index a1b1d03e4a9c..a2ae66f88d91 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/ComputeDeploymentStatus/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/ComputeDeploymentStatus/main.go index 35440bc39441..d91efa0e0080 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/ComputeDeploymentStatus/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/ComputeDeploymentStatus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/CreateBlueprint/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/CreateBlueprint/main.go index 0f9af8fbb864..3fab66801a2f 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/CreateBlueprint/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/CreateBlueprint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/CreateDeployment/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/CreateDeployment/main.go index 46cc78e93901..c15bb67bf685 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/CreateDeployment/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/CreateDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/CreateEdgeSlm/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/CreateEdgeSlm/main.go index 0e66d662d16b..9e4cf0671f98 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/CreateEdgeSlm/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/CreateEdgeSlm/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/CreateOrchestrationCluster/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/CreateOrchestrationCluster/main.go index e5ded6c4f0a6..cf69f8fac491 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/CreateOrchestrationCluster/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/CreateOrchestrationCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/DeleteBlueprint/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/DeleteBlueprint/main.go index bd2adbab6372..dabd3271a586 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/DeleteBlueprint/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/DeleteBlueprint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/DeleteEdgeSlm/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/DeleteEdgeSlm/main.go index b4746612bec7..8972201855c3 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/DeleteEdgeSlm/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/DeleteEdgeSlm/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/DeleteOperation/main.go index 1759181c45e8..dea9b9258342 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/DeleteOrchestrationCluster/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/DeleteOrchestrationCluster/main.go index 13378ef36dfc..e7cafca8973f 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/DeleteOrchestrationCluster/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/DeleteOrchestrationCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/DiscardBlueprintChanges/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/DiscardBlueprintChanges/main.go index 35e52219c13c..59bf1422ffea 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/DiscardBlueprintChanges/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/DiscardBlueprintChanges/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/DiscardDeploymentChanges/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/DiscardDeploymentChanges/main.go index 276469224215..a5cf4fd3995b 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/DiscardDeploymentChanges/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/DiscardDeploymentChanges/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/GetBlueprint/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/GetBlueprint/main.go index 0df6e857b77d..f3bef9cf52d3 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/GetBlueprint/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/GetBlueprint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/GetDeployment/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/GetDeployment/main.go index 6f27fb155fe1..25ad6acd8cc8 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/GetDeployment/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/GetDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/GetEdgeSlm/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/GetEdgeSlm/main.go index e1c748501009..de6202129b8e 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/GetEdgeSlm/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/GetEdgeSlm/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/GetHydratedDeployment/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/GetHydratedDeployment/main.go index f927217b7869..980f5eb42f49 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/GetHydratedDeployment/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/GetHydratedDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/GetLocation/main.go index d3601e488653..3150e7746990 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/GetOperation/main.go index 9d4f76a85540..66da90759bc2 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/GetOrchestrationCluster/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/GetOrchestrationCluster/main.go index 675712fc3198..90b30fd68b49 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/GetOrchestrationCluster/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/GetOrchestrationCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/GetPublicBlueprint/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/GetPublicBlueprint/main.go index 35271404ed8f..c08a7d8711a0 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/GetPublicBlueprint/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/GetPublicBlueprint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/ListBlueprintRevisions/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/ListBlueprintRevisions/main.go index 48dc1afb6356..216c75019f0d 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/ListBlueprintRevisions/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/ListBlueprintRevisions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/ListBlueprints/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/ListBlueprints/main.go index f0f099f925f4..fc83baf6c75a 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/ListBlueprints/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/ListBlueprints/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/ListDeploymentRevisions/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/ListDeploymentRevisions/main.go index 470366600c27..57aaf34c398d 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/ListDeploymentRevisions/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/ListDeploymentRevisions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/ListDeployments/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/ListDeployments/main.go index edfdaaa16f12..c4df00e2e6e0 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/ListDeployments/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/ListDeployments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/ListEdgeSlms/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/ListEdgeSlms/main.go index 45edeb5e1532..4888b5067fa5 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/ListEdgeSlms/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/ListEdgeSlms/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/ListHydratedDeployments/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/ListHydratedDeployments/main.go index 013fa8d826ad..b16131842a79 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/ListHydratedDeployments/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/ListHydratedDeployments/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/ListLocations/main.go index c67016b38e90..3e26bdfdbb19 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/ListOperations/main.go index ab2ccac49dc9..cff5fafe4392 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/ListOrchestrationClusters/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/ListOrchestrationClusters/main.go index cc3f9511fa9b..ddc633632ceb 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/ListOrchestrationClusters/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/ListOrchestrationClusters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/ListPublicBlueprints/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/ListPublicBlueprints/main.go index 0f2ae26ceb48..6b18dc3927cf 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/ListPublicBlueprints/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/ListPublicBlueprints/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/ProposeBlueprint/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/ProposeBlueprint/main.go index faf9ee16022e..8e1095022402 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/ProposeBlueprint/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/ProposeBlueprint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/RejectBlueprint/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/RejectBlueprint/main.go index 016c5430b95c..7ed090ef08c3 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/RejectBlueprint/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/RejectBlueprint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/RemoveDeployment/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/RemoveDeployment/main.go index b3ab9aeeb558..292bb26a4b19 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/RemoveDeployment/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/RemoveDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/RollbackDeployment/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/RollbackDeployment/main.go index ec0edfcc0655..f31224a7e845 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/RollbackDeployment/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/RollbackDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/SearchBlueprintRevisions/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/SearchBlueprintRevisions/main.go index d05112366c7b..8c10b826f55a 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/SearchBlueprintRevisions/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/SearchBlueprintRevisions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/SearchDeploymentRevisions/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/SearchDeploymentRevisions/main.go index 91d1202c3449..08124bb89a44 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/SearchDeploymentRevisions/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/SearchDeploymentRevisions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/UpdateBlueprint/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/UpdateBlueprint/main.go index 8af96c9db905..782e6a2b43d3 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/UpdateBlueprint/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/UpdateBlueprint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/UpdateDeployment/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/UpdateDeployment/main.go index 2e54f5adf542..9083ec283503 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/UpdateDeployment/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/UpdateDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/Client/UpdateHydratedDeployment/main.go b/internal/generated/snippets/telcoautomation/apiv1/Client/UpdateHydratedDeployment/main.go index 6fcf4d0dea36..35e3bc5e2a96 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/Client/UpdateHydratedDeployment/main.go +++ b/internal/generated/snippets/telcoautomation/apiv1/Client/UpdateHydratedDeployment/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/telcoautomation/apiv1/snippet_metadata.google.cloud.telcoautomation.v1.json b/internal/generated/snippets/telcoautomation/apiv1/snippet_metadata.google.cloud.telcoautomation.v1.json index ac93d812c98c..910b97618f49 100644 --- a/internal/generated/snippets/telcoautomation/apiv1/snippet_metadata.google.cloud.telcoautomation.v1.json +++ b/internal/generated/snippets/telcoautomation/apiv1/snippet_metadata.google.cloud.telcoautomation.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/telcoautomation/apiv1", - "version": "1.1.2", + "version": "1.1.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/texttospeech/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/texttospeech/apiv1/Client/GetOperation/main.go index 0abc9fa91801..123c2a83faeb 100644 --- a/internal/generated/snippets/texttospeech/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/texttospeech/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/texttospeech/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/texttospeech/apiv1/Client/ListOperations/main.go index 0370bdb0bb19..3458d83115e9 100644 --- a/internal/generated/snippets/texttospeech/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/texttospeech/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/texttospeech/apiv1/Client/ListVoices/main.go b/internal/generated/snippets/texttospeech/apiv1/Client/ListVoices/main.go index 5f7461a64ac5..7a07fdb6a1f5 100644 --- a/internal/generated/snippets/texttospeech/apiv1/Client/ListVoices/main.go +++ b/internal/generated/snippets/texttospeech/apiv1/Client/ListVoices/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/texttospeech/apiv1/Client/StreamingSynthesize/main.go b/internal/generated/snippets/texttospeech/apiv1/Client/StreamingSynthesize/main.go index 914fd4edf5fe..f1a0c5a1437a 100644 --- a/internal/generated/snippets/texttospeech/apiv1/Client/StreamingSynthesize/main.go +++ b/internal/generated/snippets/texttospeech/apiv1/Client/StreamingSynthesize/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/texttospeech/apiv1/Client/SynthesizeSpeech/main.go b/internal/generated/snippets/texttospeech/apiv1/Client/SynthesizeSpeech/main.go index 489822e7d685..9c7d501b31c3 100644 --- a/internal/generated/snippets/texttospeech/apiv1/Client/SynthesizeSpeech/main.go +++ b/internal/generated/snippets/texttospeech/apiv1/Client/SynthesizeSpeech/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/texttospeech/apiv1/TextToSpeechLongAudioSynthesizeClient/GetOperation/main.go b/internal/generated/snippets/texttospeech/apiv1/TextToSpeechLongAudioSynthesizeClient/GetOperation/main.go index 3917337f0b82..9e27830a966a 100644 --- a/internal/generated/snippets/texttospeech/apiv1/TextToSpeechLongAudioSynthesizeClient/GetOperation/main.go +++ b/internal/generated/snippets/texttospeech/apiv1/TextToSpeechLongAudioSynthesizeClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/texttospeech/apiv1/TextToSpeechLongAudioSynthesizeClient/ListOperations/main.go b/internal/generated/snippets/texttospeech/apiv1/TextToSpeechLongAudioSynthesizeClient/ListOperations/main.go index 9c331006dfca..46d0b365aff1 100644 --- a/internal/generated/snippets/texttospeech/apiv1/TextToSpeechLongAudioSynthesizeClient/ListOperations/main.go +++ b/internal/generated/snippets/texttospeech/apiv1/TextToSpeechLongAudioSynthesizeClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/texttospeech/apiv1/TextToSpeechLongAudioSynthesizeClient/SynthesizeLongAudio/main.go b/internal/generated/snippets/texttospeech/apiv1/TextToSpeechLongAudioSynthesizeClient/SynthesizeLongAudio/main.go index 73ec608d0402..88f76a016cbe 100644 --- a/internal/generated/snippets/texttospeech/apiv1/TextToSpeechLongAudioSynthesizeClient/SynthesizeLongAudio/main.go +++ b/internal/generated/snippets/texttospeech/apiv1/TextToSpeechLongAudioSynthesizeClient/SynthesizeLongAudio/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/tpu/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/tpu/apiv1/Client/CancelOperation/main.go index 40894d2e92c6..2a76e766b939 100644 --- a/internal/generated/snippets/tpu/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/tpu/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/tpu/apiv1/Client/CreateNode/main.go b/internal/generated/snippets/tpu/apiv1/Client/CreateNode/main.go index a0a2c6dbc0e6..7c86371d5049 100644 --- a/internal/generated/snippets/tpu/apiv1/Client/CreateNode/main.go +++ b/internal/generated/snippets/tpu/apiv1/Client/CreateNode/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/tpu/apiv1/Client/DeleteNode/main.go b/internal/generated/snippets/tpu/apiv1/Client/DeleteNode/main.go index ef6f7a798e22..a8e846243e14 100644 --- a/internal/generated/snippets/tpu/apiv1/Client/DeleteNode/main.go +++ b/internal/generated/snippets/tpu/apiv1/Client/DeleteNode/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/tpu/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/tpu/apiv1/Client/DeleteOperation/main.go index 3dd7f8eb9a5d..b5172d3d6347 100644 --- a/internal/generated/snippets/tpu/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/tpu/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/tpu/apiv1/Client/GetAcceleratorType/main.go b/internal/generated/snippets/tpu/apiv1/Client/GetAcceleratorType/main.go index d412a1fd27f0..87db8d31f8a7 100644 --- a/internal/generated/snippets/tpu/apiv1/Client/GetAcceleratorType/main.go +++ b/internal/generated/snippets/tpu/apiv1/Client/GetAcceleratorType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/tpu/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/tpu/apiv1/Client/GetLocation/main.go index 2d59c88fe6a0..8a460777a7dc 100644 --- a/internal/generated/snippets/tpu/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/tpu/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/tpu/apiv1/Client/GetNode/main.go b/internal/generated/snippets/tpu/apiv1/Client/GetNode/main.go index c8d3e7744f81..b3148c25b9e0 100644 --- a/internal/generated/snippets/tpu/apiv1/Client/GetNode/main.go +++ b/internal/generated/snippets/tpu/apiv1/Client/GetNode/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/tpu/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/tpu/apiv1/Client/GetOperation/main.go index cb1379b49748..9d6da86c6937 100644 --- a/internal/generated/snippets/tpu/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/tpu/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/tpu/apiv1/Client/GetTensorFlowVersion/main.go b/internal/generated/snippets/tpu/apiv1/Client/GetTensorFlowVersion/main.go index ee013261bec6..9c717b183c4e 100644 --- a/internal/generated/snippets/tpu/apiv1/Client/GetTensorFlowVersion/main.go +++ b/internal/generated/snippets/tpu/apiv1/Client/GetTensorFlowVersion/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/tpu/apiv1/Client/ListAcceleratorTypes/main.go b/internal/generated/snippets/tpu/apiv1/Client/ListAcceleratorTypes/main.go index e969d94f0c2c..542e24a3983e 100644 --- a/internal/generated/snippets/tpu/apiv1/Client/ListAcceleratorTypes/main.go +++ b/internal/generated/snippets/tpu/apiv1/Client/ListAcceleratorTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/tpu/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/tpu/apiv1/Client/ListLocations/main.go index 92d00be9f3c0..d986227eb648 100644 --- a/internal/generated/snippets/tpu/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/tpu/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/tpu/apiv1/Client/ListNodes/main.go b/internal/generated/snippets/tpu/apiv1/Client/ListNodes/main.go index 6cdda171e2d5..7dcb42824f4c 100644 --- a/internal/generated/snippets/tpu/apiv1/Client/ListNodes/main.go +++ b/internal/generated/snippets/tpu/apiv1/Client/ListNodes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/tpu/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/tpu/apiv1/Client/ListOperations/main.go index d293ece860a8..5615c3259d4d 100644 --- a/internal/generated/snippets/tpu/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/tpu/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/tpu/apiv1/Client/ListTensorFlowVersions/main.go b/internal/generated/snippets/tpu/apiv1/Client/ListTensorFlowVersions/main.go index 148a102abcd6..d2198fcbfda2 100644 --- a/internal/generated/snippets/tpu/apiv1/Client/ListTensorFlowVersions/main.go +++ b/internal/generated/snippets/tpu/apiv1/Client/ListTensorFlowVersions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/tpu/apiv1/Client/ReimageNode/main.go b/internal/generated/snippets/tpu/apiv1/Client/ReimageNode/main.go index 828a8c52d047..c19600833000 100644 --- a/internal/generated/snippets/tpu/apiv1/Client/ReimageNode/main.go +++ b/internal/generated/snippets/tpu/apiv1/Client/ReimageNode/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/tpu/apiv1/Client/StartNode/main.go b/internal/generated/snippets/tpu/apiv1/Client/StartNode/main.go index 31b0e9db8fae..6c26670888ea 100644 --- a/internal/generated/snippets/tpu/apiv1/Client/StartNode/main.go +++ b/internal/generated/snippets/tpu/apiv1/Client/StartNode/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/tpu/apiv1/Client/StopNode/main.go b/internal/generated/snippets/tpu/apiv1/Client/StopNode/main.go index c410947ec38f..0f9a469373e2 100644 --- a/internal/generated/snippets/tpu/apiv1/Client/StopNode/main.go +++ b/internal/generated/snippets/tpu/apiv1/Client/StopNode/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/trace/apiv1/Client/GetTrace/main.go b/internal/generated/snippets/trace/apiv1/Client/GetTrace/main.go index 130dd3c0fea3..7cea70081aea 100644 --- a/internal/generated/snippets/trace/apiv1/Client/GetTrace/main.go +++ b/internal/generated/snippets/trace/apiv1/Client/GetTrace/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/trace/apiv1/Client/ListTraces/main.go b/internal/generated/snippets/trace/apiv1/Client/ListTraces/main.go index 690090666974..4840bcc6db82 100644 --- a/internal/generated/snippets/trace/apiv1/Client/ListTraces/main.go +++ b/internal/generated/snippets/trace/apiv1/Client/ListTraces/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/trace/apiv1/Client/PatchTraces/main.go b/internal/generated/snippets/trace/apiv1/Client/PatchTraces/main.go index d2bc1911c95b..7572ecfc87ec 100644 --- a/internal/generated/snippets/trace/apiv1/Client/PatchTraces/main.go +++ b/internal/generated/snippets/trace/apiv1/Client/PatchTraces/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/trace/apiv2/Client/BatchWriteSpans/main.go b/internal/generated/snippets/trace/apiv2/Client/BatchWriteSpans/main.go index d48154a8273b..1db864e9c6de 100644 --- a/internal/generated/snippets/trace/apiv2/Client/BatchWriteSpans/main.go +++ b/internal/generated/snippets/trace/apiv2/Client/BatchWriteSpans/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/trace/apiv2/Client/CreateSpan/main.go b/internal/generated/snippets/trace/apiv2/Client/CreateSpan/main.go index 18432f301f07..af20da331a80 100644 --- a/internal/generated/snippets/trace/apiv2/Client/CreateSpan/main.go +++ b/internal/generated/snippets/trace/apiv2/Client/CreateSpan/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/AdaptiveMtTranslate/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/AdaptiveMtTranslate/main.go index 27674ce4d0cf..47a4c82ab684 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/AdaptiveMtTranslate/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/AdaptiveMtTranslate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/BatchTranslateDocument/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/BatchTranslateDocument/main.go index e15b3ee62526..a3842ed19e36 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/BatchTranslateDocument/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/BatchTranslateDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/BatchTranslateText/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/BatchTranslateText/main.go index 847d1fdaf05a..ef47d9bb6474 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/BatchTranslateText/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/BatchTranslateText/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/CancelOperation/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/CancelOperation/main.go index 093a1259a5e8..3d1f5991bcf5 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/CancelOperation/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/CreateAdaptiveMtDataset/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/CreateAdaptiveMtDataset/main.go index 1bfd85fe33b6..1fda82c975b7 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/CreateAdaptiveMtDataset/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/CreateAdaptiveMtDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/CreateDataset/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/CreateDataset/main.go index 30fbdb1a807d..6611abb3d91b 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/CreateDataset/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/CreateDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/CreateGlossary/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/CreateGlossary/main.go index 31454160b4e5..1dc3eda67f01 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/CreateGlossary/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/CreateGlossary/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/CreateGlossaryEntry/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/CreateGlossaryEntry/main.go index ba61ec2d0643..202329627a8e 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/CreateGlossaryEntry/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/CreateGlossaryEntry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/CreateModel/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/CreateModel/main.go index 250c7a3ab4f2..7b045551e546 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/CreateModel/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/CreateModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/DeleteAdaptiveMtDataset/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/DeleteAdaptiveMtDataset/main.go index b65f06114742..fc8a3e48dd13 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/DeleteAdaptiveMtDataset/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/DeleteAdaptiveMtDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/DeleteAdaptiveMtFile/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/DeleteAdaptiveMtFile/main.go index 41eb05913d34..8e6634f42937 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/DeleteAdaptiveMtFile/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/DeleteAdaptiveMtFile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/DeleteDataset/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/DeleteDataset/main.go index 80b7d99768b1..c60e04d33f5c 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/DeleteDataset/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/DeleteDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/DeleteGlossary/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/DeleteGlossary/main.go index 73301cdd7d06..04a63201a2bb 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/DeleteGlossary/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/DeleteGlossary/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/DeleteGlossaryEntry/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/DeleteGlossaryEntry/main.go index 30f08960a910..4da5f3d5ff5e 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/DeleteGlossaryEntry/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/DeleteGlossaryEntry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/DeleteModel/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/DeleteModel/main.go index 92ab2965e501..9bcfdbd0071a 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/DeleteModel/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/DeleteModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/DeleteOperation/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/DeleteOperation/main.go index 42d93f68b6df..9b3ab001d95b 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/DeleteOperation/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/DetectLanguage/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/DetectLanguage/main.go index c5ad75603829..3ca90a9e5e3e 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/DetectLanguage/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/DetectLanguage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/ExportData/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/ExportData/main.go index aca2de0c7d20..a347b48aaf6f 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/ExportData/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/ExportData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/GetAdaptiveMtDataset/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/GetAdaptiveMtDataset/main.go index e2f7fe29792a..350f2b6f5c89 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/GetAdaptiveMtDataset/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/GetAdaptiveMtDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/GetAdaptiveMtFile/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/GetAdaptiveMtFile/main.go index 917bc1cd0d4c..59bfabed3d9f 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/GetAdaptiveMtFile/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/GetAdaptiveMtFile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/GetDataset/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/GetDataset/main.go index d9efcf837688..ef249d93abdc 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/GetDataset/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/GetDataset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/GetGlossary/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/GetGlossary/main.go index 5703eb1e5792..4abefdde1d22 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/GetGlossary/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/GetGlossary/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/GetGlossaryEntry/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/GetGlossaryEntry/main.go index d9e6e408af51..5dfcd7e66149 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/GetGlossaryEntry/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/GetGlossaryEntry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/GetLocation/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/GetLocation/main.go index 0d7e178e1e1c..9f5e693b67ae 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/GetLocation/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/GetModel/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/GetModel/main.go index e675d9b36c1d..13f9bdd41679 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/GetModel/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/GetModel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/GetOperation/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/GetOperation/main.go index 0cc775562ff1..1e1cabd1df80 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/GetOperation/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/GetSupportedLanguages/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/GetSupportedLanguages/main.go index 1b34fd0f5251..82bd98004be0 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/GetSupportedLanguages/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/GetSupportedLanguages/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/ImportAdaptiveMtFile/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/ImportAdaptiveMtFile/main.go index a6f8171bec11..cc7d60c3a17c 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/ImportAdaptiveMtFile/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/ImportAdaptiveMtFile/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/ImportData/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/ImportData/main.go index 1da76d7edc9e..32c22f7d4fd3 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/ImportData/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/ImportData/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/ListAdaptiveMtDatasets/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/ListAdaptiveMtDatasets/main.go index 19789fbb7af5..ada5792446eb 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/ListAdaptiveMtDatasets/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/ListAdaptiveMtDatasets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/ListAdaptiveMtFiles/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/ListAdaptiveMtFiles/main.go index e6ea8daaa72d..abd9639df3c3 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/ListAdaptiveMtFiles/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/ListAdaptiveMtFiles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/ListAdaptiveMtSentences/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/ListAdaptiveMtSentences/main.go index 5d9053bb91c4..dc7282d940c2 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/ListAdaptiveMtSentences/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/ListAdaptiveMtSentences/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/ListDatasets/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/ListDatasets/main.go index 2c948e6ef2c9..ec6980ad3679 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/ListDatasets/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/ListDatasets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/ListExamples/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/ListExamples/main.go index 35e05757ffec..c58b6b95fccd 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/ListExamples/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/ListExamples/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/ListGlossaries/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/ListGlossaries/main.go index cdeccf502cef..750534f91ab2 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/ListGlossaries/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/ListGlossaries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/ListGlossaryEntries/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/ListGlossaryEntries/main.go index f67d91d4f8cc..b7782faba190 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/ListGlossaryEntries/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/ListGlossaryEntries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/ListLocations/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/ListLocations/main.go index c6424b392089..943977af701e 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/ListLocations/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/ListModels/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/ListModels/main.go index d30bcd815317..6e0a88807ec8 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/ListModels/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/ListModels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/ListOperations/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/ListOperations/main.go index 5824ed779a5b..b0190a1d8f4f 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/ListOperations/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/RomanizeText/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/RomanizeText/main.go index dd7c6d3f6e32..21ce2c58d57f 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/RomanizeText/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/RomanizeText/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/TranslateDocument/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/TranslateDocument/main.go index e33d67b993d0..b2093b89ea41 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/TranslateDocument/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/TranslateDocument/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/TranslateText/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/TranslateText/main.go index 377b9c4b7cf4..4931c11d303d 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/TranslateText/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/TranslateText/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/UpdateGlossary/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/UpdateGlossary/main.go index fe2a9bd722c6..b8bbd9c7b954 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/UpdateGlossary/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/UpdateGlossary/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/UpdateGlossaryEntry/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/UpdateGlossaryEntry/main.go index 4e1cc6b18c07..e0ad4ea1c21a 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/UpdateGlossaryEntry/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/UpdateGlossaryEntry/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/TranslationClient/WaitOperation/main.go b/internal/generated/snippets/translate/apiv3/TranslationClient/WaitOperation/main.go index ed283ad2ff27..a17f3e0e43ac 100644 --- a/internal/generated/snippets/translate/apiv3/TranslationClient/WaitOperation/main.go +++ b/internal/generated/snippets/translate/apiv3/TranslationClient/WaitOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/translate/apiv3/snippet_metadata.google.cloud.translation.v3.json b/internal/generated/snippets/translate/apiv3/snippet_metadata.google.cloud.translation.v3.json index 9770e18eb82a..dd54f4661a4c 100644 --- a/internal/generated/snippets/translate/apiv3/snippet_metadata.google.cloud.translation.v3.json +++ b/internal/generated/snippets/translate/apiv3/snippet_metadata.google.cloud.translation.v3.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/translate/apiv3", - "version": "1.12.2", + "version": "1.12.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/CancelOperation/main.go index 3f3a115fb5e3..4482048ea3d9 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/CreateAsset/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/CreateAsset/main.go index 82e86547fc92..7e0730ed2e31 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/CreateAsset/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/CreateAsset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/CreateChannel/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/CreateChannel/main.go index b9d4acec5b44..00ca4c54d91c 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/CreateChannel/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/CreateChannel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/CreateClip/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/CreateClip/main.go index d9f956ee00c6..2eaa473530e0 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/CreateClip/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/CreateClip/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/CreateEvent/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/CreateEvent/main.go index e681f79775f4..218045402ef8 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/CreateEvent/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/CreateEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/CreateInput/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/CreateInput/main.go index bccde1f7ba4d..8440c9ec7784 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/CreateInput/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/CreateInput/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/DeleteAsset/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/DeleteAsset/main.go index c55c8a142997..03e15b7fe95b 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/DeleteAsset/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/DeleteAsset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/DeleteChannel/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/DeleteChannel/main.go index bbd099414d7f..74ef360e948b 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/DeleteChannel/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/DeleteChannel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/DeleteClip/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/DeleteClip/main.go index 638e567d60a0..dee98fa0b79a 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/DeleteClip/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/DeleteClip/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/DeleteEvent/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/DeleteEvent/main.go index 2f8f7c4f247e..93bff6772512 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/DeleteEvent/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/DeleteEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/DeleteInput/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/DeleteInput/main.go index c408f3ffc428..dc77afd7222b 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/DeleteInput/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/DeleteInput/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/DeleteOperation/main.go index b3ddb3c5b733..1223d30dfcbb 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/GetAsset/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/GetAsset/main.go index 2f8d733174de..e6a7badf2121 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/GetAsset/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/GetAsset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/GetChannel/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/GetChannel/main.go index 29f889ab12c9..5c0cff2bf631 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/GetChannel/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/GetChannel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/GetClip/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/GetClip/main.go index d6294cd48586..fad6649a3936 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/GetClip/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/GetClip/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/GetEvent/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/GetEvent/main.go index 04d58ed36c59..aa9057242386 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/GetEvent/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/GetEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/GetInput/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/GetInput/main.go index c0faec4cbc20..144c9d264000 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/GetInput/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/GetInput/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/GetLocation/main.go index e43f4574bf19..aba6dc788f88 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/GetOperation/main.go index 0ffea31f9bd3..b5e089bf3e27 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/GetPool/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/GetPool/main.go index 7a3508f7a12e..432bdedc335b 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/GetPool/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/GetPool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/ListAssets/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/ListAssets/main.go index 5d07f4c77fb4..ae60c4e38bb3 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/ListAssets/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/ListAssets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/ListChannels/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/ListChannels/main.go index 566a720fb6eb..2212f2b6b9ae 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/ListChannels/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/ListChannels/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/ListClips/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/ListClips/main.go index 57b4400160e8..0423a6bdbd19 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/ListClips/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/ListClips/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/ListEvents/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/ListEvents/main.go index e3b3f8f4da1e..cad8b163eca4 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/ListEvents/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/ListEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/ListInputs/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/ListInputs/main.go index 305c26bf8ab7..5c3d93399dfc 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/ListInputs/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/ListInputs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/ListLocations/main.go index bb37d58ac824..01480379eb63 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/ListOperations/main.go index 870534c26c8b..6825ccbe8300 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/StartChannel/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/StartChannel/main.go index 5551bf0bc37b..7e60e7a06aea 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/StartChannel/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/StartChannel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/StopChannel/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/StopChannel/main.go index 85c64532e136..88bac489335d 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/StopChannel/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/StopChannel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/UpdateChannel/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/UpdateChannel/main.go index 1ad687a9a251..4c8a81542393 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/UpdateChannel/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/UpdateChannel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/UpdateInput/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/UpdateInput/main.go index fcb6665b6323..2f4b956bdaa5 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/UpdateInput/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/UpdateInput/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/Client/UpdatePool/main.go b/internal/generated/snippets/video/livestream/apiv1/Client/UpdatePool/main.go index c61ee320a9c0..d27907fc5198 100644 --- a/internal/generated/snippets/video/livestream/apiv1/Client/UpdatePool/main.go +++ b/internal/generated/snippets/video/livestream/apiv1/Client/UpdatePool/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/livestream/apiv1/snippet_metadata.google.cloud.video.livestream.v1.json b/internal/generated/snippets/video/livestream/apiv1/snippet_metadata.google.cloud.video.livestream.v1.json index 450b5c154f6f..8360f87c5ed7 100644 --- a/internal/generated/snippets/video/livestream/apiv1/snippet_metadata.google.cloud.video.livestream.v1.json +++ b/internal/generated/snippets/video/livestream/apiv1/snippet_metadata.google.cloud.video.livestream.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/video/livestream/apiv1", - "version": "1.23.2", + "version": "1.23.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/CancelOperation/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/CancelOperation/main.go index 740821ebd3bb..cbd340788028 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/CancelOperation/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/CreateCdnKey/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/CreateCdnKey/main.go index 0a581d85f41a..0103b5e23c39 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/CreateCdnKey/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/CreateCdnKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/CreateLiveConfig/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/CreateLiveConfig/main.go index 23fdcaef630f..c21fb81679b9 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/CreateLiveConfig/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/CreateLiveConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/CreateLiveSession/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/CreateLiveSession/main.go index 7ea4839a830e..308aa5c84a6b 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/CreateLiveSession/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/CreateLiveSession/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/CreateSlate/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/CreateSlate/main.go index df11f5406afc..bbd652f79f58 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/CreateSlate/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/CreateSlate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/CreateVodConfig/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/CreateVodConfig/main.go index 10eee4dbff4f..5f74072bff0e 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/CreateVodConfig/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/CreateVodConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/CreateVodSession/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/CreateVodSession/main.go index 2ee427c9f698..9a4e8165c6f3 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/CreateVodSession/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/CreateVodSession/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/DeleteCdnKey/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/DeleteCdnKey/main.go index cf4902f6fb53..425753f51efb 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/DeleteCdnKey/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/DeleteCdnKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/DeleteLiveConfig/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/DeleteLiveConfig/main.go index fe87c936ca3c..0ab0d200c7e7 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/DeleteLiveConfig/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/DeleteLiveConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/DeleteOperation/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/DeleteOperation/main.go index e6f4d956527b..2ee046b023a1 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/DeleteOperation/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/DeleteSlate/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/DeleteSlate/main.go index c220559d558b..3a49f17b0bfb 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/DeleteSlate/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/DeleteSlate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/DeleteVodConfig/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/DeleteVodConfig/main.go index 46cd8d2942fd..cdbae142cdb4 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/DeleteVodConfig/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/DeleteVodConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetCdnKey/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetCdnKey/main.go index 0a7623d9af0f..ae9ba56014b8 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetCdnKey/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetCdnKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetLiveAdTagDetail/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetLiveAdTagDetail/main.go index ed375f63cbb1..7f5629bcf533 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetLiveAdTagDetail/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetLiveAdTagDetail/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetLiveConfig/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetLiveConfig/main.go index 106a80cee414..86c6983d2bf2 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetLiveConfig/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetLiveConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetLiveSession/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetLiveSession/main.go index 5885d6a21c2a..c0b5bb0d89b0 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetLiveSession/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetLiveSession/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetOperation/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetOperation/main.go index 62929e7ad6d6..7ac6a215cc90 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetOperation/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetSlate/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetSlate/main.go index 30d477570e56..dccf1799c334 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetSlate/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetSlate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetVodAdTagDetail/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetVodAdTagDetail/main.go index f14c89dbc64b..19da9fcdadb8 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetVodAdTagDetail/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetVodAdTagDetail/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetVodConfig/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetVodConfig/main.go index 31c0fe735c3b..8cc7dff3c95f 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetVodConfig/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetVodConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetVodSession/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetVodSession/main.go index b96d4c5efbe2..b6c02d58d779 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetVodSession/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetVodSession/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetVodStitchDetail/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetVodStitchDetail/main.go index 14e4772fcdc0..676e15a0f842 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetVodStitchDetail/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/GetVodStitchDetail/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListCdnKeys/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListCdnKeys/main.go index 1c78c79c90fc..a80337ce7d07 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListCdnKeys/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListCdnKeys/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListLiveAdTagDetails/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListLiveAdTagDetails/main.go index 4af96c75d3d8..ce75d1a43713 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListLiveAdTagDetails/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListLiveAdTagDetails/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListLiveConfigs/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListLiveConfigs/main.go index 2031e4a3bdcc..e4af9171673e 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListLiveConfigs/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListLiveConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListOperations/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListOperations/main.go index ddc110c603e1..b38893c05277 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListOperations/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListSlates/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListSlates/main.go index 37c8ee9a5dd5..b6c861b2b9d8 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListSlates/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListSlates/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListVodAdTagDetails/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListVodAdTagDetails/main.go index fa3648703527..81079b2b3d55 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListVodAdTagDetails/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListVodAdTagDetails/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListVodConfigs/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListVodConfigs/main.go index 7c4198efb973..db5e8090bbc1 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListVodConfigs/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListVodConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListVodStitchDetails/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListVodStitchDetails/main.go index 65ccd5d0b0c6..5a6bc6af9759 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListVodStitchDetails/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/ListVodStitchDetails/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/UpdateCdnKey/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/UpdateCdnKey/main.go index 46fd3f1de802..e9de2fa6490b 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/UpdateCdnKey/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/UpdateCdnKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/UpdateLiveConfig/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/UpdateLiveConfig/main.go index 1af5c6a7d048..2a6789146c93 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/UpdateLiveConfig/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/UpdateLiveConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/UpdateSlate/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/UpdateSlate/main.go index 5d97333b22eb..73a48edbca00 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/UpdateSlate/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/UpdateSlate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/UpdateVodConfig/main.go b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/UpdateVodConfig/main.go index 4ecc7bfc1b20..8a05790bdf70 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/UpdateVodConfig/main.go +++ b/internal/generated/snippets/video/stitcher/apiv1/VideoStitcherClient/UpdateVodConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/stitcher/apiv1/snippet_metadata.google.cloud.video.stitcher.v1.json b/internal/generated/snippets/video/stitcher/apiv1/snippet_metadata.google.cloud.video.stitcher.v1.json index bce616ed1bc7..8b978718b9b4 100644 --- a/internal/generated/snippets/video/stitcher/apiv1/snippet_metadata.google.cloud.video.stitcher.v1.json +++ b/internal/generated/snippets/video/stitcher/apiv1/snippet_metadata.google.cloud.video.stitcher.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/video/stitcher/apiv1", - "version": "1.23.2", + "version": "1.23.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/video/transcoder/apiv1/Client/CreateJob/main.go b/internal/generated/snippets/video/transcoder/apiv1/Client/CreateJob/main.go index 452179e097a6..224fe58a81ab 100644 --- a/internal/generated/snippets/video/transcoder/apiv1/Client/CreateJob/main.go +++ b/internal/generated/snippets/video/transcoder/apiv1/Client/CreateJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/transcoder/apiv1/Client/CreateJobTemplate/main.go b/internal/generated/snippets/video/transcoder/apiv1/Client/CreateJobTemplate/main.go index e72fcdbb63e9..aff878055992 100644 --- a/internal/generated/snippets/video/transcoder/apiv1/Client/CreateJobTemplate/main.go +++ b/internal/generated/snippets/video/transcoder/apiv1/Client/CreateJobTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/transcoder/apiv1/Client/DeleteJob/main.go b/internal/generated/snippets/video/transcoder/apiv1/Client/DeleteJob/main.go index b944291a3dc7..6bec7b6fcdcc 100644 --- a/internal/generated/snippets/video/transcoder/apiv1/Client/DeleteJob/main.go +++ b/internal/generated/snippets/video/transcoder/apiv1/Client/DeleteJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/transcoder/apiv1/Client/DeleteJobTemplate/main.go b/internal/generated/snippets/video/transcoder/apiv1/Client/DeleteJobTemplate/main.go index 00eceedaff7a..0b8a01a781c7 100644 --- a/internal/generated/snippets/video/transcoder/apiv1/Client/DeleteJobTemplate/main.go +++ b/internal/generated/snippets/video/transcoder/apiv1/Client/DeleteJobTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/transcoder/apiv1/Client/GetJob/main.go b/internal/generated/snippets/video/transcoder/apiv1/Client/GetJob/main.go index 00405cf3ce6b..edefd4624e5c 100644 --- a/internal/generated/snippets/video/transcoder/apiv1/Client/GetJob/main.go +++ b/internal/generated/snippets/video/transcoder/apiv1/Client/GetJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/transcoder/apiv1/Client/GetJobTemplate/main.go b/internal/generated/snippets/video/transcoder/apiv1/Client/GetJobTemplate/main.go index c5e7c137c2a8..2b241c0ab053 100644 --- a/internal/generated/snippets/video/transcoder/apiv1/Client/GetJobTemplate/main.go +++ b/internal/generated/snippets/video/transcoder/apiv1/Client/GetJobTemplate/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/transcoder/apiv1/Client/ListJobTemplates/main.go b/internal/generated/snippets/video/transcoder/apiv1/Client/ListJobTemplates/main.go index 9427c0dba5a6..b33b7010ae29 100644 --- a/internal/generated/snippets/video/transcoder/apiv1/Client/ListJobTemplates/main.go +++ b/internal/generated/snippets/video/transcoder/apiv1/Client/ListJobTemplates/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/transcoder/apiv1/Client/ListJobs/main.go b/internal/generated/snippets/video/transcoder/apiv1/Client/ListJobs/main.go index 5489df20d287..5c2a30cdbf8c 100644 --- a/internal/generated/snippets/video/transcoder/apiv1/Client/ListJobs/main.go +++ b/internal/generated/snippets/video/transcoder/apiv1/Client/ListJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/video/transcoder/apiv1/snippet_metadata.google.cloud.video.transcoder.v1.json b/internal/generated/snippets/video/transcoder/apiv1/snippet_metadata.google.cloud.video.transcoder.v1.json index 780e82e72db0..cbc81e4786b7 100644 --- a/internal/generated/snippets/video/transcoder/apiv1/snippet_metadata.google.cloud.video.transcoder.v1.json +++ b/internal/generated/snippets/video/transcoder/apiv1/snippet_metadata.google.cloud.video.transcoder.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/video/transcoder/apiv1", - "version": "1.23.2", + "version": "1.23.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/videointelligence/apiv1/Client/AnnotateVideo/main.go b/internal/generated/snippets/videointelligence/apiv1/Client/AnnotateVideo/main.go index 27066f6dfd00..83b44af0bb32 100644 --- a/internal/generated/snippets/videointelligence/apiv1/Client/AnnotateVideo/main.go +++ b/internal/generated/snippets/videointelligence/apiv1/Client/AnnotateVideo/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/videointelligence/apiv1beta2/Client/AnnotateVideo/main.go b/internal/generated/snippets/videointelligence/apiv1beta2/Client/AnnotateVideo/main.go index 2d05d626f51b..83fd9938c368 100644 --- a/internal/generated/snippets/videointelligence/apiv1beta2/Client/AnnotateVideo/main.go +++ b/internal/generated/snippets/videointelligence/apiv1beta2/Client/AnnotateVideo/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/videointelligence/apiv1p3beta1/Client/AnnotateVideo/main.go b/internal/generated/snippets/videointelligence/apiv1p3beta1/Client/AnnotateVideo/main.go index 2d9b085a8992..9cf20275cbba 100644 --- a/internal/generated/snippets/videointelligence/apiv1p3beta1/Client/AnnotateVideo/main.go +++ b/internal/generated/snippets/videointelligence/apiv1p3beta1/Client/AnnotateVideo/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/videointelligence/apiv1p3beta1/StreamingVideoIntelligenceClient/StreamingAnnotateVideo/main.go b/internal/generated/snippets/videointelligence/apiv1p3beta1/StreamingVideoIntelligenceClient/StreamingAnnotateVideo/main.go index 17b450a67fc4..588563f783fc 100644 --- a/internal/generated/snippets/videointelligence/apiv1p3beta1/StreamingVideoIntelligenceClient/StreamingAnnotateVideo/main.go +++ b/internal/generated/snippets/videointelligence/apiv1p3beta1/StreamingVideoIntelligenceClient/StreamingAnnotateVideo/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vision/apiv1/ImageAnnotatorClient/AsyncBatchAnnotateFiles/main.go b/internal/generated/snippets/vision/apiv1/ImageAnnotatorClient/AsyncBatchAnnotateFiles/main.go index 5fea998b209f..d51d24a37154 100644 --- a/internal/generated/snippets/vision/apiv1/ImageAnnotatorClient/AsyncBatchAnnotateFiles/main.go +++ b/internal/generated/snippets/vision/apiv1/ImageAnnotatorClient/AsyncBatchAnnotateFiles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vision/apiv1/ImageAnnotatorClient/AsyncBatchAnnotateImages/main.go b/internal/generated/snippets/vision/apiv1/ImageAnnotatorClient/AsyncBatchAnnotateImages/main.go index 645e5b05b3b8..17790d822a01 100644 --- a/internal/generated/snippets/vision/apiv1/ImageAnnotatorClient/AsyncBatchAnnotateImages/main.go +++ b/internal/generated/snippets/vision/apiv1/ImageAnnotatorClient/AsyncBatchAnnotateImages/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vision/apiv1/ImageAnnotatorClient/BatchAnnotateFiles/main.go b/internal/generated/snippets/vision/apiv1/ImageAnnotatorClient/BatchAnnotateFiles/main.go index b3c2f900f391..bee1aa215ec8 100644 --- a/internal/generated/snippets/vision/apiv1/ImageAnnotatorClient/BatchAnnotateFiles/main.go +++ b/internal/generated/snippets/vision/apiv1/ImageAnnotatorClient/BatchAnnotateFiles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vision/apiv1/ImageAnnotatorClient/BatchAnnotateImages/main.go b/internal/generated/snippets/vision/apiv1/ImageAnnotatorClient/BatchAnnotateImages/main.go index 46b5b59e01d1..cf6b5b7096ec 100644 --- a/internal/generated/snippets/vision/apiv1/ImageAnnotatorClient/BatchAnnotateImages/main.go +++ b/internal/generated/snippets/vision/apiv1/ImageAnnotatorClient/BatchAnnotateImages/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vision/apiv1/ImageAnnotatorClient/GetOperation/main.go b/internal/generated/snippets/vision/apiv1/ImageAnnotatorClient/GetOperation/main.go index f9e4891bc7b5..b6cf16a5715d 100644 --- a/internal/generated/snippets/vision/apiv1/ImageAnnotatorClient/GetOperation/main.go +++ b/internal/generated/snippets/vision/apiv1/ImageAnnotatorClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vision/apiv1/ProductSearchClient/AddProductToProductSet/main.go b/internal/generated/snippets/vision/apiv1/ProductSearchClient/AddProductToProductSet/main.go index 3d61527fef36..8d120d79ff15 100644 --- a/internal/generated/snippets/vision/apiv1/ProductSearchClient/AddProductToProductSet/main.go +++ b/internal/generated/snippets/vision/apiv1/ProductSearchClient/AddProductToProductSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vision/apiv1/ProductSearchClient/CreateProduct/main.go b/internal/generated/snippets/vision/apiv1/ProductSearchClient/CreateProduct/main.go index af12ab7652a8..b53de0ec1962 100644 --- a/internal/generated/snippets/vision/apiv1/ProductSearchClient/CreateProduct/main.go +++ b/internal/generated/snippets/vision/apiv1/ProductSearchClient/CreateProduct/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vision/apiv1/ProductSearchClient/CreateProductSet/main.go b/internal/generated/snippets/vision/apiv1/ProductSearchClient/CreateProductSet/main.go index b3888ab1b0cc..bd95e8826296 100644 --- a/internal/generated/snippets/vision/apiv1/ProductSearchClient/CreateProductSet/main.go +++ b/internal/generated/snippets/vision/apiv1/ProductSearchClient/CreateProductSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vision/apiv1/ProductSearchClient/CreateReferenceImage/main.go b/internal/generated/snippets/vision/apiv1/ProductSearchClient/CreateReferenceImage/main.go index c12da4dcede2..71ca3d31313e 100644 --- a/internal/generated/snippets/vision/apiv1/ProductSearchClient/CreateReferenceImage/main.go +++ b/internal/generated/snippets/vision/apiv1/ProductSearchClient/CreateReferenceImage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vision/apiv1/ProductSearchClient/DeleteProduct/main.go b/internal/generated/snippets/vision/apiv1/ProductSearchClient/DeleteProduct/main.go index b29c03d3bc1b..53087a69a739 100644 --- a/internal/generated/snippets/vision/apiv1/ProductSearchClient/DeleteProduct/main.go +++ b/internal/generated/snippets/vision/apiv1/ProductSearchClient/DeleteProduct/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vision/apiv1/ProductSearchClient/DeleteProductSet/main.go b/internal/generated/snippets/vision/apiv1/ProductSearchClient/DeleteProductSet/main.go index f097db195714..3519b1863fca 100644 --- a/internal/generated/snippets/vision/apiv1/ProductSearchClient/DeleteProductSet/main.go +++ b/internal/generated/snippets/vision/apiv1/ProductSearchClient/DeleteProductSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vision/apiv1/ProductSearchClient/DeleteReferenceImage/main.go b/internal/generated/snippets/vision/apiv1/ProductSearchClient/DeleteReferenceImage/main.go index 57e622ff60d2..19d5d2cc610a 100644 --- a/internal/generated/snippets/vision/apiv1/ProductSearchClient/DeleteReferenceImage/main.go +++ b/internal/generated/snippets/vision/apiv1/ProductSearchClient/DeleteReferenceImage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vision/apiv1/ProductSearchClient/GetOperation/main.go b/internal/generated/snippets/vision/apiv1/ProductSearchClient/GetOperation/main.go index 79eb04077a99..450f54a970d2 100644 --- a/internal/generated/snippets/vision/apiv1/ProductSearchClient/GetOperation/main.go +++ b/internal/generated/snippets/vision/apiv1/ProductSearchClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vision/apiv1/ProductSearchClient/GetProduct/main.go b/internal/generated/snippets/vision/apiv1/ProductSearchClient/GetProduct/main.go index beb15fc5674f..0d2620b5cbcc 100644 --- a/internal/generated/snippets/vision/apiv1/ProductSearchClient/GetProduct/main.go +++ b/internal/generated/snippets/vision/apiv1/ProductSearchClient/GetProduct/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vision/apiv1/ProductSearchClient/GetProductSet/main.go b/internal/generated/snippets/vision/apiv1/ProductSearchClient/GetProductSet/main.go index 0fa1bbd45329..a8c1d340cd82 100644 --- a/internal/generated/snippets/vision/apiv1/ProductSearchClient/GetProductSet/main.go +++ b/internal/generated/snippets/vision/apiv1/ProductSearchClient/GetProductSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vision/apiv1/ProductSearchClient/GetReferenceImage/main.go b/internal/generated/snippets/vision/apiv1/ProductSearchClient/GetReferenceImage/main.go index 2402d04476e1..d2174c317fc5 100644 --- a/internal/generated/snippets/vision/apiv1/ProductSearchClient/GetReferenceImage/main.go +++ b/internal/generated/snippets/vision/apiv1/ProductSearchClient/GetReferenceImage/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vision/apiv1/ProductSearchClient/ImportProductSets/main.go b/internal/generated/snippets/vision/apiv1/ProductSearchClient/ImportProductSets/main.go index 19f4908f5e6f..45ebb1ad25bc 100644 --- a/internal/generated/snippets/vision/apiv1/ProductSearchClient/ImportProductSets/main.go +++ b/internal/generated/snippets/vision/apiv1/ProductSearchClient/ImportProductSets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vision/apiv1/ProductSearchClient/ListProductSets/main.go b/internal/generated/snippets/vision/apiv1/ProductSearchClient/ListProductSets/main.go index 25b57e4186b2..daf9d03f7107 100644 --- a/internal/generated/snippets/vision/apiv1/ProductSearchClient/ListProductSets/main.go +++ b/internal/generated/snippets/vision/apiv1/ProductSearchClient/ListProductSets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vision/apiv1/ProductSearchClient/ListProducts/main.go b/internal/generated/snippets/vision/apiv1/ProductSearchClient/ListProducts/main.go index fc53994a6d74..a4ca41e8387c 100644 --- a/internal/generated/snippets/vision/apiv1/ProductSearchClient/ListProducts/main.go +++ b/internal/generated/snippets/vision/apiv1/ProductSearchClient/ListProducts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vision/apiv1/ProductSearchClient/ListProductsInProductSet/main.go b/internal/generated/snippets/vision/apiv1/ProductSearchClient/ListProductsInProductSet/main.go index 95f2e4b80c66..6a7afddac8b5 100644 --- a/internal/generated/snippets/vision/apiv1/ProductSearchClient/ListProductsInProductSet/main.go +++ b/internal/generated/snippets/vision/apiv1/ProductSearchClient/ListProductsInProductSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vision/apiv1/ProductSearchClient/ListReferenceImages/main.go b/internal/generated/snippets/vision/apiv1/ProductSearchClient/ListReferenceImages/main.go index 882464c004d3..44b7aa8067cc 100644 --- a/internal/generated/snippets/vision/apiv1/ProductSearchClient/ListReferenceImages/main.go +++ b/internal/generated/snippets/vision/apiv1/ProductSearchClient/ListReferenceImages/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vision/apiv1/ProductSearchClient/PurgeProducts/main.go b/internal/generated/snippets/vision/apiv1/ProductSearchClient/PurgeProducts/main.go index faddd53b8c0c..e3ce036fe5d2 100644 --- a/internal/generated/snippets/vision/apiv1/ProductSearchClient/PurgeProducts/main.go +++ b/internal/generated/snippets/vision/apiv1/ProductSearchClient/PurgeProducts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vision/apiv1/ProductSearchClient/RemoveProductFromProductSet/main.go b/internal/generated/snippets/vision/apiv1/ProductSearchClient/RemoveProductFromProductSet/main.go index 8a5724142d04..f0ec43c5eeed 100644 --- a/internal/generated/snippets/vision/apiv1/ProductSearchClient/RemoveProductFromProductSet/main.go +++ b/internal/generated/snippets/vision/apiv1/ProductSearchClient/RemoveProductFromProductSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vision/apiv1/ProductSearchClient/UpdateProduct/main.go b/internal/generated/snippets/vision/apiv1/ProductSearchClient/UpdateProduct/main.go index ebce8437e17b..7a253715d40f 100644 --- a/internal/generated/snippets/vision/apiv1/ProductSearchClient/UpdateProduct/main.go +++ b/internal/generated/snippets/vision/apiv1/ProductSearchClient/UpdateProduct/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vision/apiv1/ProductSearchClient/UpdateProductSet/main.go b/internal/generated/snippets/vision/apiv1/ProductSearchClient/UpdateProductSet/main.go index f02949f134ba..f2c981129af3 100644 --- a/internal/generated/snippets/vision/apiv1/ProductSearchClient/UpdateProductSet/main.go +++ b/internal/generated/snippets/vision/apiv1/ProductSearchClient/UpdateProductSet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vision/apiv1/snippet_metadata.google.cloud.vision.v1.json b/internal/generated/snippets/vision/apiv1/snippet_metadata.google.cloud.vision.v1.json index 91a124da2b2e..b4d68bf2a2be 100644 --- a/internal/generated/snippets/vision/apiv1/snippet_metadata.google.cloud.vision.v1.json +++ b/internal/generated/snippets/vision/apiv1/snippet_metadata.google.cloud.vision.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/vision/v2/apiv1", - "version": "2.9.2", + "version": "2.9.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/vision/apiv1p1beta1/ImageAnnotatorClient/BatchAnnotateImages/main.go b/internal/generated/snippets/vision/apiv1p1beta1/ImageAnnotatorClient/BatchAnnotateImages/main.go index a4dd2f1a8800..e6a1cfca7efc 100644 --- a/internal/generated/snippets/vision/apiv1p1beta1/ImageAnnotatorClient/BatchAnnotateImages/main.go +++ b/internal/generated/snippets/vision/apiv1p1beta1/ImageAnnotatorClient/BatchAnnotateImages/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vision/apiv1p1beta1/snippet_metadata.google.cloud.vision.v1p1beta1.json b/internal/generated/snippets/vision/apiv1p1beta1/snippet_metadata.google.cloud.vision.v1p1beta1.json index 05dfa7dc97b9..79dfc8897993 100644 --- a/internal/generated/snippets/vision/apiv1p1beta1/snippet_metadata.google.cloud.vision.v1p1beta1.json +++ b/internal/generated/snippets/vision/apiv1p1beta1/snippet_metadata.google.cloud.vision.v1p1beta1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/vision/v2/apiv1p1beta1", - "version": "2.9.2", + "version": "2.9.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/AddApplicationStreamInput/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/AddApplicationStreamInput/main.go index bf44cf4c0db1..428143e95820 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/AddApplicationStreamInput/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/AddApplicationStreamInput/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/CancelOperation/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/CancelOperation/main.go index b749e8282869..46e437f46301 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/CancelOperation/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/CreateApplication/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/CreateApplication/main.go index 05113cf0a4c3..78c228be5363 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/CreateApplication/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/CreateApplication/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/CreateApplicationInstances/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/CreateApplicationInstances/main.go index c9e392f4507d..1548c68f89f5 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/CreateApplicationInstances/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/CreateApplicationInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/CreateDraft/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/CreateDraft/main.go index d37d6c4a9cd8..ddd6a6e68aaf 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/CreateDraft/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/CreateDraft/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/CreateProcessor/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/CreateProcessor/main.go index ac9acf20fca8..f3cc376adbc5 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/CreateProcessor/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/CreateProcessor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/DeleteApplication/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/DeleteApplication/main.go index 64ddecd88d6a..4ee0a3b5e6d8 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/DeleteApplication/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/DeleteApplication/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/DeleteApplicationInstances/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/DeleteApplicationInstances/main.go index b30ab9d3f068..81ac9670918a 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/DeleteApplicationInstances/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/DeleteApplicationInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/DeleteDraft/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/DeleteDraft/main.go index b42cde224a68..edd56509d61c 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/DeleteDraft/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/DeleteDraft/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/DeleteOperation/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/DeleteOperation/main.go index 80774044a0d1..1d6581e54691 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/DeleteOperation/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/DeleteProcessor/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/DeleteProcessor/main.go index d378663e5bfa..66a985498108 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/DeleteProcessor/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/DeleteProcessor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/DeployApplication/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/DeployApplication/main.go index 88012e21329c..c8d6cc569df6 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/DeployApplication/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/DeployApplication/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/GetApplication/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/GetApplication/main.go index 5c789d8e5f70..f9ddbce748a6 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/GetApplication/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/GetApplication/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/GetDraft/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/GetDraft/main.go index b465fdc1e60b..ff70774abdbd 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/GetDraft/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/GetDraft/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/GetInstance/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/GetInstance/main.go index 199bb473b43e..20da21ada708 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/GetInstance/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/GetInstance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/GetOperation/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/GetOperation/main.go index 3565e70feb8b..7461366d1ad8 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/GetOperation/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/GetProcessor/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/GetProcessor/main.go index 3defb69d287c..f87d5e2dd56b 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/GetProcessor/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/GetProcessor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/ListApplications/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/ListApplications/main.go index 43fe690a8c8b..6a2d695cd0ae 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/ListApplications/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/ListApplications/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/ListDrafts/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/ListDrafts/main.go index 6408920ba659..668f8c4ff243 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/ListDrafts/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/ListDrafts/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/ListInstances/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/ListInstances/main.go index c25fe1d526d1..077a6997f0ce 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/ListInstances/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/ListInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/ListOperations/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/ListOperations/main.go index ce77dae99ed6..925a757c3c07 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/ListOperations/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/ListPrebuiltProcessors/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/ListPrebuiltProcessors/main.go index 1cfdad8a6f24..8464ea8e4636 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/ListPrebuiltProcessors/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/ListPrebuiltProcessors/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/ListProcessors/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/ListProcessors/main.go index 0c337083320d..54287736fa5a 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/ListProcessors/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/ListProcessors/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/RemoveApplicationStreamInput/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/RemoveApplicationStreamInput/main.go index c6486478fd6b..d46997160677 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/RemoveApplicationStreamInput/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/RemoveApplicationStreamInput/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/UndeployApplication/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/UndeployApplication/main.go index a7d3ae124ed3..23eb766e02d1 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/UndeployApplication/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/UndeployApplication/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/UpdateApplication/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/UpdateApplication/main.go index 9eb1b25288e3..dc7a768de335 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/UpdateApplication/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/UpdateApplication/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/UpdateApplicationInstances/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/UpdateApplicationInstances/main.go index 8daeb571a180..a83d104ebb88 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/UpdateApplicationInstances/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/UpdateApplicationInstances/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/UpdateApplicationStreamInput/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/UpdateApplicationStreamInput/main.go index f0085c730aa1..41d44ceae15a 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/UpdateApplicationStreamInput/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/UpdateApplicationStreamInput/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/UpdateDraft/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/UpdateDraft/main.go index eca9870681db..ea5c64b7239c 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/UpdateDraft/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/UpdateDraft/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/UpdateProcessor/main.go b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/UpdateProcessor/main.go index e56e99cda886..9e99cbd6b11d 100644 --- a/internal/generated/snippets/visionai/apiv1/AppPlatformClient/UpdateProcessor/main.go +++ b/internal/generated/snippets/visionai/apiv1/AppPlatformClient/UpdateProcessor/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/HealthCheckClient/CancelOperation/main.go b/internal/generated/snippets/visionai/apiv1/HealthCheckClient/CancelOperation/main.go index f8838107a3f2..69aef9cb82c3 100644 --- a/internal/generated/snippets/visionai/apiv1/HealthCheckClient/CancelOperation/main.go +++ b/internal/generated/snippets/visionai/apiv1/HealthCheckClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/HealthCheckClient/DeleteOperation/main.go b/internal/generated/snippets/visionai/apiv1/HealthCheckClient/DeleteOperation/main.go index e24bffd4011e..545606251301 100644 --- a/internal/generated/snippets/visionai/apiv1/HealthCheckClient/DeleteOperation/main.go +++ b/internal/generated/snippets/visionai/apiv1/HealthCheckClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/HealthCheckClient/GetOperation/main.go b/internal/generated/snippets/visionai/apiv1/HealthCheckClient/GetOperation/main.go index 3b453fc02a06..17b0d50f4f00 100644 --- a/internal/generated/snippets/visionai/apiv1/HealthCheckClient/GetOperation/main.go +++ b/internal/generated/snippets/visionai/apiv1/HealthCheckClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/HealthCheckClient/HealthCheck/main.go b/internal/generated/snippets/visionai/apiv1/HealthCheckClient/HealthCheck/main.go index f01deb02055a..7bbb55d35c4d 100644 --- a/internal/generated/snippets/visionai/apiv1/HealthCheckClient/HealthCheck/main.go +++ b/internal/generated/snippets/visionai/apiv1/HealthCheckClient/HealthCheck/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/HealthCheckClient/ListOperations/main.go b/internal/generated/snippets/visionai/apiv1/HealthCheckClient/ListOperations/main.go index 23d2650582f1..52bb638a326b 100644 --- a/internal/generated/snippets/visionai/apiv1/HealthCheckClient/ListOperations/main.go +++ b/internal/generated/snippets/visionai/apiv1/HealthCheckClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/BatchRunProcess/main.go b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/BatchRunProcess/main.go index b16c2039152f..d5c787a89772 100644 --- a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/BatchRunProcess/main.go +++ b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/BatchRunProcess/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/CancelOperation/main.go b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/CancelOperation/main.go index 068f0141b27a..6e151f0ce862 100644 --- a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/CancelOperation/main.go +++ b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/CreateAnalysis/main.go b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/CreateAnalysis/main.go index 7f68f6305116..5b4aacd182e2 100644 --- a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/CreateAnalysis/main.go +++ b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/CreateAnalysis/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/CreateOperator/main.go b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/CreateOperator/main.go index 5c592245111a..3259ed4f9876 100644 --- a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/CreateOperator/main.go +++ b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/CreateOperator/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/CreateProcess/main.go b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/CreateProcess/main.go index f287ab9b577b..e7a2a46b722e 100644 --- a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/CreateProcess/main.go +++ b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/CreateProcess/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/DeleteAnalysis/main.go b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/DeleteAnalysis/main.go index 81653e33178d..42825f615f6e 100644 --- a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/DeleteAnalysis/main.go +++ b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/DeleteAnalysis/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/DeleteOperation/main.go b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/DeleteOperation/main.go index 2f6957ad56b1..e83bdc1aaa79 100644 --- a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/DeleteOperation/main.go +++ b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/DeleteOperator/main.go b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/DeleteOperator/main.go index d0ce7f207027..62bb3117cee2 100644 --- a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/DeleteOperator/main.go +++ b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/DeleteOperator/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/DeleteProcess/main.go b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/DeleteProcess/main.go index 78a824eb5b9f..faf322cea169 100644 --- a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/DeleteProcess/main.go +++ b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/DeleteProcess/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/GetAnalysis/main.go b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/GetAnalysis/main.go index 679c7561d23d..eec7362214a2 100644 --- a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/GetAnalysis/main.go +++ b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/GetAnalysis/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/GetOperation/main.go b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/GetOperation/main.go index c01106e21618..e40a4734df6a 100644 --- a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/GetOperation/main.go +++ b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/GetOperator/main.go b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/GetOperator/main.go index 13c2c3b0d929..efeec0ae1229 100644 --- a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/GetOperator/main.go +++ b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/GetOperator/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/GetProcess/main.go b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/GetProcess/main.go index ef325bca7f80..ad14c80420c0 100644 --- a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/GetProcess/main.go +++ b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/GetProcess/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/ListAnalyses/main.go b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/ListAnalyses/main.go index 069319a89f10..a1c54d892639 100644 --- a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/ListAnalyses/main.go +++ b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/ListAnalyses/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/ListOperations/main.go b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/ListOperations/main.go index 78ec45a664e9..de88c8dab511 100644 --- a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/ListOperations/main.go +++ b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/ListOperators/main.go b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/ListOperators/main.go index 4fc8c0b423f8..c8e34828b4b0 100644 --- a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/ListOperators/main.go +++ b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/ListOperators/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/ListProcesses/main.go b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/ListProcesses/main.go index a705a87d899a..cd1726d82425 100644 --- a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/ListProcesses/main.go +++ b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/ListProcesses/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/ListPublicOperators/main.go b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/ListPublicOperators/main.go index 232960a191c9..f866537e0098 100644 --- a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/ListPublicOperators/main.go +++ b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/ListPublicOperators/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/ResolveOperatorInfo/main.go b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/ResolveOperatorInfo/main.go index e1cbf7e3c742..498105b6b8af 100644 --- a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/ResolveOperatorInfo/main.go +++ b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/ResolveOperatorInfo/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/UpdateAnalysis/main.go b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/UpdateAnalysis/main.go index 3c89d05ad8f8..3b8d5f4ebbda 100644 --- a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/UpdateAnalysis/main.go +++ b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/UpdateAnalysis/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/UpdateOperator/main.go b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/UpdateOperator/main.go index 11d940ca66fc..c10cee97125e 100644 --- a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/UpdateOperator/main.go +++ b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/UpdateOperator/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/UpdateProcess/main.go b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/UpdateProcess/main.go index 86417165b145..e1d7169eb1e4 100644 --- a/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/UpdateProcess/main.go +++ b/internal/generated/snippets/visionai/apiv1/LiveVideoAnalyticsClient/UpdateProcess/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamingClient/AcquireLease/main.go b/internal/generated/snippets/visionai/apiv1/StreamingClient/AcquireLease/main.go index d59a525d6602..22d0a7c663d0 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamingClient/AcquireLease/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamingClient/AcquireLease/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamingClient/CancelOperation/main.go b/internal/generated/snippets/visionai/apiv1/StreamingClient/CancelOperation/main.go index 22fbaa1a25db..db995b64b47c 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamingClient/CancelOperation/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamingClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamingClient/DeleteOperation/main.go b/internal/generated/snippets/visionai/apiv1/StreamingClient/DeleteOperation/main.go index 46a0815ca4a2..da0fdde65f11 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamingClient/DeleteOperation/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamingClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamingClient/GetOperation/main.go b/internal/generated/snippets/visionai/apiv1/StreamingClient/GetOperation/main.go index 29c8f8cdbfe5..f0a03bb5fada 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamingClient/GetOperation/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamingClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamingClient/ListOperations/main.go b/internal/generated/snippets/visionai/apiv1/StreamingClient/ListOperations/main.go index 40d0c51dd179..6c9faef01ccb 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamingClient/ListOperations/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamingClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamingClient/ReceiveEvents/main.go b/internal/generated/snippets/visionai/apiv1/StreamingClient/ReceiveEvents/main.go index 0a9851b53533..f074f398779b 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamingClient/ReceiveEvents/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamingClient/ReceiveEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamingClient/ReceivePackets/main.go b/internal/generated/snippets/visionai/apiv1/StreamingClient/ReceivePackets/main.go index 7040ae5063a4..0b89ef368b86 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamingClient/ReceivePackets/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamingClient/ReceivePackets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamingClient/ReleaseLease/main.go b/internal/generated/snippets/visionai/apiv1/StreamingClient/ReleaseLease/main.go index 2c8055646387..88c972b59b73 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamingClient/ReleaseLease/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamingClient/ReleaseLease/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamingClient/RenewLease/main.go b/internal/generated/snippets/visionai/apiv1/StreamingClient/RenewLease/main.go index aad3445c7535..18c67573b56c 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamingClient/RenewLease/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamingClient/RenewLease/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamingClient/SendPackets/main.go b/internal/generated/snippets/visionai/apiv1/StreamingClient/SendPackets/main.go index cd745d3891ca..3d0c2d4be6d4 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamingClient/SendPackets/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamingClient/SendPackets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamsClient/CancelOperation/main.go b/internal/generated/snippets/visionai/apiv1/StreamsClient/CancelOperation/main.go index f66583511b79..b085ead294c5 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamsClient/CancelOperation/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamsClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamsClient/CreateCluster/main.go b/internal/generated/snippets/visionai/apiv1/StreamsClient/CreateCluster/main.go index 69cc08945199..960f249a4365 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamsClient/CreateCluster/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamsClient/CreateCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamsClient/CreateEvent/main.go b/internal/generated/snippets/visionai/apiv1/StreamsClient/CreateEvent/main.go index 8a36f6e7c0ca..dca0c4fc5887 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamsClient/CreateEvent/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamsClient/CreateEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamsClient/CreateSeries/main.go b/internal/generated/snippets/visionai/apiv1/StreamsClient/CreateSeries/main.go index 934d34d062a3..2bcb6b2da5fe 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamsClient/CreateSeries/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamsClient/CreateSeries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamsClient/CreateStream/main.go b/internal/generated/snippets/visionai/apiv1/StreamsClient/CreateStream/main.go index 89b6d6dc321d..c1bd940ecdfb 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamsClient/CreateStream/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamsClient/CreateStream/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamsClient/DeleteCluster/main.go b/internal/generated/snippets/visionai/apiv1/StreamsClient/DeleteCluster/main.go index 3b099a1c07cd..d81e68fcaf88 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamsClient/DeleteCluster/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamsClient/DeleteCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamsClient/DeleteEvent/main.go b/internal/generated/snippets/visionai/apiv1/StreamsClient/DeleteEvent/main.go index 1e40c741b18c..8f556cb0eb1f 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamsClient/DeleteEvent/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamsClient/DeleteEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamsClient/DeleteOperation/main.go b/internal/generated/snippets/visionai/apiv1/StreamsClient/DeleteOperation/main.go index 9c1423d6f4e0..e98e7a254ece 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamsClient/DeleteOperation/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamsClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamsClient/DeleteSeries/main.go b/internal/generated/snippets/visionai/apiv1/StreamsClient/DeleteSeries/main.go index 773327e2cfd1..a5d9b1d229e3 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamsClient/DeleteSeries/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamsClient/DeleteSeries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamsClient/DeleteStream/main.go b/internal/generated/snippets/visionai/apiv1/StreamsClient/DeleteStream/main.go index 4194e753b212..7ce38946e7ae 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamsClient/DeleteStream/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamsClient/DeleteStream/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamsClient/GenerateStreamHlsToken/main.go b/internal/generated/snippets/visionai/apiv1/StreamsClient/GenerateStreamHlsToken/main.go index 5d7c9af8b64f..e25f26086237 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamsClient/GenerateStreamHlsToken/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamsClient/GenerateStreamHlsToken/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamsClient/GetCluster/main.go b/internal/generated/snippets/visionai/apiv1/StreamsClient/GetCluster/main.go index 116ea5b08c66..54784aadf95a 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamsClient/GetCluster/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamsClient/GetCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamsClient/GetEvent/main.go b/internal/generated/snippets/visionai/apiv1/StreamsClient/GetEvent/main.go index cb4167843ffc..089557116c37 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamsClient/GetEvent/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamsClient/GetEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamsClient/GetOperation/main.go b/internal/generated/snippets/visionai/apiv1/StreamsClient/GetOperation/main.go index f89be3dbc102..6c4bb953fc36 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamsClient/GetOperation/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamsClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamsClient/GetSeries/main.go b/internal/generated/snippets/visionai/apiv1/StreamsClient/GetSeries/main.go index 7ed00c85a923..0197d8d6ad1e 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamsClient/GetSeries/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamsClient/GetSeries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamsClient/GetStream/main.go b/internal/generated/snippets/visionai/apiv1/StreamsClient/GetStream/main.go index c7e20562bd56..5f7207c3ed76 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamsClient/GetStream/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamsClient/GetStream/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamsClient/GetStreamThumbnail/main.go b/internal/generated/snippets/visionai/apiv1/StreamsClient/GetStreamThumbnail/main.go index 75018ae07320..e904a6c3a09e 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamsClient/GetStreamThumbnail/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamsClient/GetStreamThumbnail/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamsClient/ListClusters/main.go b/internal/generated/snippets/visionai/apiv1/StreamsClient/ListClusters/main.go index ca688471f3cb..81fa1ae9d1d7 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamsClient/ListClusters/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamsClient/ListClusters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamsClient/ListEvents/main.go b/internal/generated/snippets/visionai/apiv1/StreamsClient/ListEvents/main.go index 680debead673..3a32b581fe35 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamsClient/ListEvents/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamsClient/ListEvents/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamsClient/ListOperations/main.go b/internal/generated/snippets/visionai/apiv1/StreamsClient/ListOperations/main.go index e7860e0557ca..8911b9a91002 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamsClient/ListOperations/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamsClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamsClient/ListSeries/main.go b/internal/generated/snippets/visionai/apiv1/StreamsClient/ListSeries/main.go index 644d6754bb5d..eaffc9bf63a6 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamsClient/ListSeries/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamsClient/ListSeries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamsClient/ListStreams/main.go b/internal/generated/snippets/visionai/apiv1/StreamsClient/ListStreams/main.go index f0fca326fb87..f9a2edf11dcd 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamsClient/ListStreams/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamsClient/ListStreams/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamsClient/MaterializeChannel/main.go b/internal/generated/snippets/visionai/apiv1/StreamsClient/MaterializeChannel/main.go index 076d67c7ae49..7558af149744 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamsClient/MaterializeChannel/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamsClient/MaterializeChannel/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamsClient/UpdateCluster/main.go b/internal/generated/snippets/visionai/apiv1/StreamsClient/UpdateCluster/main.go index 94f380d27bb3..12c4879bfbba 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamsClient/UpdateCluster/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamsClient/UpdateCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamsClient/UpdateEvent/main.go b/internal/generated/snippets/visionai/apiv1/StreamsClient/UpdateEvent/main.go index a3f955bf50a0..70fff5cba12e 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamsClient/UpdateEvent/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamsClient/UpdateEvent/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamsClient/UpdateSeries/main.go b/internal/generated/snippets/visionai/apiv1/StreamsClient/UpdateSeries/main.go index 7c441b1a241e..957dddad77c8 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamsClient/UpdateSeries/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamsClient/UpdateSeries/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/StreamsClient/UpdateStream/main.go b/internal/generated/snippets/visionai/apiv1/StreamsClient/UpdateStream/main.go index 67a59564e552..893f380ccb8f 100644 --- a/internal/generated/snippets/visionai/apiv1/StreamsClient/UpdateStream/main.go +++ b/internal/generated/snippets/visionai/apiv1/StreamsClient/UpdateStream/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/AddCollectionItem/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/AddCollectionItem/main.go index 16cc1e49908d..5745cd0f685b 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/AddCollectionItem/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/AddCollectionItem/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/AnalyzeAsset/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/AnalyzeAsset/main.go index a5f1d09701a7..bf142f3566f1 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/AnalyzeAsset/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/AnalyzeAsset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/AnalyzeCorpus/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/AnalyzeCorpus/main.go index c675f8589b20..ced0f6d9016a 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/AnalyzeCorpus/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/AnalyzeCorpus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/CancelOperation/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/CancelOperation/main.go index db053304c4ef..cd69dc55f70f 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/CancelOperation/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/ClipAsset/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/ClipAsset/main.go index b4df07612572..8fb47466cd40 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/ClipAsset/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/ClipAsset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateAnnotation/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateAnnotation/main.go index fac4a1db171b..f61de27e7916 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateAnnotation/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateAnnotation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateAsset/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateAsset/main.go index c0c3851a1e40..d5efe3f25ef6 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateAsset/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateAsset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateCollection/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateCollection/main.go index 282af580975f..79f888cc68f5 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateCollection/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateCollection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateCorpus/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateCorpus/main.go index 8dd07b075d1a..4d16795a6395 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateCorpus/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateCorpus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateDataSchema/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateDataSchema/main.go index 1bd4427bb61d..f62d64387cbb 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateDataSchema/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateDataSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateIndex/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateIndex/main.go index fb6138eb0a30..4237ef05acd8 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateIndex/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateIndex/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateIndexEndpoint/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateIndexEndpoint/main.go index 31e7f355741d..12fadc538847 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateIndexEndpoint/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateIndexEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateSearchConfig/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateSearchConfig/main.go index ef4c7e572101..03ee605b499c 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateSearchConfig/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateSearchConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateSearchHypernym/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateSearchHypernym/main.go index 32c50316752c..e20aebdc243d 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateSearchHypernym/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/CreateSearchHypernym/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteAnnotation/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteAnnotation/main.go index d1d0fe951095..2ae67db0bf77 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteAnnotation/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteAnnotation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteAsset/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteAsset/main.go index b9b8e5fda0c8..6396b81053c1 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteAsset/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteAsset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteCollection/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteCollection/main.go index 59e613a13d5a..8478047f2ab0 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteCollection/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteCollection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteCorpus/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteCorpus/main.go index 617e07604df0..87f9387ef2fb 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteCorpus/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteCorpus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteDataSchema/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteDataSchema/main.go index fe2113672600..1090f9038811 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteDataSchema/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteDataSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteIndex/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteIndex/main.go index a6b05b7ef930..983eb7a61798 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteIndex/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteIndex/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteIndexEndpoint/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteIndexEndpoint/main.go index ab5608c3bee1..1eab9041501b 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteIndexEndpoint/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteIndexEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteOperation/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteOperation/main.go index 3d6bfe96d79b..2f68d83f6019 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteOperation/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteSearchConfig/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteSearchConfig/main.go index 2dcccf6c7a63..1149377461b9 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteSearchConfig/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteSearchConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteSearchHypernym/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteSearchHypernym/main.go index eb547b358d47..c8e5b660229c 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteSearchHypernym/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeleteSearchHypernym/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeployIndex/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeployIndex/main.go index d0d24dec3099..2b59ad64b578 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeployIndex/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/DeployIndex/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/GenerateHlsUri/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/GenerateHlsUri/main.go index 09e77fe07a16..a59a576d64fc 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/GenerateHlsUri/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/GenerateHlsUri/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/GenerateRetrievalUrl/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/GenerateRetrievalUrl/main.go index 333d7e89c22f..75745d916b8a 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/GenerateRetrievalUrl/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/GenerateRetrievalUrl/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetAnnotation/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetAnnotation/main.go index 317396b58cde..d5c6e67f7af5 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetAnnotation/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetAnnotation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetAsset/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetAsset/main.go index a587d411c843..2fc3d46ea048 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetAsset/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetAsset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetCollection/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetCollection/main.go index d3e954d22a10..cc166a6463b8 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetCollection/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetCollection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetCorpus/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetCorpus/main.go index df784d424ca8..0a5f2df8f7a8 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetCorpus/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetCorpus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetDataSchema/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetDataSchema/main.go index 5423c60c6d3a..a44182afeed9 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetDataSchema/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetDataSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetIndex/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetIndex/main.go index 07fd901febcb..a83180adce11 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetIndex/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetIndex/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetIndexEndpoint/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetIndexEndpoint/main.go index c447cd2d7fa2..beb3b69109ce 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetIndexEndpoint/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetIndexEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetOperation/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetOperation/main.go index bbc7cbc36298..682cda9d0589 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetOperation/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetSearchConfig/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetSearchConfig/main.go index 01d763b28afe..39db185c4813 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetSearchConfig/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetSearchConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetSearchHypernym/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetSearchHypernym/main.go index 624e19b9e4ba..7c6316a88280 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetSearchHypernym/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/GetSearchHypernym/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/ImportAssets/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/ImportAssets/main.go index e89921f4772f..d61040d8f575 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/ImportAssets/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/ImportAssets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/IndexAsset/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/IndexAsset/main.go index 313da04c4f44..1a6902b82664 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/IndexAsset/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/IndexAsset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/IngestAsset/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/IngestAsset/main.go index b7d37968d8ac..e194e6de68b4 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/IngestAsset/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/IngestAsset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListAnnotations/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListAnnotations/main.go index 8b484af3bf6d..0aa6a67b8565 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListAnnotations/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListAnnotations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListAssets/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListAssets/main.go index b0b1972ae58a..46b8ae789196 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListAssets/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListAssets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListCollections/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListCollections/main.go index a9f01b22aba0..b7a5005ca6db 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListCollections/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListCollections/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListCorpora/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListCorpora/main.go index 113409f3396f..efb403abbb10 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListCorpora/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListCorpora/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListDataSchemas/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListDataSchemas/main.go index d5078f7a7a00..a86664f4d317 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListDataSchemas/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListDataSchemas/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListIndexEndpoints/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListIndexEndpoints/main.go index 43cfd8aec079..89f9396534d9 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListIndexEndpoints/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListIndexEndpoints/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListIndexes/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListIndexes/main.go index 7f7c4d72cae9..49c8199b730c 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListIndexes/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListIndexes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListOperations/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListOperations/main.go index 11c06a5b9b13..b43e05422d85 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListOperations/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListSearchConfigs/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListSearchConfigs/main.go index 4800e4a0bd98..853852c800e8 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListSearchConfigs/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListSearchConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListSearchHypernyms/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListSearchHypernyms/main.go index 723a56b55ca0..3189c0ed1cd5 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListSearchHypernyms/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/ListSearchHypernyms/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/RemoveCollectionItem/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/RemoveCollectionItem/main.go index 52c17b68be69..416166db6107 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/RemoveCollectionItem/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/RemoveCollectionItem/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/RemoveIndexAsset/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/RemoveIndexAsset/main.go index 3e0448f47429..14ec655b9e2e 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/RemoveIndexAsset/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/RemoveIndexAsset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/SearchAssets/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/SearchAssets/main.go index ef823acba391..d5069a944b60 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/SearchAssets/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/SearchAssets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/SearchIndexEndpoint/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/SearchIndexEndpoint/main.go index eb9d747b3c70..4ddf018cd161 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/SearchIndexEndpoint/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/SearchIndexEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/UndeployIndex/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/UndeployIndex/main.go index 82b5bae02f3d..5bf4186ec333 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/UndeployIndex/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/UndeployIndex/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateAnnotation/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateAnnotation/main.go index a32b07ed4252..3a7fddfd0e8d 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateAnnotation/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateAnnotation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateAsset/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateAsset/main.go index 80d5c233ae9e..0e7dabbdba2c 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateAsset/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateAsset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateCollection/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateCollection/main.go index 90e37ff3ecdc..c32b30919522 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateCollection/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateCollection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateCorpus/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateCorpus/main.go index 850f64d7bb7f..db95679196d0 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateCorpus/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateCorpus/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateDataSchema/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateDataSchema/main.go index a3cfcca3fe57..9a9a34818317 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateDataSchema/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateDataSchema/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateIndex/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateIndex/main.go index 01ef58b3bcdb..a3cb57eb7ae9 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateIndex/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateIndex/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateIndexEndpoint/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateIndexEndpoint/main.go index 5104d5934782..f2facbafdb99 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateIndexEndpoint/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateIndexEndpoint/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateSearchConfig/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateSearchConfig/main.go index e6a4bc0d692f..1fdbef7bd2fc 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateSearchConfig/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateSearchConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateSearchHypernym/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateSearchHypernym/main.go index 48558a1cfdda..e3384d9f9204 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateSearchHypernym/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/UpdateSearchHypernym/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/UploadAsset/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/UploadAsset/main.go index edc70fe95685..845aa3352b06 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/UploadAsset/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/UploadAsset/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/ViewCollectionItems/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/ViewCollectionItems/main.go index b625a37089e2..844ed0ec65b6 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/ViewCollectionItems/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/ViewCollectionItems/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/WarehouseClient/ViewIndexedAssets/main.go b/internal/generated/snippets/visionai/apiv1/WarehouseClient/ViewIndexedAssets/main.go index d7f02b5f8519..afaf000ac00c 100644 --- a/internal/generated/snippets/visionai/apiv1/WarehouseClient/ViewIndexedAssets/main.go +++ b/internal/generated/snippets/visionai/apiv1/WarehouseClient/ViewIndexedAssets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/visionai/apiv1/snippet_metadata.google.cloud.visionai.v1.json b/internal/generated/snippets/visionai/apiv1/snippet_metadata.google.cloud.visionai.v1.json index c9a9d5e7a48f..e2e3cfab7073 100644 --- a/internal/generated/snippets/visionai/apiv1/snippet_metadata.google.cloud.visionai.v1.json +++ b/internal/generated/snippets/visionai/apiv1/snippet_metadata.google.cloud.visionai.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/visionai/apiv1", - "version": "0.4.2", + "version": "0.4.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/AddGroupMigration/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/AddGroupMigration/main.go index 445c2f86e1fc..15cd52220bc6 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/AddGroupMigration/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/AddGroupMigration/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/CancelCloneJob/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/CancelCloneJob/main.go index 2daf64c415c9..555a0a1a9cd6 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/CancelCloneJob/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/CancelCloneJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/CancelCutoverJob/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/CancelCutoverJob/main.go index 70cb63b12c71..2a6dc69b39a8 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/CancelCutoverJob/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/CancelCutoverJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/CancelOperation/main.go index 93f94acb3719..a6becda673b2 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/CreateCloneJob/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/CreateCloneJob/main.go index 4c20cf90f5bc..df04d9a23b65 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/CreateCloneJob/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/CreateCloneJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/CreateCutoverJob/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/CreateCutoverJob/main.go index b183d77a8c65..7552eea2f68b 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/CreateCutoverJob/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/CreateCutoverJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/CreateDatacenterConnector/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/CreateDatacenterConnector/main.go index bc0d1ec2259f..e06d22eca3c2 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/CreateDatacenterConnector/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/CreateDatacenterConnector/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/CreateGroup/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/CreateGroup/main.go index 0d23fa1a3e4d..7346bf363c46 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/CreateGroup/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/CreateGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/CreateMigratingVm/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/CreateMigratingVm/main.go index c448ad385920..74110e58b88b 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/CreateMigratingVm/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/CreateMigratingVm/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/CreateSource/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/CreateSource/main.go index ec10d94b15bf..2c7d0e1f5fbb 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/CreateSource/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/CreateSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/CreateTargetProject/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/CreateTargetProject/main.go index 870ec68a0423..17dcc0ac2487 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/CreateTargetProject/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/CreateTargetProject/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/CreateUtilizationReport/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/CreateUtilizationReport/main.go index bb25de4c406b..4547605486ee 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/CreateUtilizationReport/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/CreateUtilizationReport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/DeleteDatacenterConnector/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/DeleteDatacenterConnector/main.go index 2128bab3b0d0..9a83b88d9d70 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/DeleteDatacenterConnector/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/DeleteDatacenterConnector/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/DeleteGroup/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/DeleteGroup/main.go index 0c7ab9273ee3..e9f4e586c838 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/DeleteGroup/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/DeleteGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/DeleteMigratingVm/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/DeleteMigratingVm/main.go index bca79e14bfed..7f0be1927c2e 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/DeleteMigratingVm/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/DeleteMigratingVm/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/DeleteOperation/main.go index fb59c8518e07..ffcd915d0926 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/DeleteSource/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/DeleteSource/main.go index 6bb0562198d7..412128850e44 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/DeleteSource/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/DeleteSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/DeleteTargetProject/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/DeleteTargetProject/main.go index aa244f485e99..cdc8465f6858 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/DeleteTargetProject/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/DeleteTargetProject/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/DeleteUtilizationReport/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/DeleteUtilizationReport/main.go index a6da4627569f..ad9c102ed773 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/DeleteUtilizationReport/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/DeleteUtilizationReport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/FetchInventory/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/FetchInventory/main.go index bbeb471d24d3..bec8823a0b9e 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/FetchInventory/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/FetchInventory/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/FinalizeMigration/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/FinalizeMigration/main.go index e279bb304969..fa7c5757a429 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/FinalizeMigration/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/FinalizeMigration/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/GetCloneJob/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/GetCloneJob/main.go index 3815f29cbdd2..43eae071484f 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/GetCloneJob/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/GetCloneJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/GetCutoverJob/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/GetCutoverJob/main.go index ff5c7779f704..8dbc28226a91 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/GetCutoverJob/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/GetCutoverJob/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/GetDatacenterConnector/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/GetDatacenterConnector/main.go index deb03cde725b..bdde76ab0882 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/GetDatacenterConnector/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/GetDatacenterConnector/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/GetGroup/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/GetGroup/main.go index ff0bb0e9f74c..841b2c6fc55b 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/GetGroup/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/GetGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/GetLocation/main.go index 94b17f75d14d..f7986209a15b 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/GetMigratingVm/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/GetMigratingVm/main.go index 105783d5f54e..90c5ca0a33c7 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/GetMigratingVm/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/GetMigratingVm/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/GetOperation/main.go index 5dd15e5af8d8..d57cf6f2e500 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/GetReplicationCycle/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/GetReplicationCycle/main.go index f8514f6e9dd9..bdb6e0763852 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/GetReplicationCycle/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/GetReplicationCycle/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/GetSource/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/GetSource/main.go index 87726fdde712..ce50920174f5 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/GetSource/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/GetSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/GetTargetProject/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/GetTargetProject/main.go index 9158255c59fb..9a5f627a6301 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/GetTargetProject/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/GetTargetProject/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/GetUtilizationReport/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/GetUtilizationReport/main.go index b35063222647..82c9b189de0f 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/GetUtilizationReport/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/GetUtilizationReport/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/ListCloneJobs/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/ListCloneJobs/main.go index a4169a8b3ec9..687a7e6ee79e 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/ListCloneJobs/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/ListCloneJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/ListCutoverJobs/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/ListCutoverJobs/main.go index 712512331317..ecd9b465e3cb 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/ListCutoverJobs/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/ListCutoverJobs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/ListDatacenterConnectors/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/ListDatacenterConnectors/main.go index 4ba568cd5c4f..ef8acf544071 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/ListDatacenterConnectors/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/ListDatacenterConnectors/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/ListGroups/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/ListGroups/main.go index abf0e7f11c25..37e145313895 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/ListGroups/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/ListGroups/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/ListLocations/main.go index 726c7b748296..174ccec91f09 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/ListMigratingVms/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/ListMigratingVms/main.go index a603479c1685..c869fc31b742 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/ListMigratingVms/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/ListMigratingVms/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/ListOperations/main.go index 5b0d7828fe37..886d9fa60c00 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/ListReplicationCycles/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/ListReplicationCycles/main.go index bcbfb16ed6f5..e4358d5a04bf 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/ListReplicationCycles/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/ListReplicationCycles/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/ListSources/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/ListSources/main.go index aa298f26a64a..5a63a441b2b2 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/ListSources/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/ListSources/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/ListTargetProjects/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/ListTargetProjects/main.go index d720754cee14..a72767a5c5e5 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/ListTargetProjects/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/ListTargetProjects/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/ListUtilizationReports/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/ListUtilizationReports/main.go index 9ad02725d56c..eabd92584ddb 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/ListUtilizationReports/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/ListUtilizationReports/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/PauseMigration/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/PauseMigration/main.go index 46e8fbbca1b9..320aa7f538ce 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/PauseMigration/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/PauseMigration/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/RemoveGroupMigration/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/RemoveGroupMigration/main.go index e4e297ed6e35..d339c7151aba 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/RemoveGroupMigration/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/RemoveGroupMigration/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/ResumeMigration/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/ResumeMigration/main.go index 27c6bd41b72f..3cde32f8ccac 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/ResumeMigration/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/ResumeMigration/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/StartMigration/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/StartMigration/main.go index 2facde710667..2346b316a33d 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/StartMigration/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/StartMigration/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/UpdateGroup/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/UpdateGroup/main.go index 239cee966728..3a461d38cd98 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/UpdateGroup/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/UpdateGroup/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/UpdateMigratingVm/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/UpdateMigratingVm/main.go index 60d5292d8b6c..fe8f645c42ac 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/UpdateMigratingVm/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/UpdateMigratingVm/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/UpdateSource/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/UpdateSource/main.go index 9d9dd09da806..ee3f45f365ae 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/UpdateSource/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/UpdateSource/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/UpdateTargetProject/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/UpdateTargetProject/main.go index c5258f8544e0..cd30d35ee113 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/UpdateTargetProject/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/UpdateTargetProject/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmmigration/apiv1/Client/UpgradeAppliance/main.go b/internal/generated/snippets/vmmigration/apiv1/Client/UpgradeAppliance/main.go index 20032f8243d5..86c8dbefa5f1 100644 --- a/internal/generated/snippets/vmmigration/apiv1/Client/UpgradeAppliance/main.go +++ b/internal/generated/snippets/vmmigration/apiv1/Client/UpgradeAppliance/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/CreateCluster/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/CreateCluster/main.go index dff34f59b52a..608bf21e9a51 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/CreateCluster/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/CreateCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/CreateExternalAccessRule/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/CreateExternalAccessRule/main.go index 0ef2eb99d3c2..292e7d4e160e 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/CreateExternalAccessRule/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/CreateExternalAccessRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/CreateExternalAddress/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/CreateExternalAddress/main.go index 9a22e3b485de..1b6e2755d4ea 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/CreateExternalAddress/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/CreateExternalAddress/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/CreateHcxActivationKey/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/CreateHcxActivationKey/main.go index defb1d095d89..95ecef6ffc0b 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/CreateHcxActivationKey/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/CreateHcxActivationKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/CreateLoggingServer/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/CreateLoggingServer/main.go index c1ede32896ad..2d42a8e80bd1 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/CreateLoggingServer/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/CreateLoggingServer/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/CreateManagementDnsZoneBinding/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/CreateManagementDnsZoneBinding/main.go index 7ceb642a5fdf..12e9951834a9 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/CreateManagementDnsZoneBinding/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/CreateManagementDnsZoneBinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/CreateNetworkPeering/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/CreateNetworkPeering/main.go index 745ea6a5f07f..b4d4c8b0005a 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/CreateNetworkPeering/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/CreateNetworkPeering/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/CreateNetworkPolicy/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/CreateNetworkPolicy/main.go index b606be81bcfa..c6235cea304e 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/CreateNetworkPolicy/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/CreateNetworkPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/CreatePrivateCloud/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/CreatePrivateCloud/main.go index 05fa73e92883..eb992c77aa0d 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/CreatePrivateCloud/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/CreatePrivateCloud/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/CreatePrivateConnection/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/CreatePrivateConnection/main.go index af2215c4c893..eeb48a95a978 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/CreatePrivateConnection/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/CreatePrivateConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/CreateVmwareEngineNetwork/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/CreateVmwareEngineNetwork/main.go index f9f44fbab917..e5ad2894ea22 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/CreateVmwareEngineNetwork/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/CreateVmwareEngineNetwork/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteCluster/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteCluster/main.go index f22eb224d2b5..9aaab9ff151e 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteCluster/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteExternalAccessRule/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteExternalAccessRule/main.go index 1eb21448ba80..1552d9c148a1 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteExternalAccessRule/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteExternalAccessRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteExternalAddress/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteExternalAddress/main.go index e6152e690dde..beee2c2ed989 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteExternalAddress/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteExternalAddress/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteLoggingServer/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteLoggingServer/main.go index 97488e3e2d46..a16f3517bcaf 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteLoggingServer/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteLoggingServer/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteManagementDnsZoneBinding/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteManagementDnsZoneBinding/main.go index f25a79552325..24ef3a5912c8 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteManagementDnsZoneBinding/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteManagementDnsZoneBinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteNetworkPeering/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteNetworkPeering/main.go index 7268193dfc1c..c69bc4850e1e 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteNetworkPeering/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteNetworkPeering/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteNetworkPolicy/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteNetworkPolicy/main.go index 31c5b39ab57c..9b591393c197 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteNetworkPolicy/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteNetworkPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteOperation/main.go index c0020df095e7..c95e1ce1581e 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/DeletePrivateCloud/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/DeletePrivateCloud/main.go index 9bcb6fbc7614..d7a72b22244a 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/DeletePrivateCloud/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/DeletePrivateCloud/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/DeletePrivateConnection/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/DeletePrivateConnection/main.go index 1e05e6506310..8148483a354a 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/DeletePrivateConnection/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/DeletePrivateConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteVmwareEngineNetwork/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteVmwareEngineNetwork/main.go index d612bc3f2d4d..b2d98c773dcb 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteVmwareEngineNetwork/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/DeleteVmwareEngineNetwork/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/FetchNetworkPolicyExternalAddresses/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/FetchNetworkPolicyExternalAddresses/main.go index 7c78ebc9a0d5..53f9ccb84f7f 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/FetchNetworkPolicyExternalAddresses/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/FetchNetworkPolicyExternalAddresses/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/GetCluster/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/GetCluster/main.go index 8690563a4b10..7815d851bb3e 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/GetCluster/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/GetCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/GetDnsBindPermission/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/GetDnsBindPermission/main.go index 59243767c115..c7c2e712b4e0 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/GetDnsBindPermission/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/GetDnsBindPermission/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/GetDnsForwarding/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/GetDnsForwarding/main.go index 4910b151c237..19aed35e6ad9 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/GetDnsForwarding/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/GetDnsForwarding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/GetExternalAccessRule/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/GetExternalAccessRule/main.go index 08c0f026a568..a4a5514dddbe 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/GetExternalAccessRule/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/GetExternalAccessRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/GetExternalAddress/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/GetExternalAddress/main.go index 533a736b7114..f9f2068a6e31 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/GetExternalAddress/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/GetExternalAddress/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/GetHcxActivationKey/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/GetHcxActivationKey/main.go index 7f4b6a52083d..30806ea49f4e 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/GetHcxActivationKey/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/GetHcxActivationKey/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/GetIamPolicy/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/GetIamPolicy/main.go index 9a7f1e623102..508dbabdde7c 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/GetLocation/main.go index e4a7ce8a86b5..476ecb3bb588 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/GetLoggingServer/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/GetLoggingServer/main.go index b82e67ee6d1d..53e9ff94e97b 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/GetLoggingServer/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/GetLoggingServer/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/GetManagementDnsZoneBinding/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/GetManagementDnsZoneBinding/main.go index edf47ee172cd..aa8d858c4cad 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/GetManagementDnsZoneBinding/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/GetManagementDnsZoneBinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/GetNetworkPeering/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/GetNetworkPeering/main.go index ae4660cd0942..9190b3458216 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/GetNetworkPeering/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/GetNetworkPeering/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/GetNetworkPolicy/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/GetNetworkPolicy/main.go index 6b93880edf30..80e9df64dcd0 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/GetNetworkPolicy/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/GetNetworkPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/GetNode/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/GetNode/main.go index ee5ab2ff6814..586ed5879591 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/GetNode/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/GetNode/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/GetNodeType/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/GetNodeType/main.go index fb23f7e56fde..02838c1e4b73 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/GetNodeType/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/GetNodeType/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/GetOperation/main.go index 93271904d437..1ea974c5e5a6 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/GetPrivateCloud/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/GetPrivateCloud/main.go index 2d8cc911f671..6c2d461931d5 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/GetPrivateCloud/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/GetPrivateCloud/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/GetPrivateConnection/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/GetPrivateConnection/main.go index ad76d717b519..071833f7887e 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/GetPrivateConnection/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/GetPrivateConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/GetSubnet/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/GetSubnet/main.go index 65a33cee27f3..45b81c8f8eb9 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/GetSubnet/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/GetSubnet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/GetVmwareEngineNetwork/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/GetVmwareEngineNetwork/main.go index cb4b759ac94b..e04a220c2480 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/GetVmwareEngineNetwork/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/GetVmwareEngineNetwork/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/GrantDnsBindPermission/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/GrantDnsBindPermission/main.go index d16d138ce729..dbf57a53083d 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/GrantDnsBindPermission/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/GrantDnsBindPermission/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/ListClusters/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/ListClusters/main.go index c2d48ac39992..2f0cf5a2a1fe 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/ListClusters/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/ListClusters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/ListExternalAccessRules/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/ListExternalAccessRules/main.go index 01e238f90c2c..7fd6cab90bb3 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/ListExternalAccessRules/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/ListExternalAccessRules/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/ListExternalAddresses/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/ListExternalAddresses/main.go index de3586cf8e8d..a4182b22a5b0 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/ListExternalAddresses/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/ListExternalAddresses/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/ListHcxActivationKeys/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/ListHcxActivationKeys/main.go index b6bc836154ee..eef93a6605ef 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/ListHcxActivationKeys/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/ListHcxActivationKeys/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/ListLocations/main.go index e740debae9dc..28bb8111b304 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/ListLoggingServers/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/ListLoggingServers/main.go index 47c01713d0a2..864e75883cb0 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/ListLoggingServers/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/ListLoggingServers/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/ListManagementDnsZoneBindings/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/ListManagementDnsZoneBindings/main.go index bd4a076102e3..240d873c5d4f 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/ListManagementDnsZoneBindings/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/ListManagementDnsZoneBindings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/ListNetworkPeerings/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/ListNetworkPeerings/main.go index 3c9565b14b60..7ea88174b7af 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/ListNetworkPeerings/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/ListNetworkPeerings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/ListNetworkPolicies/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/ListNetworkPolicies/main.go index f2608a6f91bd..d405cb20421a 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/ListNetworkPolicies/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/ListNetworkPolicies/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/ListNodeTypes/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/ListNodeTypes/main.go index f4688643e912..f793904f651e 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/ListNodeTypes/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/ListNodeTypes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/ListNodes/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/ListNodes/main.go index 9d8b7d238303..b089763bad26 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/ListNodes/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/ListNodes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/ListOperations/main.go index a083ea445431..3a8209d3fa00 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/ListPeeringRoutes/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/ListPeeringRoutes/main.go index c67fdd3aa21d..3a25304afc7b 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/ListPeeringRoutes/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/ListPeeringRoutes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/ListPrivateClouds/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/ListPrivateClouds/main.go index 5e93da06b935..fdcbfea01581 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/ListPrivateClouds/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/ListPrivateClouds/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/ListPrivateConnectionPeeringRoutes/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/ListPrivateConnectionPeeringRoutes/main.go index c7549f06d001..e1e7a1b204a8 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/ListPrivateConnectionPeeringRoutes/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/ListPrivateConnectionPeeringRoutes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/ListPrivateConnections/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/ListPrivateConnections/main.go index 43d903c8505c..057f483655d0 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/ListPrivateConnections/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/ListPrivateConnections/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/ListSubnets/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/ListSubnets/main.go index aa85bfc104bb..26f8a8e253a6 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/ListSubnets/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/ListSubnets/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/ListVmwareEngineNetworks/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/ListVmwareEngineNetworks/main.go index 18ba2bfccf57..4b08187fcdf3 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/ListVmwareEngineNetworks/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/ListVmwareEngineNetworks/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/RepairManagementDnsZoneBinding/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/RepairManagementDnsZoneBinding/main.go index 491fdc7fe9a1..0b90c9c52d08 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/RepairManagementDnsZoneBinding/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/RepairManagementDnsZoneBinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/ResetNsxCredentials/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/ResetNsxCredentials/main.go index c519c89e5b15..77cea59db338 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/ResetNsxCredentials/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/ResetNsxCredentials/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/ResetVcenterCredentials/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/ResetVcenterCredentials/main.go index f00ce1b996eb..2c838c466125 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/ResetVcenterCredentials/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/ResetVcenterCredentials/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/RevokeDnsBindPermission/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/RevokeDnsBindPermission/main.go index 8d51ccf63069..e40c6115a4af 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/RevokeDnsBindPermission/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/RevokeDnsBindPermission/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/SetIamPolicy/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/SetIamPolicy/main.go index 16164c376a9c..4267e38394b7 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/ShowNsxCredentials/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/ShowNsxCredentials/main.go index 1f5031a48ab8..0c3543c49162 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/ShowNsxCredentials/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/ShowNsxCredentials/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/ShowVcenterCredentials/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/ShowVcenterCredentials/main.go index 2b8bd3ee66dc..8926ea8e88e7 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/ShowVcenterCredentials/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/ShowVcenterCredentials/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/TestIamPermissions/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/TestIamPermissions/main.go index afaf07e37366..c1e60f75dfb8 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/UndeletePrivateCloud/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/UndeletePrivateCloud/main.go index d24788a52b4a..fd82c3f4c67c 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/UndeletePrivateCloud/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/UndeletePrivateCloud/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateCluster/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateCluster/main.go index 123fdacb106d..5c93d7bee249 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateCluster/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateDnsForwarding/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateDnsForwarding/main.go index 0be7b33b9fac..72f8e74de590 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateDnsForwarding/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateDnsForwarding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateExternalAccessRule/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateExternalAccessRule/main.go index 6b2cb22d49ae..8688b54344d4 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateExternalAccessRule/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateExternalAccessRule/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateExternalAddress/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateExternalAddress/main.go index 3e5d3faca3d7..0b1caf1c93eb 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateExternalAddress/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateExternalAddress/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateLoggingServer/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateLoggingServer/main.go index 9114e7a3e062..8d7d58d3f43f 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateLoggingServer/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateLoggingServer/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateManagementDnsZoneBinding/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateManagementDnsZoneBinding/main.go index cfe67fe9cb96..fb2c25097114 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateManagementDnsZoneBinding/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateManagementDnsZoneBinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateNetworkPeering/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateNetworkPeering/main.go index 451e8a35e073..c3bc48b52323 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateNetworkPeering/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateNetworkPeering/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateNetworkPolicy/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateNetworkPolicy/main.go index 2b6825bcecf4..12462a404e32 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateNetworkPolicy/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateNetworkPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/UpdatePrivateCloud/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/UpdatePrivateCloud/main.go index d28b24337512..fe9ff0d4aba3 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/UpdatePrivateCloud/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/UpdatePrivateCloud/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/UpdatePrivateConnection/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/UpdatePrivateConnection/main.go index 372f5e9de4b0..256d7a5a98a5 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/UpdatePrivateConnection/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/UpdatePrivateConnection/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateSubnet/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateSubnet/main.go index 407260e757f2..e245c299e353 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateSubnet/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateSubnet/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateVmwareEngineNetwork/main.go b/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateVmwareEngineNetwork/main.go index 018aae628c9a..bed1dbc7a732 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateVmwareEngineNetwork/main.go +++ b/internal/generated/snippets/vmwareengine/apiv1/Client/UpdateVmwareEngineNetwork/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vmwareengine/apiv1/snippet_metadata.google.cloud.vmwareengine.v1.json b/internal/generated/snippets/vmwareengine/apiv1/snippet_metadata.google.cloud.vmwareengine.v1.json index e3c39f647e87..2e3e4d026c3a 100644 --- a/internal/generated/snippets/vmwareengine/apiv1/snippet_metadata.google.cloud.vmwareengine.v1.json +++ b/internal/generated/snippets/vmwareengine/apiv1/snippet_metadata.google.cloud.vmwareengine.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/vmwareengine/apiv1", - "version": "1.3.2", + "version": "1.3.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/vpcaccess/apiv1/Client/CreateConnector/main.go b/internal/generated/snippets/vpcaccess/apiv1/Client/CreateConnector/main.go index a6b4cda83b7d..b942f6288c02 100644 --- a/internal/generated/snippets/vpcaccess/apiv1/Client/CreateConnector/main.go +++ b/internal/generated/snippets/vpcaccess/apiv1/Client/CreateConnector/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vpcaccess/apiv1/Client/DeleteConnector/main.go b/internal/generated/snippets/vpcaccess/apiv1/Client/DeleteConnector/main.go index 79d48cabdb75..60490b1e2982 100644 --- a/internal/generated/snippets/vpcaccess/apiv1/Client/DeleteConnector/main.go +++ b/internal/generated/snippets/vpcaccess/apiv1/Client/DeleteConnector/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vpcaccess/apiv1/Client/GetConnector/main.go b/internal/generated/snippets/vpcaccess/apiv1/Client/GetConnector/main.go index cfd439c91fbe..aa9309b5566b 100644 --- a/internal/generated/snippets/vpcaccess/apiv1/Client/GetConnector/main.go +++ b/internal/generated/snippets/vpcaccess/apiv1/Client/GetConnector/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vpcaccess/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/vpcaccess/apiv1/Client/GetOperation/main.go index f1dfef97fd36..e8fffba1e301 100644 --- a/internal/generated/snippets/vpcaccess/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/vpcaccess/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vpcaccess/apiv1/Client/ListConnectors/main.go b/internal/generated/snippets/vpcaccess/apiv1/Client/ListConnectors/main.go index f11f4edaaa22..d71c24cfd86f 100644 --- a/internal/generated/snippets/vpcaccess/apiv1/Client/ListConnectors/main.go +++ b/internal/generated/snippets/vpcaccess/apiv1/Client/ListConnectors/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vpcaccess/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/vpcaccess/apiv1/Client/ListLocations/main.go index 22a84eb8827b..5c0434475cae 100644 --- a/internal/generated/snippets/vpcaccess/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/vpcaccess/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/vpcaccess/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/vpcaccess/apiv1/Client/ListOperations/main.go index 2066d2d0d406..b8a627de857a 100644 --- a/internal/generated/snippets/vpcaccess/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/vpcaccess/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/webrisk/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/webrisk/apiv1/Client/CancelOperation/main.go index 0bb80b1069ac..1650e766170d 100644 --- a/internal/generated/snippets/webrisk/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/webrisk/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/webrisk/apiv1/Client/ComputeThreatListDiff/main.go b/internal/generated/snippets/webrisk/apiv1/Client/ComputeThreatListDiff/main.go index 1ff07a72e603..6985175f76da 100644 --- a/internal/generated/snippets/webrisk/apiv1/Client/ComputeThreatListDiff/main.go +++ b/internal/generated/snippets/webrisk/apiv1/Client/ComputeThreatListDiff/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/webrisk/apiv1/Client/CreateSubmission/main.go b/internal/generated/snippets/webrisk/apiv1/Client/CreateSubmission/main.go index d352556dafe3..dcdb3dae281a 100644 --- a/internal/generated/snippets/webrisk/apiv1/Client/CreateSubmission/main.go +++ b/internal/generated/snippets/webrisk/apiv1/Client/CreateSubmission/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/webrisk/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/webrisk/apiv1/Client/DeleteOperation/main.go index 4fc663531360..55810b0b1093 100644 --- a/internal/generated/snippets/webrisk/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/webrisk/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/webrisk/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/webrisk/apiv1/Client/GetOperation/main.go index 812034f20e5b..3f9c548307e0 100644 --- a/internal/generated/snippets/webrisk/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/webrisk/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/webrisk/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/webrisk/apiv1/Client/ListOperations/main.go index 89aa7a04de4a..37d2e35f1fde 100644 --- a/internal/generated/snippets/webrisk/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/webrisk/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/webrisk/apiv1/Client/SearchHashes/main.go b/internal/generated/snippets/webrisk/apiv1/Client/SearchHashes/main.go index 55b79e4cba76..545794fab6a0 100644 --- a/internal/generated/snippets/webrisk/apiv1/Client/SearchHashes/main.go +++ b/internal/generated/snippets/webrisk/apiv1/Client/SearchHashes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/webrisk/apiv1/Client/SearchUris/main.go b/internal/generated/snippets/webrisk/apiv1/Client/SearchUris/main.go index a3c850545c50..16f49a413f2e 100644 --- a/internal/generated/snippets/webrisk/apiv1/Client/SearchUris/main.go +++ b/internal/generated/snippets/webrisk/apiv1/Client/SearchUris/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/webrisk/apiv1/Client/SubmitUri/main.go b/internal/generated/snippets/webrisk/apiv1/Client/SubmitUri/main.go index c21b5f8ca6a8..812a2128cef0 100644 --- a/internal/generated/snippets/webrisk/apiv1/Client/SubmitUri/main.go +++ b/internal/generated/snippets/webrisk/apiv1/Client/SubmitUri/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/webrisk/apiv1beta1/WebRiskServiceV1Beta1Client/ComputeThreatListDiff/main.go b/internal/generated/snippets/webrisk/apiv1beta1/WebRiskServiceV1Beta1Client/ComputeThreatListDiff/main.go index 03e7337646e7..330da96c4adb 100644 --- a/internal/generated/snippets/webrisk/apiv1beta1/WebRiskServiceV1Beta1Client/ComputeThreatListDiff/main.go +++ b/internal/generated/snippets/webrisk/apiv1beta1/WebRiskServiceV1Beta1Client/ComputeThreatListDiff/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/webrisk/apiv1beta1/WebRiskServiceV1Beta1Client/SearchHashes/main.go b/internal/generated/snippets/webrisk/apiv1beta1/WebRiskServiceV1Beta1Client/SearchHashes/main.go index 66f9db96a043..85505be32a6b 100644 --- a/internal/generated/snippets/webrisk/apiv1beta1/WebRiskServiceV1Beta1Client/SearchHashes/main.go +++ b/internal/generated/snippets/webrisk/apiv1beta1/WebRiskServiceV1Beta1Client/SearchHashes/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/webrisk/apiv1beta1/WebRiskServiceV1Beta1Client/SearchUris/main.go b/internal/generated/snippets/webrisk/apiv1beta1/WebRiskServiceV1Beta1Client/SearchUris/main.go index 4f0220987b8c..00a7eca93020 100644 --- a/internal/generated/snippets/webrisk/apiv1beta1/WebRiskServiceV1Beta1Client/SearchUris/main.go +++ b/internal/generated/snippets/webrisk/apiv1beta1/WebRiskServiceV1Beta1Client/SearchUris/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/websecurityscanner/apiv1/Client/CreateScanConfig/main.go b/internal/generated/snippets/websecurityscanner/apiv1/Client/CreateScanConfig/main.go index ce84edbb8f58..162b5e3fa188 100644 --- a/internal/generated/snippets/websecurityscanner/apiv1/Client/CreateScanConfig/main.go +++ b/internal/generated/snippets/websecurityscanner/apiv1/Client/CreateScanConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/websecurityscanner/apiv1/Client/DeleteScanConfig/main.go b/internal/generated/snippets/websecurityscanner/apiv1/Client/DeleteScanConfig/main.go index bab4f663bebd..0872565b61f9 100644 --- a/internal/generated/snippets/websecurityscanner/apiv1/Client/DeleteScanConfig/main.go +++ b/internal/generated/snippets/websecurityscanner/apiv1/Client/DeleteScanConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/websecurityscanner/apiv1/Client/GetFinding/main.go b/internal/generated/snippets/websecurityscanner/apiv1/Client/GetFinding/main.go index e385a5688ef3..7d6877d9e0f5 100644 --- a/internal/generated/snippets/websecurityscanner/apiv1/Client/GetFinding/main.go +++ b/internal/generated/snippets/websecurityscanner/apiv1/Client/GetFinding/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/websecurityscanner/apiv1/Client/GetScanConfig/main.go b/internal/generated/snippets/websecurityscanner/apiv1/Client/GetScanConfig/main.go index fdc51d238f0e..34d5900d80a2 100644 --- a/internal/generated/snippets/websecurityscanner/apiv1/Client/GetScanConfig/main.go +++ b/internal/generated/snippets/websecurityscanner/apiv1/Client/GetScanConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/websecurityscanner/apiv1/Client/GetScanRun/main.go b/internal/generated/snippets/websecurityscanner/apiv1/Client/GetScanRun/main.go index d168c46d712a..45c51cbc2021 100644 --- a/internal/generated/snippets/websecurityscanner/apiv1/Client/GetScanRun/main.go +++ b/internal/generated/snippets/websecurityscanner/apiv1/Client/GetScanRun/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/websecurityscanner/apiv1/Client/ListCrawledUrls/main.go b/internal/generated/snippets/websecurityscanner/apiv1/Client/ListCrawledUrls/main.go index 70bbde8c0ab8..99e463484946 100644 --- a/internal/generated/snippets/websecurityscanner/apiv1/Client/ListCrawledUrls/main.go +++ b/internal/generated/snippets/websecurityscanner/apiv1/Client/ListCrawledUrls/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/websecurityscanner/apiv1/Client/ListFindingTypeStats/main.go b/internal/generated/snippets/websecurityscanner/apiv1/Client/ListFindingTypeStats/main.go index a8c7d84a3f4b..e12b36a5be53 100644 --- a/internal/generated/snippets/websecurityscanner/apiv1/Client/ListFindingTypeStats/main.go +++ b/internal/generated/snippets/websecurityscanner/apiv1/Client/ListFindingTypeStats/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/websecurityscanner/apiv1/Client/ListFindings/main.go b/internal/generated/snippets/websecurityscanner/apiv1/Client/ListFindings/main.go index a0752c802487..8763426c17c7 100644 --- a/internal/generated/snippets/websecurityscanner/apiv1/Client/ListFindings/main.go +++ b/internal/generated/snippets/websecurityscanner/apiv1/Client/ListFindings/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/websecurityscanner/apiv1/Client/ListScanConfigs/main.go b/internal/generated/snippets/websecurityscanner/apiv1/Client/ListScanConfigs/main.go index 503caade4838..abb51e19040e 100644 --- a/internal/generated/snippets/websecurityscanner/apiv1/Client/ListScanConfigs/main.go +++ b/internal/generated/snippets/websecurityscanner/apiv1/Client/ListScanConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/websecurityscanner/apiv1/Client/ListScanRuns/main.go b/internal/generated/snippets/websecurityscanner/apiv1/Client/ListScanRuns/main.go index 5b75d9ebd64e..2ca469a89dc4 100644 --- a/internal/generated/snippets/websecurityscanner/apiv1/Client/ListScanRuns/main.go +++ b/internal/generated/snippets/websecurityscanner/apiv1/Client/ListScanRuns/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/websecurityscanner/apiv1/Client/StartScanRun/main.go b/internal/generated/snippets/websecurityscanner/apiv1/Client/StartScanRun/main.go index f07818da73b3..f784e5d2b98b 100644 --- a/internal/generated/snippets/websecurityscanner/apiv1/Client/StartScanRun/main.go +++ b/internal/generated/snippets/websecurityscanner/apiv1/Client/StartScanRun/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/websecurityscanner/apiv1/Client/StopScanRun/main.go b/internal/generated/snippets/websecurityscanner/apiv1/Client/StopScanRun/main.go index 246c801fd2de..29a29366c241 100644 --- a/internal/generated/snippets/websecurityscanner/apiv1/Client/StopScanRun/main.go +++ b/internal/generated/snippets/websecurityscanner/apiv1/Client/StopScanRun/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/websecurityscanner/apiv1/Client/UpdateScanConfig/main.go b/internal/generated/snippets/websecurityscanner/apiv1/Client/UpdateScanConfig/main.go index 6e854fb6059b..3b7937436c02 100644 --- a/internal/generated/snippets/websecurityscanner/apiv1/Client/UpdateScanConfig/main.go +++ b/internal/generated/snippets/websecurityscanner/apiv1/Client/UpdateScanConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workflows/apiv1/Client/CreateWorkflow/main.go b/internal/generated/snippets/workflows/apiv1/Client/CreateWorkflow/main.go index 1d2b12f59a38..f0412fd22ffd 100644 --- a/internal/generated/snippets/workflows/apiv1/Client/CreateWorkflow/main.go +++ b/internal/generated/snippets/workflows/apiv1/Client/CreateWorkflow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workflows/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/workflows/apiv1/Client/DeleteOperation/main.go index 1163513cb1ab..23269b7f2371 100644 --- a/internal/generated/snippets/workflows/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/workflows/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workflows/apiv1/Client/DeleteWorkflow/main.go b/internal/generated/snippets/workflows/apiv1/Client/DeleteWorkflow/main.go index ce916e738f78..781bc61efa26 100644 --- a/internal/generated/snippets/workflows/apiv1/Client/DeleteWorkflow/main.go +++ b/internal/generated/snippets/workflows/apiv1/Client/DeleteWorkflow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workflows/apiv1/Client/GetLocation/main.go b/internal/generated/snippets/workflows/apiv1/Client/GetLocation/main.go index 0121dd3ccde7..64a1ba3b1c3f 100644 --- a/internal/generated/snippets/workflows/apiv1/Client/GetLocation/main.go +++ b/internal/generated/snippets/workflows/apiv1/Client/GetLocation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workflows/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/workflows/apiv1/Client/GetOperation/main.go index a19e5b4dfa31..38e92d0fd592 100644 --- a/internal/generated/snippets/workflows/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/workflows/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workflows/apiv1/Client/GetWorkflow/main.go b/internal/generated/snippets/workflows/apiv1/Client/GetWorkflow/main.go index 2c22e38e890a..24d6d7d5a87d 100644 --- a/internal/generated/snippets/workflows/apiv1/Client/GetWorkflow/main.go +++ b/internal/generated/snippets/workflows/apiv1/Client/GetWorkflow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workflows/apiv1/Client/ListLocations/main.go b/internal/generated/snippets/workflows/apiv1/Client/ListLocations/main.go index 9bb46599ff5e..20f13fd14fc2 100644 --- a/internal/generated/snippets/workflows/apiv1/Client/ListLocations/main.go +++ b/internal/generated/snippets/workflows/apiv1/Client/ListLocations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workflows/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/workflows/apiv1/Client/ListOperations/main.go index 9b84fb5bfd02..7012f9950ff6 100644 --- a/internal/generated/snippets/workflows/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/workflows/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workflows/apiv1/Client/ListWorkflows/main.go b/internal/generated/snippets/workflows/apiv1/Client/ListWorkflows/main.go index 655d4514b4e3..4c3a0aaf6a6c 100644 --- a/internal/generated/snippets/workflows/apiv1/Client/ListWorkflows/main.go +++ b/internal/generated/snippets/workflows/apiv1/Client/ListWorkflows/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workflows/apiv1/Client/UpdateWorkflow/main.go b/internal/generated/snippets/workflows/apiv1/Client/UpdateWorkflow/main.go index cfb829da6c6e..bfee208c357d 100644 --- a/internal/generated/snippets/workflows/apiv1/Client/UpdateWorkflow/main.go +++ b/internal/generated/snippets/workflows/apiv1/Client/UpdateWorkflow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workflows/apiv1beta/Client/CreateWorkflow/main.go b/internal/generated/snippets/workflows/apiv1beta/Client/CreateWorkflow/main.go index 7549356b426f..8e3d957fe698 100644 --- a/internal/generated/snippets/workflows/apiv1beta/Client/CreateWorkflow/main.go +++ b/internal/generated/snippets/workflows/apiv1beta/Client/CreateWorkflow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workflows/apiv1beta/Client/DeleteWorkflow/main.go b/internal/generated/snippets/workflows/apiv1beta/Client/DeleteWorkflow/main.go index e35d9ee09650..e066eb652490 100644 --- a/internal/generated/snippets/workflows/apiv1beta/Client/DeleteWorkflow/main.go +++ b/internal/generated/snippets/workflows/apiv1beta/Client/DeleteWorkflow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workflows/apiv1beta/Client/GetWorkflow/main.go b/internal/generated/snippets/workflows/apiv1beta/Client/GetWorkflow/main.go index dbefd755d3bf..c03ba95287ee 100644 --- a/internal/generated/snippets/workflows/apiv1beta/Client/GetWorkflow/main.go +++ b/internal/generated/snippets/workflows/apiv1beta/Client/GetWorkflow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workflows/apiv1beta/Client/ListWorkflows/main.go b/internal/generated/snippets/workflows/apiv1beta/Client/ListWorkflows/main.go index 169a70c7350f..04b8c6f182a0 100644 --- a/internal/generated/snippets/workflows/apiv1beta/Client/ListWorkflows/main.go +++ b/internal/generated/snippets/workflows/apiv1beta/Client/ListWorkflows/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workflows/apiv1beta/Client/UpdateWorkflow/main.go b/internal/generated/snippets/workflows/apiv1beta/Client/UpdateWorkflow/main.go index b9201b53cee2..b481e8ec986d 100644 --- a/internal/generated/snippets/workflows/apiv1beta/Client/UpdateWorkflow/main.go +++ b/internal/generated/snippets/workflows/apiv1beta/Client/UpdateWorkflow/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workflows/executions/apiv1/Client/CancelExecution/main.go b/internal/generated/snippets/workflows/executions/apiv1/Client/CancelExecution/main.go index ed08650fff23..95a84ecb7a03 100644 --- a/internal/generated/snippets/workflows/executions/apiv1/Client/CancelExecution/main.go +++ b/internal/generated/snippets/workflows/executions/apiv1/Client/CancelExecution/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workflows/executions/apiv1/Client/CreateExecution/main.go b/internal/generated/snippets/workflows/executions/apiv1/Client/CreateExecution/main.go index 8c56bc5e8b42..7af49d4387f5 100644 --- a/internal/generated/snippets/workflows/executions/apiv1/Client/CreateExecution/main.go +++ b/internal/generated/snippets/workflows/executions/apiv1/Client/CreateExecution/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workflows/executions/apiv1/Client/GetExecution/main.go b/internal/generated/snippets/workflows/executions/apiv1/Client/GetExecution/main.go index 0dcf825cfe7b..25682c644717 100644 --- a/internal/generated/snippets/workflows/executions/apiv1/Client/GetExecution/main.go +++ b/internal/generated/snippets/workflows/executions/apiv1/Client/GetExecution/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workflows/executions/apiv1/Client/ListExecutions/main.go b/internal/generated/snippets/workflows/executions/apiv1/Client/ListExecutions/main.go index 0bba6741e29b..00db1c13159b 100644 --- a/internal/generated/snippets/workflows/executions/apiv1/Client/ListExecutions/main.go +++ b/internal/generated/snippets/workflows/executions/apiv1/Client/ListExecutions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workflows/executions/apiv1beta/Client/CancelExecution/main.go b/internal/generated/snippets/workflows/executions/apiv1beta/Client/CancelExecution/main.go index 83577c899d1b..db09b198cfa8 100644 --- a/internal/generated/snippets/workflows/executions/apiv1beta/Client/CancelExecution/main.go +++ b/internal/generated/snippets/workflows/executions/apiv1beta/Client/CancelExecution/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workflows/executions/apiv1beta/Client/CreateExecution/main.go b/internal/generated/snippets/workflows/executions/apiv1beta/Client/CreateExecution/main.go index 03c4c9c1aff2..a6b8bd8ac63d 100644 --- a/internal/generated/snippets/workflows/executions/apiv1beta/Client/CreateExecution/main.go +++ b/internal/generated/snippets/workflows/executions/apiv1beta/Client/CreateExecution/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workflows/executions/apiv1beta/Client/GetExecution/main.go b/internal/generated/snippets/workflows/executions/apiv1beta/Client/GetExecution/main.go index 6b2439c70137..08c985f909c9 100644 --- a/internal/generated/snippets/workflows/executions/apiv1beta/Client/GetExecution/main.go +++ b/internal/generated/snippets/workflows/executions/apiv1beta/Client/GetExecution/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workflows/executions/apiv1beta/Client/ListExecutions/main.go b/internal/generated/snippets/workflows/executions/apiv1beta/Client/ListExecutions/main.go index d8e917dcefc4..907889e8784e 100644 --- a/internal/generated/snippets/workflows/executions/apiv1beta/Client/ListExecutions/main.go +++ b/internal/generated/snippets/workflows/executions/apiv1beta/Client/ListExecutions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1/Client/CancelOperation/main.go b/internal/generated/snippets/workstations/apiv1/Client/CancelOperation/main.go index ad0a8175b5e6..65584fa9039b 100644 --- a/internal/generated/snippets/workstations/apiv1/Client/CancelOperation/main.go +++ b/internal/generated/snippets/workstations/apiv1/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1/Client/CreateWorkstation/main.go b/internal/generated/snippets/workstations/apiv1/Client/CreateWorkstation/main.go index 82d75e701a0d..fdc7d85a6edd 100644 --- a/internal/generated/snippets/workstations/apiv1/Client/CreateWorkstation/main.go +++ b/internal/generated/snippets/workstations/apiv1/Client/CreateWorkstation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1/Client/CreateWorkstationCluster/main.go b/internal/generated/snippets/workstations/apiv1/Client/CreateWorkstationCluster/main.go index 1d0a6125dcaa..d423f135fccb 100644 --- a/internal/generated/snippets/workstations/apiv1/Client/CreateWorkstationCluster/main.go +++ b/internal/generated/snippets/workstations/apiv1/Client/CreateWorkstationCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1/Client/CreateWorkstationConfig/main.go b/internal/generated/snippets/workstations/apiv1/Client/CreateWorkstationConfig/main.go index 160ff5b487f9..e712aa47af16 100644 --- a/internal/generated/snippets/workstations/apiv1/Client/CreateWorkstationConfig/main.go +++ b/internal/generated/snippets/workstations/apiv1/Client/CreateWorkstationConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1/Client/DeleteOperation/main.go b/internal/generated/snippets/workstations/apiv1/Client/DeleteOperation/main.go index 15845fadd255..a42b52292987 100644 --- a/internal/generated/snippets/workstations/apiv1/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/workstations/apiv1/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1/Client/DeleteWorkstation/main.go b/internal/generated/snippets/workstations/apiv1/Client/DeleteWorkstation/main.go index fc39096c1b8b..9a0ad06f72af 100644 --- a/internal/generated/snippets/workstations/apiv1/Client/DeleteWorkstation/main.go +++ b/internal/generated/snippets/workstations/apiv1/Client/DeleteWorkstation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1/Client/DeleteWorkstationCluster/main.go b/internal/generated/snippets/workstations/apiv1/Client/DeleteWorkstationCluster/main.go index c4b26acd4eee..e00fe33bf472 100644 --- a/internal/generated/snippets/workstations/apiv1/Client/DeleteWorkstationCluster/main.go +++ b/internal/generated/snippets/workstations/apiv1/Client/DeleteWorkstationCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1/Client/DeleteWorkstationConfig/main.go b/internal/generated/snippets/workstations/apiv1/Client/DeleteWorkstationConfig/main.go index 6ac87ceecf2f..0e895e531c19 100644 --- a/internal/generated/snippets/workstations/apiv1/Client/DeleteWorkstationConfig/main.go +++ b/internal/generated/snippets/workstations/apiv1/Client/DeleteWorkstationConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1/Client/GenerateAccessToken/main.go b/internal/generated/snippets/workstations/apiv1/Client/GenerateAccessToken/main.go index f70cbbe010bb..73cee412e29a 100644 --- a/internal/generated/snippets/workstations/apiv1/Client/GenerateAccessToken/main.go +++ b/internal/generated/snippets/workstations/apiv1/Client/GenerateAccessToken/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1/Client/GetIamPolicy/main.go b/internal/generated/snippets/workstations/apiv1/Client/GetIamPolicy/main.go index 8c33bdfd28e5..754a59a52e56 100644 --- a/internal/generated/snippets/workstations/apiv1/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/workstations/apiv1/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1/Client/GetOperation/main.go b/internal/generated/snippets/workstations/apiv1/Client/GetOperation/main.go index 1f2ad444c82d..4a92f642447b 100644 --- a/internal/generated/snippets/workstations/apiv1/Client/GetOperation/main.go +++ b/internal/generated/snippets/workstations/apiv1/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1/Client/GetWorkstation/main.go b/internal/generated/snippets/workstations/apiv1/Client/GetWorkstation/main.go index 9c1aae927d4e..04d27a94990c 100644 --- a/internal/generated/snippets/workstations/apiv1/Client/GetWorkstation/main.go +++ b/internal/generated/snippets/workstations/apiv1/Client/GetWorkstation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1/Client/GetWorkstationCluster/main.go b/internal/generated/snippets/workstations/apiv1/Client/GetWorkstationCluster/main.go index b848a5a7fc19..ad01e1b8edb8 100644 --- a/internal/generated/snippets/workstations/apiv1/Client/GetWorkstationCluster/main.go +++ b/internal/generated/snippets/workstations/apiv1/Client/GetWorkstationCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1/Client/GetWorkstationConfig/main.go b/internal/generated/snippets/workstations/apiv1/Client/GetWorkstationConfig/main.go index 7aef9d3b4987..6036cc61196f 100644 --- a/internal/generated/snippets/workstations/apiv1/Client/GetWorkstationConfig/main.go +++ b/internal/generated/snippets/workstations/apiv1/Client/GetWorkstationConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1/Client/ListOperations/main.go b/internal/generated/snippets/workstations/apiv1/Client/ListOperations/main.go index 069acc44e622..9f1834f38883 100644 --- a/internal/generated/snippets/workstations/apiv1/Client/ListOperations/main.go +++ b/internal/generated/snippets/workstations/apiv1/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1/Client/ListUsableWorkstationConfigs/main.go b/internal/generated/snippets/workstations/apiv1/Client/ListUsableWorkstationConfigs/main.go index 63f9e9b8b482..86080abeb88d 100644 --- a/internal/generated/snippets/workstations/apiv1/Client/ListUsableWorkstationConfigs/main.go +++ b/internal/generated/snippets/workstations/apiv1/Client/ListUsableWorkstationConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1/Client/ListUsableWorkstations/main.go b/internal/generated/snippets/workstations/apiv1/Client/ListUsableWorkstations/main.go index 34d2236a132a..553a6acefa2e 100644 --- a/internal/generated/snippets/workstations/apiv1/Client/ListUsableWorkstations/main.go +++ b/internal/generated/snippets/workstations/apiv1/Client/ListUsableWorkstations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1/Client/ListWorkstationClusters/main.go b/internal/generated/snippets/workstations/apiv1/Client/ListWorkstationClusters/main.go index 62c61ec47647..c314c65e512f 100644 --- a/internal/generated/snippets/workstations/apiv1/Client/ListWorkstationClusters/main.go +++ b/internal/generated/snippets/workstations/apiv1/Client/ListWorkstationClusters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1/Client/ListWorkstationConfigs/main.go b/internal/generated/snippets/workstations/apiv1/Client/ListWorkstationConfigs/main.go index c9fca89b69a7..9bba9f9155a4 100644 --- a/internal/generated/snippets/workstations/apiv1/Client/ListWorkstationConfigs/main.go +++ b/internal/generated/snippets/workstations/apiv1/Client/ListWorkstationConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1/Client/ListWorkstations/main.go b/internal/generated/snippets/workstations/apiv1/Client/ListWorkstations/main.go index 6a5f1759333b..7ac0e89f704d 100644 --- a/internal/generated/snippets/workstations/apiv1/Client/ListWorkstations/main.go +++ b/internal/generated/snippets/workstations/apiv1/Client/ListWorkstations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1/Client/SetIamPolicy/main.go b/internal/generated/snippets/workstations/apiv1/Client/SetIamPolicy/main.go index 9918c532d420..f08748bbfb3f 100644 --- a/internal/generated/snippets/workstations/apiv1/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/workstations/apiv1/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1/Client/StartWorkstation/main.go b/internal/generated/snippets/workstations/apiv1/Client/StartWorkstation/main.go index 4e41a4c40974..5de92d9af24a 100644 --- a/internal/generated/snippets/workstations/apiv1/Client/StartWorkstation/main.go +++ b/internal/generated/snippets/workstations/apiv1/Client/StartWorkstation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1/Client/StopWorkstation/main.go b/internal/generated/snippets/workstations/apiv1/Client/StopWorkstation/main.go index 3a1e3986bd61..47ca97878f95 100644 --- a/internal/generated/snippets/workstations/apiv1/Client/StopWorkstation/main.go +++ b/internal/generated/snippets/workstations/apiv1/Client/StopWorkstation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1/Client/TestIamPermissions/main.go b/internal/generated/snippets/workstations/apiv1/Client/TestIamPermissions/main.go index e82d64afc483..686a69e22265 100644 --- a/internal/generated/snippets/workstations/apiv1/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/workstations/apiv1/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1/Client/UpdateWorkstation/main.go b/internal/generated/snippets/workstations/apiv1/Client/UpdateWorkstation/main.go index 8bac645ecdc0..1cee2454a24a 100644 --- a/internal/generated/snippets/workstations/apiv1/Client/UpdateWorkstation/main.go +++ b/internal/generated/snippets/workstations/apiv1/Client/UpdateWorkstation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1/Client/UpdateWorkstationCluster/main.go b/internal/generated/snippets/workstations/apiv1/Client/UpdateWorkstationCluster/main.go index 476ff1f9358d..73c05cdfbf64 100644 --- a/internal/generated/snippets/workstations/apiv1/Client/UpdateWorkstationCluster/main.go +++ b/internal/generated/snippets/workstations/apiv1/Client/UpdateWorkstationCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1/Client/UpdateWorkstationConfig/main.go b/internal/generated/snippets/workstations/apiv1/Client/UpdateWorkstationConfig/main.go index db5b6c0e00b6..893dc8b80c75 100644 --- a/internal/generated/snippets/workstations/apiv1/Client/UpdateWorkstationConfig/main.go +++ b/internal/generated/snippets/workstations/apiv1/Client/UpdateWorkstationConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1/snippet_metadata.google.cloud.workstations.v1.json b/internal/generated/snippets/workstations/apiv1/snippet_metadata.google.cloud.workstations.v1.json index 4c93da1e13d0..9977a8b525f2 100644 --- a/internal/generated/snippets/workstations/apiv1/snippet_metadata.google.cloud.workstations.v1.json +++ b/internal/generated/snippets/workstations/apiv1/snippet_metadata.google.cloud.workstations.v1.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/workstations/apiv1", - "version": "1.1.2", + "version": "1.1.3", "language": "GO", "apis": [ { diff --git a/internal/generated/snippets/workstations/apiv1beta/Client/CancelOperation/main.go b/internal/generated/snippets/workstations/apiv1beta/Client/CancelOperation/main.go index f11c682e1366..77920d1822ad 100644 --- a/internal/generated/snippets/workstations/apiv1beta/Client/CancelOperation/main.go +++ b/internal/generated/snippets/workstations/apiv1beta/Client/CancelOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1beta/Client/CreateWorkstation/main.go b/internal/generated/snippets/workstations/apiv1beta/Client/CreateWorkstation/main.go index a2bc4f00810b..c3b30b97b683 100644 --- a/internal/generated/snippets/workstations/apiv1beta/Client/CreateWorkstation/main.go +++ b/internal/generated/snippets/workstations/apiv1beta/Client/CreateWorkstation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1beta/Client/CreateWorkstationCluster/main.go b/internal/generated/snippets/workstations/apiv1beta/Client/CreateWorkstationCluster/main.go index 8193869c7c31..0dda3d50ca9f 100644 --- a/internal/generated/snippets/workstations/apiv1beta/Client/CreateWorkstationCluster/main.go +++ b/internal/generated/snippets/workstations/apiv1beta/Client/CreateWorkstationCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1beta/Client/CreateWorkstationConfig/main.go b/internal/generated/snippets/workstations/apiv1beta/Client/CreateWorkstationConfig/main.go index bf1d7cb7e24a..3c08824099ca 100644 --- a/internal/generated/snippets/workstations/apiv1beta/Client/CreateWorkstationConfig/main.go +++ b/internal/generated/snippets/workstations/apiv1beta/Client/CreateWorkstationConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1beta/Client/DeleteOperation/main.go b/internal/generated/snippets/workstations/apiv1beta/Client/DeleteOperation/main.go index 223f57d49b7e..37861bf7bed5 100644 --- a/internal/generated/snippets/workstations/apiv1beta/Client/DeleteOperation/main.go +++ b/internal/generated/snippets/workstations/apiv1beta/Client/DeleteOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1beta/Client/DeleteWorkstation/main.go b/internal/generated/snippets/workstations/apiv1beta/Client/DeleteWorkstation/main.go index 931070b1757c..19e1e4e48e12 100644 --- a/internal/generated/snippets/workstations/apiv1beta/Client/DeleteWorkstation/main.go +++ b/internal/generated/snippets/workstations/apiv1beta/Client/DeleteWorkstation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1beta/Client/DeleteWorkstationCluster/main.go b/internal/generated/snippets/workstations/apiv1beta/Client/DeleteWorkstationCluster/main.go index f7dd20c2d5da..6c56d51b4ab9 100644 --- a/internal/generated/snippets/workstations/apiv1beta/Client/DeleteWorkstationCluster/main.go +++ b/internal/generated/snippets/workstations/apiv1beta/Client/DeleteWorkstationCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1beta/Client/DeleteWorkstationConfig/main.go b/internal/generated/snippets/workstations/apiv1beta/Client/DeleteWorkstationConfig/main.go index 6823f8e3b925..6179b186dc0f 100644 --- a/internal/generated/snippets/workstations/apiv1beta/Client/DeleteWorkstationConfig/main.go +++ b/internal/generated/snippets/workstations/apiv1beta/Client/DeleteWorkstationConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1beta/Client/GenerateAccessToken/main.go b/internal/generated/snippets/workstations/apiv1beta/Client/GenerateAccessToken/main.go index 625ab983712b..e7bf54fb0b29 100644 --- a/internal/generated/snippets/workstations/apiv1beta/Client/GenerateAccessToken/main.go +++ b/internal/generated/snippets/workstations/apiv1beta/Client/GenerateAccessToken/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1beta/Client/GetIamPolicy/main.go b/internal/generated/snippets/workstations/apiv1beta/Client/GetIamPolicy/main.go index 0bf92b5dbfc4..e90928ebe7c8 100644 --- a/internal/generated/snippets/workstations/apiv1beta/Client/GetIamPolicy/main.go +++ b/internal/generated/snippets/workstations/apiv1beta/Client/GetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1beta/Client/GetOperation/main.go b/internal/generated/snippets/workstations/apiv1beta/Client/GetOperation/main.go index 4867ba7007c7..7dff54a67ecb 100644 --- a/internal/generated/snippets/workstations/apiv1beta/Client/GetOperation/main.go +++ b/internal/generated/snippets/workstations/apiv1beta/Client/GetOperation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1beta/Client/GetWorkstation/main.go b/internal/generated/snippets/workstations/apiv1beta/Client/GetWorkstation/main.go index 1b850ff6ef59..0f9438c17ee0 100644 --- a/internal/generated/snippets/workstations/apiv1beta/Client/GetWorkstation/main.go +++ b/internal/generated/snippets/workstations/apiv1beta/Client/GetWorkstation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1beta/Client/GetWorkstationCluster/main.go b/internal/generated/snippets/workstations/apiv1beta/Client/GetWorkstationCluster/main.go index ad674d3adffe..4b9891cfb425 100644 --- a/internal/generated/snippets/workstations/apiv1beta/Client/GetWorkstationCluster/main.go +++ b/internal/generated/snippets/workstations/apiv1beta/Client/GetWorkstationCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1beta/Client/GetWorkstationConfig/main.go b/internal/generated/snippets/workstations/apiv1beta/Client/GetWorkstationConfig/main.go index 46b51287fb00..0867bdddeba7 100644 --- a/internal/generated/snippets/workstations/apiv1beta/Client/GetWorkstationConfig/main.go +++ b/internal/generated/snippets/workstations/apiv1beta/Client/GetWorkstationConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1beta/Client/ListOperations/main.go b/internal/generated/snippets/workstations/apiv1beta/Client/ListOperations/main.go index 8226186db5df..7f33e24a96dd 100644 --- a/internal/generated/snippets/workstations/apiv1beta/Client/ListOperations/main.go +++ b/internal/generated/snippets/workstations/apiv1beta/Client/ListOperations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1beta/Client/ListUsableWorkstationConfigs/main.go b/internal/generated/snippets/workstations/apiv1beta/Client/ListUsableWorkstationConfigs/main.go index e3b14cd02f13..c2014204f269 100644 --- a/internal/generated/snippets/workstations/apiv1beta/Client/ListUsableWorkstationConfigs/main.go +++ b/internal/generated/snippets/workstations/apiv1beta/Client/ListUsableWorkstationConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1beta/Client/ListUsableWorkstations/main.go b/internal/generated/snippets/workstations/apiv1beta/Client/ListUsableWorkstations/main.go index a8bcc5939fb5..7330283b841a 100644 --- a/internal/generated/snippets/workstations/apiv1beta/Client/ListUsableWorkstations/main.go +++ b/internal/generated/snippets/workstations/apiv1beta/Client/ListUsableWorkstations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1beta/Client/ListWorkstationClusters/main.go b/internal/generated/snippets/workstations/apiv1beta/Client/ListWorkstationClusters/main.go index 59b297265f25..ca08d1be2538 100644 --- a/internal/generated/snippets/workstations/apiv1beta/Client/ListWorkstationClusters/main.go +++ b/internal/generated/snippets/workstations/apiv1beta/Client/ListWorkstationClusters/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1beta/Client/ListWorkstationConfigs/main.go b/internal/generated/snippets/workstations/apiv1beta/Client/ListWorkstationConfigs/main.go index 48275f32544e..f5655734dffa 100644 --- a/internal/generated/snippets/workstations/apiv1beta/Client/ListWorkstationConfigs/main.go +++ b/internal/generated/snippets/workstations/apiv1beta/Client/ListWorkstationConfigs/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1beta/Client/ListWorkstations/main.go b/internal/generated/snippets/workstations/apiv1beta/Client/ListWorkstations/main.go index 77200513de62..804f051ebb37 100644 --- a/internal/generated/snippets/workstations/apiv1beta/Client/ListWorkstations/main.go +++ b/internal/generated/snippets/workstations/apiv1beta/Client/ListWorkstations/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1beta/Client/SetIamPolicy/main.go b/internal/generated/snippets/workstations/apiv1beta/Client/SetIamPolicy/main.go index 85de2c1593c1..3af76b40b88f 100644 --- a/internal/generated/snippets/workstations/apiv1beta/Client/SetIamPolicy/main.go +++ b/internal/generated/snippets/workstations/apiv1beta/Client/SetIamPolicy/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1beta/Client/StartWorkstation/main.go b/internal/generated/snippets/workstations/apiv1beta/Client/StartWorkstation/main.go index 8a2bfd642fe5..016df36a7b3b 100644 --- a/internal/generated/snippets/workstations/apiv1beta/Client/StartWorkstation/main.go +++ b/internal/generated/snippets/workstations/apiv1beta/Client/StartWorkstation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1beta/Client/StopWorkstation/main.go b/internal/generated/snippets/workstations/apiv1beta/Client/StopWorkstation/main.go index 592513e051e0..121da17feff1 100644 --- a/internal/generated/snippets/workstations/apiv1beta/Client/StopWorkstation/main.go +++ b/internal/generated/snippets/workstations/apiv1beta/Client/StopWorkstation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1beta/Client/TestIamPermissions/main.go b/internal/generated/snippets/workstations/apiv1beta/Client/TestIamPermissions/main.go index cd6293a0c2f6..6305fafdc1ff 100644 --- a/internal/generated/snippets/workstations/apiv1beta/Client/TestIamPermissions/main.go +++ b/internal/generated/snippets/workstations/apiv1beta/Client/TestIamPermissions/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1beta/Client/UpdateWorkstation/main.go b/internal/generated/snippets/workstations/apiv1beta/Client/UpdateWorkstation/main.go index e246f8059e79..0e14f711202d 100644 --- a/internal/generated/snippets/workstations/apiv1beta/Client/UpdateWorkstation/main.go +++ b/internal/generated/snippets/workstations/apiv1beta/Client/UpdateWorkstation/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1beta/Client/UpdateWorkstationCluster/main.go b/internal/generated/snippets/workstations/apiv1beta/Client/UpdateWorkstationCluster/main.go index ff71fa4b1d14..a2c669ccb9ff 100644 --- a/internal/generated/snippets/workstations/apiv1beta/Client/UpdateWorkstationCluster/main.go +++ b/internal/generated/snippets/workstations/apiv1beta/Client/UpdateWorkstationCluster/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1beta/Client/UpdateWorkstationConfig/main.go b/internal/generated/snippets/workstations/apiv1beta/Client/UpdateWorkstationConfig/main.go index 9967eefa38d4..9367cca549b1 100644 --- a/internal/generated/snippets/workstations/apiv1beta/Client/UpdateWorkstationConfig/main.go +++ b/internal/generated/snippets/workstations/apiv1beta/Client/UpdateWorkstationConfig/main.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/internal/generated/snippets/workstations/apiv1beta/snippet_metadata.google.cloud.workstations.v1beta.json b/internal/generated/snippets/workstations/apiv1beta/snippet_metadata.google.cloud.workstations.v1beta.json index 5f3655e92d23..b7700e39046a 100644 --- a/internal/generated/snippets/workstations/apiv1beta/snippet_metadata.google.cloud.workstations.v1beta.json +++ b/internal/generated/snippets/workstations/apiv1beta/snippet_metadata.google.cloud.workstations.v1beta.json @@ -1,7 +1,7 @@ { "clientLibrary": { "name": "cloud.google.com/go/workstations/apiv1beta", - "version": "1.1.2", + "version": "1.1.3", "language": "GO", "apis": [ { diff --git a/iot/apiv1/auxiliary.go b/iot/apiv1/auxiliary.go index 090eda66a2a7..1bcd8052f384 100755 --- a/iot/apiv1/auxiliary.go +++ b/iot/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iot/apiv1/auxiliary_go123.go b/iot/apiv1/auxiliary_go123.go index bbfc0d57b724..c806e84e0ef6 100755 --- a/iot/apiv1/auxiliary_go123.go +++ b/iot/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iot/apiv1/device_manager_client.go b/iot/apiv1/device_manager_client.go index 7f4397ea1559..94ccfe3cf17b 100755 --- a/iot/apiv1/device_manager_client.go +++ b/iot/apiv1/device_manager_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iot/apiv1/device_manager_client_example_go123_test.go b/iot/apiv1/device_manager_client_example_go123_test.go index 72604da9f86d..0d12a1b23ff2 100644 --- a/iot/apiv1/device_manager_client_example_go123_test.go +++ b/iot/apiv1/device_manager_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iot/apiv1/device_manager_client_example_test.go b/iot/apiv1/device_manager_client_example_test.go index dc12c020902f..3ff7ed1dfcea 100644 --- a/iot/apiv1/device_manager_client_example_test.go +++ b/iot/apiv1/device_manager_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iot/apiv1/doc.go b/iot/apiv1/doc.go index ab7d77cde13a..9f902071053e 100755 --- a/iot/apiv1/doc.go +++ b/iot/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/iot/apiv1/helpers.go b/iot/apiv1/helpers.go index 0d67abe6051f..340166526703 100755 --- a/iot/apiv1/helpers.go +++ b/iot/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/kms/apiv1/autokey_admin_client.go b/kms/apiv1/autokey_admin_client.go index 2e3add07f5ff..22b9eaa141a7 100755 --- a/kms/apiv1/autokey_admin_client.go +++ b/kms/apiv1/autokey_admin_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/kms/apiv1/autokey_admin_client_example_go123_test.go b/kms/apiv1/autokey_admin_client_example_go123_test.go index 3d7cd7130cd1..d6f29f222398 100644 --- a/kms/apiv1/autokey_admin_client_example_go123_test.go +++ b/kms/apiv1/autokey_admin_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/kms/apiv1/autokey_admin_client_example_test.go b/kms/apiv1/autokey_admin_client_example_test.go index ce79f0c3c86d..19a807a11cb7 100644 --- a/kms/apiv1/autokey_admin_client_example_test.go +++ b/kms/apiv1/autokey_admin_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/kms/apiv1/autokey_client.go b/kms/apiv1/autokey_client.go index d4c7c3bd6df4..7986a78e1d4f 100755 --- a/kms/apiv1/autokey_client.go +++ b/kms/apiv1/autokey_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/kms/apiv1/autokey_client_example_go123_test.go b/kms/apiv1/autokey_client_example_go123_test.go index 4e321012fc2c..be1007c661d6 100644 --- a/kms/apiv1/autokey_client_example_go123_test.go +++ b/kms/apiv1/autokey_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/kms/apiv1/autokey_client_example_test.go b/kms/apiv1/autokey_client_example_test.go index a56a411a041e..96d02a1d6da3 100644 --- a/kms/apiv1/autokey_client_example_test.go +++ b/kms/apiv1/autokey_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/kms/apiv1/auxiliary.go b/kms/apiv1/auxiliary.go index 57eff9a98df5..36e6bf84c1fc 100755 --- a/kms/apiv1/auxiliary.go +++ b/kms/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/kms/apiv1/auxiliary_go123.go b/kms/apiv1/auxiliary_go123.go index 7a8043ee9a24..b8517f3815e2 100755 --- a/kms/apiv1/auxiliary_go123.go +++ b/kms/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/kms/apiv1/doc.go b/kms/apiv1/doc.go index 8e9ced1a3b4f..7f85be3e6ca8 100755 --- a/kms/apiv1/doc.go +++ b/kms/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/kms/apiv1/ekm_client.go b/kms/apiv1/ekm_client.go index 7488bb432c5c..f7ef5ac46e70 100755 --- a/kms/apiv1/ekm_client.go +++ b/kms/apiv1/ekm_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/kms/apiv1/ekm_client_example_go123_test.go b/kms/apiv1/ekm_client_example_go123_test.go index 6077c15a3fb4..293a73653c99 100644 --- a/kms/apiv1/ekm_client_example_go123_test.go +++ b/kms/apiv1/ekm_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/kms/apiv1/ekm_client_example_test.go b/kms/apiv1/ekm_client_example_test.go index 912304317679..28490761f482 100644 --- a/kms/apiv1/ekm_client_example_test.go +++ b/kms/apiv1/ekm_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/kms/apiv1/helpers.go b/kms/apiv1/helpers.go index 9dfe05507637..862824c1cbf0 100755 --- a/kms/apiv1/helpers.go +++ b/kms/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/kms/apiv1/key_management_client.go b/kms/apiv1/key_management_client.go index 07f8e4ba05ae..61c5775f1404 100755 --- a/kms/apiv1/key_management_client.go +++ b/kms/apiv1/key_management_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/kms/apiv1/key_management_client_example_go123_test.go b/kms/apiv1/key_management_client_example_go123_test.go index 0c3fb85c1784..ae0886131529 100644 --- a/kms/apiv1/key_management_client_example_go123_test.go +++ b/kms/apiv1/key_management_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/kms/apiv1/key_management_client_example_test.go b/kms/apiv1/key_management_client_example_test.go index 484c7196598a..414b2a469f59 100644 --- a/kms/apiv1/key_management_client_example_test.go +++ b/kms/apiv1/key_management_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/kms/inventory/apiv1/auxiliary.go b/kms/inventory/apiv1/auxiliary.go index e9639a002eec..cba6ea170802 100755 --- a/kms/inventory/apiv1/auxiliary.go +++ b/kms/inventory/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/kms/inventory/apiv1/auxiliary_go123.go b/kms/inventory/apiv1/auxiliary_go123.go index 14c945817d0d..da94634b37fd 100755 --- a/kms/inventory/apiv1/auxiliary_go123.go +++ b/kms/inventory/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/kms/inventory/apiv1/doc.go b/kms/inventory/apiv1/doc.go index ea6a9f0fda38..f07aa968860a 100755 --- a/kms/inventory/apiv1/doc.go +++ b/kms/inventory/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/kms/inventory/apiv1/helpers.go b/kms/inventory/apiv1/helpers.go index e83cd44311e3..93338c51991b 100755 --- a/kms/inventory/apiv1/helpers.go +++ b/kms/inventory/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/kms/inventory/apiv1/key_dashboard_client.go b/kms/inventory/apiv1/key_dashboard_client.go index 406474eb965e..db9756f0f38d 100755 --- a/kms/inventory/apiv1/key_dashboard_client.go +++ b/kms/inventory/apiv1/key_dashboard_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/kms/inventory/apiv1/key_dashboard_client_example_go123_test.go b/kms/inventory/apiv1/key_dashboard_client_example_go123_test.go index 63dbe3b18b17..8c313563ca2b 100644 --- a/kms/inventory/apiv1/key_dashboard_client_example_go123_test.go +++ b/kms/inventory/apiv1/key_dashboard_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/kms/inventory/apiv1/key_dashboard_client_example_test.go b/kms/inventory/apiv1/key_dashboard_client_example_test.go index 760333d0dada..febda1c82125 100644 --- a/kms/inventory/apiv1/key_dashboard_client_example_test.go +++ b/kms/inventory/apiv1/key_dashboard_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/kms/inventory/apiv1/key_tracking_client.go b/kms/inventory/apiv1/key_tracking_client.go index ebb6fa4e6a73..997c545f2a71 100755 --- a/kms/inventory/apiv1/key_tracking_client.go +++ b/kms/inventory/apiv1/key_tracking_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/kms/inventory/apiv1/key_tracking_client_example_go123_test.go b/kms/inventory/apiv1/key_tracking_client_example_go123_test.go index a591d6d1fd08..2e533dbcc79b 100644 --- a/kms/inventory/apiv1/key_tracking_client_example_go123_test.go +++ b/kms/inventory/apiv1/key_tracking_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/kms/inventory/apiv1/key_tracking_client_example_test.go b/kms/inventory/apiv1/key_tracking_client_example_test.go index 7647bb920939..604d9aefda5b 100644 --- a/kms/inventory/apiv1/key_tracking_client_example_test.go +++ b/kms/inventory/apiv1/key_tracking_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/language/apiv1/auxiliary.go b/language/apiv1/auxiliary.go index f4c6d0a94251..ab914986eb12 100755 --- a/language/apiv1/auxiliary.go +++ b/language/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/language/apiv1/auxiliary_go123.go b/language/apiv1/auxiliary_go123.go index b806c365989f..b99412a3c0a2 100755 --- a/language/apiv1/auxiliary_go123.go +++ b/language/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/language/apiv1/doc.go b/language/apiv1/doc.go index 91cda2ae7d76..b3bbd2d09bde 100755 --- a/language/apiv1/doc.go +++ b/language/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/language/apiv1/helpers.go b/language/apiv1/helpers.go index 78257998d03e..c100d24d49b5 100755 --- a/language/apiv1/helpers.go +++ b/language/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/language/apiv1/language_client.go b/language/apiv1/language_client.go index adad4b00342c..9ce3dafd1512 100755 --- a/language/apiv1/language_client.go +++ b/language/apiv1/language_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/language/apiv1/language_client_example_go123_test.go b/language/apiv1/language_client_example_go123_test.go index 75eec9bc9c4c..976364f7f086 100644 --- a/language/apiv1/language_client_example_go123_test.go +++ b/language/apiv1/language_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/language/apiv1/language_client_example_test.go b/language/apiv1/language_client_example_test.go index 421c66e7fb6b..59aaddd4c9fb 100644 --- a/language/apiv1/language_client_example_test.go +++ b/language/apiv1/language_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/language/apiv1beta2/auxiliary.go b/language/apiv1beta2/auxiliary.go index f4c6d0a94251..ab914986eb12 100755 --- a/language/apiv1beta2/auxiliary.go +++ b/language/apiv1beta2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/language/apiv1beta2/auxiliary_go123.go b/language/apiv1beta2/auxiliary_go123.go index b806c365989f..b99412a3c0a2 100755 --- a/language/apiv1beta2/auxiliary_go123.go +++ b/language/apiv1beta2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/language/apiv1beta2/doc.go b/language/apiv1beta2/doc.go index ccad192361d8..a1258bf79e9f 100755 --- a/language/apiv1beta2/doc.go +++ b/language/apiv1beta2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/language/apiv1beta2/helpers.go b/language/apiv1beta2/helpers.go index 78257998d03e..c100d24d49b5 100755 --- a/language/apiv1beta2/helpers.go +++ b/language/apiv1beta2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/language/apiv1beta2/language_client.go b/language/apiv1beta2/language_client.go index f3ca0e5134ce..d900a8432e10 100755 --- a/language/apiv1beta2/language_client.go +++ b/language/apiv1beta2/language_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/language/apiv1beta2/language_client_example_go123_test.go b/language/apiv1beta2/language_client_example_go123_test.go index 75eec9bc9c4c..976364f7f086 100644 --- a/language/apiv1beta2/language_client_example_go123_test.go +++ b/language/apiv1beta2/language_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/language/apiv1beta2/language_client_example_test.go b/language/apiv1beta2/language_client_example_test.go index 0abcc60f33ce..607e71a28ca5 100644 --- a/language/apiv1beta2/language_client_example_test.go +++ b/language/apiv1beta2/language_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/language/apiv2/auxiliary.go b/language/apiv2/auxiliary.go index f4c6d0a94251..ab914986eb12 100755 --- a/language/apiv2/auxiliary.go +++ b/language/apiv2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/language/apiv2/auxiliary_go123.go b/language/apiv2/auxiliary_go123.go index b806c365989f..b99412a3c0a2 100755 --- a/language/apiv2/auxiliary_go123.go +++ b/language/apiv2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/language/apiv2/doc.go b/language/apiv2/doc.go index 6dcac03af018..e99fa0abc86b 100755 --- a/language/apiv2/doc.go +++ b/language/apiv2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/language/apiv2/helpers.go b/language/apiv2/helpers.go index 78257998d03e..c100d24d49b5 100755 --- a/language/apiv2/helpers.go +++ b/language/apiv2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/language/apiv2/language_client.go b/language/apiv2/language_client.go index 9f811e8994bc..999481e5c7dd 100755 --- a/language/apiv2/language_client.go +++ b/language/apiv2/language_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/language/apiv2/language_client_example_go123_test.go b/language/apiv2/language_client_example_go123_test.go index 75eec9bc9c4c..976364f7f086 100644 --- a/language/apiv2/language_client_example_go123_test.go +++ b/language/apiv2/language_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/language/apiv2/language_client_example_test.go b/language/apiv2/language_client_example_test.go index a8cb65351ca0..aa01787ae840 100644 --- a/language/apiv2/language_client_example_test.go +++ b/language/apiv2/language_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/lifesciences/apiv2beta/auxiliary.go b/lifesciences/apiv2beta/auxiliary.go index 86b63cd6e60b..7e3ad7f5460d 100755 --- a/lifesciences/apiv2beta/auxiliary.go +++ b/lifesciences/apiv2beta/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/lifesciences/apiv2beta/auxiliary_go123.go b/lifesciences/apiv2beta/auxiliary_go123.go index cb1e9e00a42c..4b6139379f02 100755 --- a/lifesciences/apiv2beta/auxiliary_go123.go +++ b/lifesciences/apiv2beta/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/lifesciences/apiv2beta/doc.go b/lifesciences/apiv2beta/doc.go index 293a09bbc830..6a48f0349898 100755 --- a/lifesciences/apiv2beta/doc.go +++ b/lifesciences/apiv2beta/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/lifesciences/apiv2beta/helpers.go b/lifesciences/apiv2beta/helpers.go index 45323970a95e..48cb3a6345f0 100755 --- a/lifesciences/apiv2beta/helpers.go +++ b/lifesciences/apiv2beta/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/lifesciences/apiv2beta/workflows_service_v2_beta_client.go b/lifesciences/apiv2beta/workflows_service_v2_beta_client.go index fbcf89f4e642..2080b24b016d 100755 --- a/lifesciences/apiv2beta/workflows_service_v2_beta_client.go +++ b/lifesciences/apiv2beta/workflows_service_v2_beta_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/lifesciences/apiv2beta/workflows_service_v2_beta_client_example_go123_test.go b/lifesciences/apiv2beta/workflows_service_v2_beta_client_example_go123_test.go index 79972e28fe29..461e778ffb33 100644 --- a/lifesciences/apiv2beta/workflows_service_v2_beta_client_example_go123_test.go +++ b/lifesciences/apiv2beta/workflows_service_v2_beta_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/lifesciences/apiv2beta/workflows_service_v2_beta_client_example_test.go b/lifesciences/apiv2beta/workflows_service_v2_beta_client_example_test.go index 981c26337590..b7d2129a4306 100644 --- a/lifesciences/apiv2beta/workflows_service_v2_beta_client_example_test.go +++ b/lifesciences/apiv2beta/workflows_service_v2_beta_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/logging/apiv2/auxiliary.go b/logging/apiv2/auxiliary.go index 84a6c67c8ec6..90048dc86c98 100755 --- a/logging/apiv2/auxiliary.go +++ b/logging/apiv2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/logging/apiv2/auxiliary_go123.go b/logging/apiv2/auxiliary_go123.go index 191431fee98e..6ef154974380 100755 --- a/logging/apiv2/auxiliary_go123.go +++ b/logging/apiv2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/logging/apiv2/config_client.go b/logging/apiv2/config_client.go index 285395173aa1..6bc5aafdf4e1 100755 --- a/logging/apiv2/config_client.go +++ b/logging/apiv2/config_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/logging/apiv2/config_client_example_go123_test.go b/logging/apiv2/config_client_example_go123_test.go index 420fb859b58a..3387351aa108 100644 --- a/logging/apiv2/config_client_example_go123_test.go +++ b/logging/apiv2/config_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/logging/apiv2/config_client_example_test.go b/logging/apiv2/config_client_example_test.go index f30750b5965f..79f1818c829d 100644 --- a/logging/apiv2/config_client_example_test.go +++ b/logging/apiv2/config_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/logging/apiv2/doc.go b/logging/apiv2/doc.go index c0a5db639cbc..de64c8ac3d78 100755 --- a/logging/apiv2/doc.go +++ b/logging/apiv2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/logging/apiv2/helpers.go b/logging/apiv2/helpers.go index 8a1a768d7c45..c1afec178792 100755 --- a/logging/apiv2/helpers.go +++ b/logging/apiv2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/logging/apiv2/logging_client.go b/logging/apiv2/logging_client.go index 5c5b8c04428b..ded947710a90 100755 --- a/logging/apiv2/logging_client.go +++ b/logging/apiv2/logging_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/logging/apiv2/logging_client_example_go123_test.go b/logging/apiv2/logging_client_example_go123_test.go index 9a00c2281a5b..0af05fc54f10 100644 --- a/logging/apiv2/logging_client_example_go123_test.go +++ b/logging/apiv2/logging_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/logging/apiv2/logging_client_example_test.go b/logging/apiv2/logging_client_example_test.go index 8bc07e3d58d7..cf81afd0cb7a 100644 --- a/logging/apiv2/logging_client_example_test.go +++ b/logging/apiv2/logging_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/logging/apiv2/metrics_client.go b/logging/apiv2/metrics_client.go index 150ce865390b..b86b988b7c33 100755 --- a/logging/apiv2/metrics_client.go +++ b/logging/apiv2/metrics_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/logging/apiv2/metrics_client_example_go123_test.go b/logging/apiv2/metrics_client_example_go123_test.go index a7aa8eac3ba7..40524afb81b3 100644 --- a/logging/apiv2/metrics_client_example_go123_test.go +++ b/logging/apiv2/metrics_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/logging/apiv2/metrics_client_example_test.go b/logging/apiv2/metrics_client_example_test.go index b5d1acddf44d..547a310b3394 100644 --- a/logging/apiv2/metrics_client_example_test.go +++ b/logging/apiv2/metrics_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/longrunning/autogen/auxiliary.go b/longrunning/autogen/auxiliary.go index f3d679ccfd7a..966f099114bb 100755 --- a/longrunning/autogen/auxiliary.go +++ b/longrunning/autogen/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/longrunning/autogen/auxiliary_go123.go b/longrunning/autogen/auxiliary_go123.go index eca6d4def1fc..aac4cd795efa 100755 --- a/longrunning/autogen/auxiliary_go123.go +++ b/longrunning/autogen/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/longrunning/autogen/doc.go b/longrunning/autogen/doc.go index 7f5c0bef3c35..11436b7c4f96 100755 --- a/longrunning/autogen/doc.go +++ b/longrunning/autogen/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/longrunning/autogen/helpers.go b/longrunning/autogen/helpers.go index d14fac0d3f81..6c6d53388e43 100755 --- a/longrunning/autogen/helpers.go +++ b/longrunning/autogen/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/longrunning/autogen/operations_client.go b/longrunning/autogen/operations_client.go index a0a229cf0e9a..57c8173e929d 100755 --- a/longrunning/autogen/operations_client.go +++ b/longrunning/autogen/operations_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/longrunning/autogen/operations_client_example_go123_test.go b/longrunning/autogen/operations_client_example_go123_test.go index 8b8cce4172cb..2a4fe3e1a86d 100644 --- a/longrunning/autogen/operations_client_example_go123_test.go +++ b/longrunning/autogen/operations_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/longrunning/autogen/operations_client_example_test.go b/longrunning/autogen/operations_client_example_test.go index 2e68ca34802c..7b4a44b668af 100644 --- a/longrunning/autogen/operations_client_example_test.go +++ b/longrunning/autogen/operations_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/managedidentities/apiv1/auxiliary.go b/managedidentities/apiv1/auxiliary.go index 32000e417b9a..734bd3d6f8c7 100755 --- a/managedidentities/apiv1/auxiliary.go +++ b/managedidentities/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/managedidentities/apiv1/auxiliary_go123.go b/managedidentities/apiv1/auxiliary_go123.go index e8c683e93ed6..88d84f661dbb 100755 --- a/managedidentities/apiv1/auxiliary_go123.go +++ b/managedidentities/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/managedidentities/apiv1/doc.go b/managedidentities/apiv1/doc.go index 566d8cce6567..aa43cba640d1 100755 --- a/managedidentities/apiv1/doc.go +++ b/managedidentities/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/managedidentities/apiv1/helpers.go b/managedidentities/apiv1/helpers.go index d1c83f8f8df9..38c1884ede21 100755 --- a/managedidentities/apiv1/helpers.go +++ b/managedidentities/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/managedidentities/apiv1/managed_identities_client.go b/managedidentities/apiv1/managed_identities_client.go index a78c950eecde..832d7557ada7 100755 --- a/managedidentities/apiv1/managed_identities_client.go +++ b/managedidentities/apiv1/managed_identities_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/managedidentities/apiv1/managed_identities_client_example_go123_test.go b/managedidentities/apiv1/managed_identities_client_example_go123_test.go index a5fcbf76f562..813175041c0d 100644 --- a/managedidentities/apiv1/managed_identities_client_example_go123_test.go +++ b/managedidentities/apiv1/managed_identities_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/managedidentities/apiv1/managed_identities_client_example_test.go b/managedidentities/apiv1/managed_identities_client_example_test.go index 862211d576a6..ec85771f03ac 100644 --- a/managedidentities/apiv1/managed_identities_client_example_test.go +++ b/managedidentities/apiv1/managed_identities_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/managedkafka/apiv1/auxiliary.go b/managedkafka/apiv1/auxiliary.go index 22d93fde211f..433b37618078 100755 --- a/managedkafka/apiv1/auxiliary.go +++ b/managedkafka/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/managedkafka/apiv1/auxiliary_go123.go b/managedkafka/apiv1/auxiliary_go123.go index 4538d987ab19..e057bd42288d 100755 --- a/managedkafka/apiv1/auxiliary_go123.go +++ b/managedkafka/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/managedkafka/apiv1/doc.go b/managedkafka/apiv1/doc.go index e11aea58cee7..008688460896 100755 --- a/managedkafka/apiv1/doc.go +++ b/managedkafka/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/managedkafka/apiv1/helpers.go b/managedkafka/apiv1/helpers.go index cdbfe106fb65..aa7a10205b0e 100755 --- a/managedkafka/apiv1/helpers.go +++ b/managedkafka/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/managedkafka/apiv1/managed_kafka_client.go b/managedkafka/apiv1/managed_kafka_client.go index 92173b42e0a1..b2d8bcd73ddc 100755 --- a/managedkafka/apiv1/managed_kafka_client.go +++ b/managedkafka/apiv1/managed_kafka_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/managedkafka/apiv1/managed_kafka_client_example_go123_test.go b/managedkafka/apiv1/managed_kafka_client_example_go123_test.go index b1e27b227f63..d0b37d4c4c3e 100644 --- a/managedkafka/apiv1/managed_kafka_client_example_go123_test.go +++ b/managedkafka/apiv1/managed_kafka_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/managedkafka/apiv1/managed_kafka_client_example_test.go b/managedkafka/apiv1/managed_kafka_client_example_test.go index 82c7cb22f148..3656b2f2e07d 100644 --- a/managedkafka/apiv1/managed_kafka_client_example_test.go +++ b/managedkafka/apiv1/managed_kafka_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/addressvalidation/apiv1/address_validation_client.go b/maps/addressvalidation/apiv1/address_validation_client.go index 77fb569089e2..a63eed8eebbb 100755 --- a/maps/addressvalidation/apiv1/address_validation_client.go +++ b/maps/addressvalidation/apiv1/address_validation_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/addressvalidation/apiv1/address_validation_client_example_go123_test.go b/maps/addressvalidation/apiv1/address_validation_client_example_go123_test.go index ff4edc083ed0..38178b7008b2 100644 --- a/maps/addressvalidation/apiv1/address_validation_client_example_go123_test.go +++ b/maps/addressvalidation/apiv1/address_validation_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/addressvalidation/apiv1/address_validation_client_example_test.go b/maps/addressvalidation/apiv1/address_validation_client_example_test.go index c09833f087f9..0b4ac0760ae2 100644 --- a/maps/addressvalidation/apiv1/address_validation_client_example_test.go +++ b/maps/addressvalidation/apiv1/address_validation_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/addressvalidation/apiv1/auxiliary.go b/maps/addressvalidation/apiv1/auxiliary.go index 6cf00b0a6f6e..558d7a92162b 100755 --- a/maps/addressvalidation/apiv1/auxiliary.go +++ b/maps/addressvalidation/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/addressvalidation/apiv1/auxiliary_go123.go b/maps/addressvalidation/apiv1/auxiliary_go123.go index be4ba17b95ef..f2d275e08bb4 100755 --- a/maps/addressvalidation/apiv1/auxiliary_go123.go +++ b/maps/addressvalidation/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/addressvalidation/apiv1/doc.go b/maps/addressvalidation/apiv1/doc.go index 780e55f4896e..67dbbc1deeaa 100755 --- a/maps/addressvalidation/apiv1/doc.go +++ b/maps/addressvalidation/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/addressvalidation/apiv1/helpers.go b/maps/addressvalidation/apiv1/helpers.go index 85890371ddc9..ad4c4289da1e 100755 --- a/maps/addressvalidation/apiv1/helpers.go +++ b/maps/addressvalidation/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/areainsights/apiv1/area_insights_client.go b/maps/areainsights/apiv1/area_insights_client.go index ecce1b2d1ed5..c273e43283a7 100755 --- a/maps/areainsights/apiv1/area_insights_client.go +++ b/maps/areainsights/apiv1/area_insights_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/areainsights/apiv1/area_insights_client_example_go123_test.go b/maps/areainsights/apiv1/area_insights_client_example_go123_test.go index a4b1de17f74b..2f4d0fa60e19 100644 --- a/maps/areainsights/apiv1/area_insights_client_example_go123_test.go +++ b/maps/areainsights/apiv1/area_insights_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/areainsights/apiv1/area_insights_client_example_test.go b/maps/areainsights/apiv1/area_insights_client_example_test.go index 35b487ab678d..7bd288e31859 100644 --- a/maps/areainsights/apiv1/area_insights_client_example_test.go +++ b/maps/areainsights/apiv1/area_insights_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/areainsights/apiv1/auxiliary.go b/maps/areainsights/apiv1/auxiliary.go index 24bcc7837d6e..8a64dbb5c55a 100755 --- a/maps/areainsights/apiv1/auxiliary.go +++ b/maps/areainsights/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/areainsights/apiv1/auxiliary_go123.go b/maps/areainsights/apiv1/auxiliary_go123.go index 2d5fe26c7f1d..9ef80a25bfb6 100755 --- a/maps/areainsights/apiv1/auxiliary_go123.go +++ b/maps/areainsights/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/areainsights/apiv1/doc.go b/maps/areainsights/apiv1/doc.go index d122f67b4f1c..67a23bb90e56 100755 --- a/maps/areainsights/apiv1/doc.go +++ b/maps/areainsights/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/areainsights/apiv1/helpers.go b/maps/areainsights/apiv1/helpers.go index c0fc5cdb9a32..e81838a46e61 100755 --- a/maps/areainsights/apiv1/helpers.go +++ b/maps/areainsights/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/fleetengine/apiv1/auxiliary.go b/maps/fleetengine/apiv1/auxiliary.go index f0f9fee4ed55..66967a311f5f 100755 --- a/maps/fleetengine/apiv1/auxiliary.go +++ b/maps/fleetengine/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/fleetengine/apiv1/auxiliary_go123.go b/maps/fleetengine/apiv1/auxiliary_go123.go index da2769b4927f..a009e9e0d7da 100755 --- a/maps/fleetengine/apiv1/auxiliary_go123.go +++ b/maps/fleetengine/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/fleetengine/apiv1/doc.go b/maps/fleetengine/apiv1/doc.go index f87dd3e98b95..257df333fb43 100755 --- a/maps/fleetengine/apiv1/doc.go +++ b/maps/fleetengine/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/fleetengine/apiv1/helpers.go b/maps/fleetengine/apiv1/helpers.go index b4b7636bd0cb..dc7827ee1d5d 100755 --- a/maps/fleetengine/apiv1/helpers.go +++ b/maps/fleetengine/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/fleetengine/apiv1/trip_client.go b/maps/fleetengine/apiv1/trip_client.go index f9ebda4a5048..d6970f8ca7bb 100755 --- a/maps/fleetengine/apiv1/trip_client.go +++ b/maps/fleetengine/apiv1/trip_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/fleetengine/apiv1/trip_client_example_go123_test.go b/maps/fleetengine/apiv1/trip_client_example_go123_test.go index 2a38a984ae1f..6bb37ad2b48c 100644 --- a/maps/fleetengine/apiv1/trip_client_example_go123_test.go +++ b/maps/fleetengine/apiv1/trip_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/fleetengine/apiv1/trip_client_example_test.go b/maps/fleetengine/apiv1/trip_client_example_test.go index bf51d28dfca3..4e3f06c5cf1c 100644 --- a/maps/fleetengine/apiv1/trip_client_example_test.go +++ b/maps/fleetengine/apiv1/trip_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/fleetengine/apiv1/vehicle_client.go b/maps/fleetengine/apiv1/vehicle_client.go index 3b5b98fb0ab0..755f2183e06d 100755 --- a/maps/fleetengine/apiv1/vehicle_client.go +++ b/maps/fleetengine/apiv1/vehicle_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/fleetengine/apiv1/vehicle_client_example_go123_test.go b/maps/fleetengine/apiv1/vehicle_client_example_go123_test.go index 3359b1366363..bb027f130d46 100644 --- a/maps/fleetengine/apiv1/vehicle_client_example_go123_test.go +++ b/maps/fleetengine/apiv1/vehicle_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/fleetengine/apiv1/vehicle_client_example_test.go b/maps/fleetengine/apiv1/vehicle_client_example_test.go index adc604357c01..6b26accb1862 100644 --- a/maps/fleetengine/apiv1/vehicle_client_example_test.go +++ b/maps/fleetengine/apiv1/vehicle_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/fleetengine/delivery/apiv1/auxiliary.go b/maps/fleetengine/delivery/apiv1/auxiliary.go index b77e15dcbff1..83de0b61a896 100755 --- a/maps/fleetengine/delivery/apiv1/auxiliary.go +++ b/maps/fleetengine/delivery/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/fleetengine/delivery/apiv1/auxiliary_go123.go b/maps/fleetengine/delivery/apiv1/auxiliary_go123.go index eb283613a41a..c212b98f52a8 100755 --- a/maps/fleetengine/delivery/apiv1/auxiliary_go123.go +++ b/maps/fleetengine/delivery/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/fleetengine/delivery/apiv1/delivery_client.go b/maps/fleetengine/delivery/apiv1/delivery_client.go index 0094f59e0e7d..806fd4f469ac 100755 --- a/maps/fleetengine/delivery/apiv1/delivery_client.go +++ b/maps/fleetengine/delivery/apiv1/delivery_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/fleetengine/delivery/apiv1/delivery_client_example_go123_test.go b/maps/fleetengine/delivery/apiv1/delivery_client_example_go123_test.go index 02ed0eae9a29..1fc23168bda8 100644 --- a/maps/fleetengine/delivery/apiv1/delivery_client_example_go123_test.go +++ b/maps/fleetengine/delivery/apiv1/delivery_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/fleetengine/delivery/apiv1/delivery_client_example_test.go b/maps/fleetengine/delivery/apiv1/delivery_client_example_test.go index 85dcc4882297..f48623ecab04 100644 --- a/maps/fleetengine/delivery/apiv1/delivery_client_example_test.go +++ b/maps/fleetengine/delivery/apiv1/delivery_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/fleetengine/delivery/apiv1/doc.go b/maps/fleetengine/delivery/apiv1/doc.go index bf5d68203890..7f56963a4640 100755 --- a/maps/fleetengine/delivery/apiv1/doc.go +++ b/maps/fleetengine/delivery/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/fleetengine/delivery/apiv1/helpers.go b/maps/fleetengine/delivery/apiv1/helpers.go index 75914639360e..dcd92d0d1876 100755 --- a/maps/fleetengine/delivery/apiv1/helpers.go +++ b/maps/fleetengine/delivery/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/places/apiv1/auxiliary.go b/maps/places/apiv1/auxiliary.go index 3ca263245c18..fd1c27fc0148 100755 --- a/maps/places/apiv1/auxiliary.go +++ b/maps/places/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/places/apiv1/auxiliary_go123.go b/maps/places/apiv1/auxiliary_go123.go index 10220dcb331d..2c3c56ef08e1 100755 --- a/maps/places/apiv1/auxiliary_go123.go +++ b/maps/places/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/places/apiv1/doc.go b/maps/places/apiv1/doc.go index aa737a392add..602cf167b9ea 100755 --- a/maps/places/apiv1/doc.go +++ b/maps/places/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/places/apiv1/helpers.go b/maps/places/apiv1/helpers.go index e88214bc9c8d..113c24c01b12 100755 --- a/maps/places/apiv1/helpers.go +++ b/maps/places/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/places/apiv1/places_client.go b/maps/places/apiv1/places_client.go index c317171c222d..996b53577e0f 100755 --- a/maps/places/apiv1/places_client.go +++ b/maps/places/apiv1/places_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/places/apiv1/places_client_example_go123_test.go b/maps/places/apiv1/places_client_example_go123_test.go index 1b58e7bfffac..3d4e81d6a779 100644 --- a/maps/places/apiv1/places_client_example_go123_test.go +++ b/maps/places/apiv1/places_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/places/apiv1/places_client_example_test.go b/maps/places/apiv1/places_client_example_test.go index 3b542afe8cb7..6350d94fecad 100644 --- a/maps/places/apiv1/places_client_example_test.go +++ b/maps/places/apiv1/places_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/routeoptimization/apiv1/auxiliary.go b/maps/routeoptimization/apiv1/auxiliary.go index 8d494472fe4f..5e62f0da0504 100755 --- a/maps/routeoptimization/apiv1/auxiliary.go +++ b/maps/routeoptimization/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/routeoptimization/apiv1/auxiliary_go123.go b/maps/routeoptimization/apiv1/auxiliary_go123.go index 4be921cc562f..3cae3ac8f2e0 100755 --- a/maps/routeoptimization/apiv1/auxiliary_go123.go +++ b/maps/routeoptimization/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/routeoptimization/apiv1/doc.go b/maps/routeoptimization/apiv1/doc.go index cb07b706b882..0fcef4be8860 100755 --- a/maps/routeoptimization/apiv1/doc.go +++ b/maps/routeoptimization/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/routeoptimization/apiv1/helpers.go b/maps/routeoptimization/apiv1/helpers.go index 71acf01c3bc9..e6dc8b73e164 100755 --- a/maps/routeoptimization/apiv1/helpers.go +++ b/maps/routeoptimization/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/routeoptimization/apiv1/route_optimization_client.go b/maps/routeoptimization/apiv1/route_optimization_client.go index 08e7cd048143..b667c7397bd5 100755 --- a/maps/routeoptimization/apiv1/route_optimization_client.go +++ b/maps/routeoptimization/apiv1/route_optimization_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/routeoptimization/apiv1/route_optimization_client_example_go123_test.go b/maps/routeoptimization/apiv1/route_optimization_client_example_go123_test.go index cbb50b0fc770..0a238abef021 100644 --- a/maps/routeoptimization/apiv1/route_optimization_client_example_go123_test.go +++ b/maps/routeoptimization/apiv1/route_optimization_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/routeoptimization/apiv1/route_optimization_client_example_test.go b/maps/routeoptimization/apiv1/route_optimization_client_example_test.go index f0b0d475a24d..f371660fc81c 100644 --- a/maps/routeoptimization/apiv1/route_optimization_client_example_test.go +++ b/maps/routeoptimization/apiv1/route_optimization_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/routing/apiv2/auxiliary.go b/maps/routing/apiv2/auxiliary.go index b51142acd05b..5477732398ea 100755 --- a/maps/routing/apiv2/auxiliary.go +++ b/maps/routing/apiv2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/routing/apiv2/auxiliary_go123.go b/maps/routing/apiv2/auxiliary_go123.go index e4b40511594a..c03299bff391 100755 --- a/maps/routing/apiv2/auxiliary_go123.go +++ b/maps/routing/apiv2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/routing/apiv2/doc.go b/maps/routing/apiv2/doc.go index 73bbabb03140..8541954be736 100755 --- a/maps/routing/apiv2/doc.go +++ b/maps/routing/apiv2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/routing/apiv2/helpers.go b/maps/routing/apiv2/helpers.go index f31ffb81b876..e5b5ee54a8bb 100755 --- a/maps/routing/apiv2/helpers.go +++ b/maps/routing/apiv2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/routing/apiv2/routes_client.go b/maps/routing/apiv2/routes_client.go index f24cae90fa2b..90682e6ebe65 100755 --- a/maps/routing/apiv2/routes_client.go +++ b/maps/routing/apiv2/routes_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/routing/apiv2/routes_client_example_go123_test.go b/maps/routing/apiv2/routes_client_example_go123_test.go index 45099ed5d62a..6d7a740c1d78 100644 --- a/maps/routing/apiv2/routes_client_example_go123_test.go +++ b/maps/routing/apiv2/routes_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/routing/apiv2/routes_client_example_test.go b/maps/routing/apiv2/routes_client_example_test.go index ceb1ffc0b5e6..9ec63a54662d 100644 --- a/maps/routing/apiv2/routes_client_example_test.go +++ b/maps/routing/apiv2/routes_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/solar/apiv1/auxiliary.go b/maps/solar/apiv1/auxiliary.go index affd145393b2..54abd98c96e4 100755 --- a/maps/solar/apiv1/auxiliary.go +++ b/maps/solar/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/solar/apiv1/auxiliary_go123.go b/maps/solar/apiv1/auxiliary_go123.go index 6029a666c92b..259772b762cf 100755 --- a/maps/solar/apiv1/auxiliary_go123.go +++ b/maps/solar/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/solar/apiv1/doc.go b/maps/solar/apiv1/doc.go index 34c0688ca6c3..e2bcd99774b7 100755 --- a/maps/solar/apiv1/doc.go +++ b/maps/solar/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/solar/apiv1/helpers.go b/maps/solar/apiv1/helpers.go index 22213580f597..64df262c3485 100755 --- a/maps/solar/apiv1/helpers.go +++ b/maps/solar/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/solar/apiv1/solar_client.go b/maps/solar/apiv1/solar_client.go index 96f1a9a6c39c..e9a0e63e10fd 100755 --- a/maps/solar/apiv1/solar_client.go +++ b/maps/solar/apiv1/solar_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/solar/apiv1/solar_client_example_go123_test.go b/maps/solar/apiv1/solar_client_example_go123_test.go index 343bf0a05793..c69599116949 100644 --- a/maps/solar/apiv1/solar_client_example_go123_test.go +++ b/maps/solar/apiv1/solar_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/maps/solar/apiv1/solar_client_example_test.go b/maps/solar/apiv1/solar_client_example_test.go index cbf8f8325c21..16bd4cbaf1b5 100644 --- a/maps/solar/apiv1/solar_client_example_test.go +++ b/maps/solar/apiv1/solar_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/mediatranslation/apiv1beta1/auxiliary.go b/mediatranslation/apiv1beta1/auxiliary.go index b34bfc0ec84c..a50960b6884b 100755 --- a/mediatranslation/apiv1beta1/auxiliary.go +++ b/mediatranslation/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/mediatranslation/apiv1beta1/auxiliary_go123.go b/mediatranslation/apiv1beta1/auxiliary_go123.go index 6b57bb21aea1..ddba71bf1dc6 100755 --- a/mediatranslation/apiv1beta1/auxiliary_go123.go +++ b/mediatranslation/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/mediatranslation/apiv1beta1/doc.go b/mediatranslation/apiv1beta1/doc.go index 92662df577ad..2985a338183f 100755 --- a/mediatranslation/apiv1beta1/doc.go +++ b/mediatranslation/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/mediatranslation/apiv1beta1/helpers.go b/mediatranslation/apiv1beta1/helpers.go index 1aa27f94ee08..ecf45460d9a9 100755 --- a/mediatranslation/apiv1beta1/helpers.go +++ b/mediatranslation/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/mediatranslation/apiv1beta1/speech_translation_client.go b/mediatranslation/apiv1beta1/speech_translation_client.go index 56680cfb76e0..c2ad7bafdd1c 100755 --- a/mediatranslation/apiv1beta1/speech_translation_client.go +++ b/mediatranslation/apiv1beta1/speech_translation_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/mediatranslation/apiv1beta1/speech_translation_client_example_go123_test.go b/mediatranslation/apiv1beta1/speech_translation_client_example_go123_test.go index b0b63c35d6a8..69f655a317f5 100644 --- a/mediatranslation/apiv1beta1/speech_translation_client_example_go123_test.go +++ b/mediatranslation/apiv1beta1/speech_translation_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/mediatranslation/apiv1beta1/speech_translation_client_example_test.go b/mediatranslation/apiv1beta1/speech_translation_client_example_test.go index 14a05fb21ed7..d0a80012ed3c 100644 --- a/mediatranslation/apiv1beta1/speech_translation_client_example_test.go +++ b/mediatranslation/apiv1beta1/speech_translation_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/memcache/apiv1/auxiliary.go b/memcache/apiv1/auxiliary.go index ef98475c4e3d..902e6b4f037f 100755 --- a/memcache/apiv1/auxiliary.go +++ b/memcache/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/memcache/apiv1/auxiliary_go123.go b/memcache/apiv1/auxiliary_go123.go index 6633dee4f1ad..ddf5054bf307 100755 --- a/memcache/apiv1/auxiliary_go123.go +++ b/memcache/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/memcache/apiv1/cloud_memcache_client.go b/memcache/apiv1/cloud_memcache_client.go index 445a7266a279..c858a52ad1af 100755 --- a/memcache/apiv1/cloud_memcache_client.go +++ b/memcache/apiv1/cloud_memcache_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/memcache/apiv1/cloud_memcache_client_example_go123_test.go b/memcache/apiv1/cloud_memcache_client_example_go123_test.go index e732ad16935d..2865972636ae 100644 --- a/memcache/apiv1/cloud_memcache_client_example_go123_test.go +++ b/memcache/apiv1/cloud_memcache_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/memcache/apiv1/cloud_memcache_client_example_test.go b/memcache/apiv1/cloud_memcache_client_example_test.go index 248b926299cc..383dbe7bfd85 100644 --- a/memcache/apiv1/cloud_memcache_client_example_test.go +++ b/memcache/apiv1/cloud_memcache_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/memcache/apiv1/doc.go b/memcache/apiv1/doc.go index baf713f41932..7f8097915c76 100755 --- a/memcache/apiv1/doc.go +++ b/memcache/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/memcache/apiv1/helpers.go b/memcache/apiv1/helpers.go index a2f8a0fa5e56..533ffd277a91 100755 --- a/memcache/apiv1/helpers.go +++ b/memcache/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/memcache/apiv1beta2/auxiliary.go b/memcache/apiv1beta2/auxiliary.go index 3b339c92eb8c..4e472d5b01d2 100755 --- a/memcache/apiv1beta2/auxiliary.go +++ b/memcache/apiv1beta2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/memcache/apiv1beta2/auxiliary_go123.go b/memcache/apiv1beta2/auxiliary_go123.go index cd83c2dbf59f..bbf654537053 100755 --- a/memcache/apiv1beta2/auxiliary_go123.go +++ b/memcache/apiv1beta2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/memcache/apiv1beta2/cloud_memcache_client.go b/memcache/apiv1beta2/cloud_memcache_client.go index 959250b2195d..65f8cdf4117a 100755 --- a/memcache/apiv1beta2/cloud_memcache_client.go +++ b/memcache/apiv1beta2/cloud_memcache_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/memcache/apiv1beta2/cloud_memcache_client_example_go123_test.go b/memcache/apiv1beta2/cloud_memcache_client_example_go123_test.go index 43c21d22c430..46b1b6d43eaa 100644 --- a/memcache/apiv1beta2/cloud_memcache_client_example_go123_test.go +++ b/memcache/apiv1beta2/cloud_memcache_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/memcache/apiv1beta2/cloud_memcache_client_example_test.go b/memcache/apiv1beta2/cloud_memcache_client_example_test.go index 9b8696cd2310..3b0d4211cebd 100644 --- a/memcache/apiv1beta2/cloud_memcache_client_example_test.go +++ b/memcache/apiv1beta2/cloud_memcache_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/memcache/apiv1beta2/doc.go b/memcache/apiv1beta2/doc.go index 5f56a5aa9107..7ca381bc5b1e 100755 --- a/memcache/apiv1beta2/doc.go +++ b/memcache/apiv1beta2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/memcache/apiv1beta2/helpers.go b/memcache/apiv1beta2/helpers.go index a2f8a0fa5e56..533ffd277a91 100755 --- a/memcache/apiv1beta2/helpers.go +++ b/memcache/apiv1beta2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/memorystore/apiv1/auxiliary.go b/memorystore/apiv1/auxiliary.go index b8ca1564f0a7..be9b13067197 100755 --- a/memorystore/apiv1/auxiliary.go +++ b/memorystore/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/memorystore/apiv1/auxiliary_go123.go b/memorystore/apiv1/auxiliary_go123.go index 0f8a02b3b4d7..30adb27e79bd 100755 --- a/memorystore/apiv1/auxiliary_go123.go +++ b/memorystore/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/memorystore/apiv1/doc.go b/memorystore/apiv1/doc.go index 9d19bb897d78..174ffd7e7930 100755 --- a/memorystore/apiv1/doc.go +++ b/memorystore/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/memorystore/apiv1/helpers.go b/memorystore/apiv1/helpers.go index 3f2ea8dd6376..0179f8b6b552 100755 --- a/memorystore/apiv1/helpers.go +++ b/memorystore/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/memorystore/apiv1/memorystore_client.go b/memorystore/apiv1/memorystore_client.go index 621a20a85fce..1c56fa337ada 100755 --- a/memorystore/apiv1/memorystore_client.go +++ b/memorystore/apiv1/memorystore_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/memorystore/apiv1/memorystore_client_example_go123_test.go b/memorystore/apiv1/memorystore_client_example_go123_test.go index 3b7730daf55c..8e6ac5c1c6ba 100644 --- a/memorystore/apiv1/memorystore_client_example_go123_test.go +++ b/memorystore/apiv1/memorystore_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/memorystore/apiv1/memorystore_client_example_test.go b/memorystore/apiv1/memorystore_client_example_test.go index 7d6cc8c2b376..2b1d2e7e062f 100644 --- a/memorystore/apiv1/memorystore_client_example_test.go +++ b/memorystore/apiv1/memorystore_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/memorystore/apiv1beta/auxiliary.go b/memorystore/apiv1beta/auxiliary.go index e14ae4db1753..20122288e1cd 100755 --- a/memorystore/apiv1beta/auxiliary.go +++ b/memorystore/apiv1beta/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/memorystore/apiv1beta/auxiliary_go123.go b/memorystore/apiv1beta/auxiliary_go123.go index e220a14f5b87..d3e6c7ca30c2 100755 --- a/memorystore/apiv1beta/auxiliary_go123.go +++ b/memorystore/apiv1beta/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/memorystore/apiv1beta/doc.go b/memorystore/apiv1beta/doc.go index 97e4f0f4665e..9f7bd6f32e51 100755 --- a/memorystore/apiv1beta/doc.go +++ b/memorystore/apiv1beta/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/memorystore/apiv1beta/helpers.go b/memorystore/apiv1beta/helpers.go index 3f2ea8dd6376..0179f8b6b552 100755 --- a/memorystore/apiv1beta/helpers.go +++ b/memorystore/apiv1beta/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/memorystore/apiv1beta/memorystore_client.go b/memorystore/apiv1beta/memorystore_client.go index a0abcd1313a1..ea1fe2154e9e 100755 --- a/memorystore/apiv1beta/memorystore_client.go +++ b/memorystore/apiv1beta/memorystore_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/memorystore/apiv1beta/memorystore_client_example_go123_test.go b/memorystore/apiv1beta/memorystore_client_example_go123_test.go index a60748c38f95..efddef8110a6 100644 --- a/memorystore/apiv1beta/memorystore_client_example_go123_test.go +++ b/memorystore/apiv1beta/memorystore_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/memorystore/apiv1beta/memorystore_client_example_test.go b/memorystore/apiv1beta/memorystore_client_example_test.go index ecdf63951dbc..494af3d67ff7 100644 --- a/memorystore/apiv1beta/memorystore_client_example_test.go +++ b/memorystore/apiv1beta/memorystore_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1/auxiliary.go b/metastore/apiv1/auxiliary.go index 1e3f436a8c49..98112a120096 100755 --- a/metastore/apiv1/auxiliary.go +++ b/metastore/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1/auxiliary_go123.go b/metastore/apiv1/auxiliary_go123.go index eeeeb0c8a5ba..e64fa94c304a 100755 --- a/metastore/apiv1/auxiliary_go123.go +++ b/metastore/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1/dataproc_metastore_client.go b/metastore/apiv1/dataproc_metastore_client.go index 833fe0e081a5..f6c4ac60cb1d 100755 --- a/metastore/apiv1/dataproc_metastore_client.go +++ b/metastore/apiv1/dataproc_metastore_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1/dataproc_metastore_client_example_go123_test.go b/metastore/apiv1/dataproc_metastore_client_example_go123_test.go index 84f80f9e993c..bbb16ef7aeb2 100644 --- a/metastore/apiv1/dataproc_metastore_client_example_go123_test.go +++ b/metastore/apiv1/dataproc_metastore_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1/dataproc_metastore_client_example_test.go b/metastore/apiv1/dataproc_metastore_client_example_test.go index 5c927aa20cb2..d764ba57fd70 100644 --- a/metastore/apiv1/dataproc_metastore_client_example_test.go +++ b/metastore/apiv1/dataproc_metastore_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1/dataproc_metastore_federation_client.go b/metastore/apiv1/dataproc_metastore_federation_client.go index 0fa01677d390..ff52544a56e1 100755 --- a/metastore/apiv1/dataproc_metastore_federation_client.go +++ b/metastore/apiv1/dataproc_metastore_federation_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1/dataproc_metastore_federation_client_example_go123_test.go b/metastore/apiv1/dataproc_metastore_federation_client_example_go123_test.go index dd4e8401a41b..aaed840f51fd 100644 --- a/metastore/apiv1/dataproc_metastore_federation_client_example_go123_test.go +++ b/metastore/apiv1/dataproc_metastore_federation_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1/dataproc_metastore_federation_client_example_test.go b/metastore/apiv1/dataproc_metastore_federation_client_example_test.go index 129e4ca6d5b9..453e1cddc848 100644 --- a/metastore/apiv1/dataproc_metastore_federation_client_example_test.go +++ b/metastore/apiv1/dataproc_metastore_federation_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1/doc.go b/metastore/apiv1/doc.go index 1f19b5bf62b0..018e891b59ce 100755 --- a/metastore/apiv1/doc.go +++ b/metastore/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1/helpers.go b/metastore/apiv1/helpers.go index 76e24fee5486..5dee27176a59 100755 --- a/metastore/apiv1/helpers.go +++ b/metastore/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1alpha/auxiliary.go b/metastore/apiv1alpha/auxiliary.go index bfaa21618738..9e128cf03967 100755 --- a/metastore/apiv1alpha/auxiliary.go +++ b/metastore/apiv1alpha/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1alpha/auxiliary_go123.go b/metastore/apiv1alpha/auxiliary_go123.go index 02596aba4612..238454fd7218 100755 --- a/metastore/apiv1alpha/auxiliary_go123.go +++ b/metastore/apiv1alpha/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1alpha/dataproc_metastore_client.go b/metastore/apiv1alpha/dataproc_metastore_client.go index f70beb5cec21..c256a61e8512 100755 --- a/metastore/apiv1alpha/dataproc_metastore_client.go +++ b/metastore/apiv1alpha/dataproc_metastore_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1alpha/dataproc_metastore_client_example_go123_test.go b/metastore/apiv1alpha/dataproc_metastore_client_example_go123_test.go index 76a6d4f0cfc6..b340332074de 100644 --- a/metastore/apiv1alpha/dataproc_metastore_client_example_go123_test.go +++ b/metastore/apiv1alpha/dataproc_metastore_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1alpha/dataproc_metastore_client_example_test.go b/metastore/apiv1alpha/dataproc_metastore_client_example_test.go index 670bfb80e58f..51a8343c0a8a 100644 --- a/metastore/apiv1alpha/dataproc_metastore_client_example_test.go +++ b/metastore/apiv1alpha/dataproc_metastore_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1alpha/dataproc_metastore_federation_client.go b/metastore/apiv1alpha/dataproc_metastore_federation_client.go index ba6600900c85..9ac5fb91b220 100755 --- a/metastore/apiv1alpha/dataproc_metastore_federation_client.go +++ b/metastore/apiv1alpha/dataproc_metastore_federation_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1alpha/dataproc_metastore_federation_client_example_go123_test.go b/metastore/apiv1alpha/dataproc_metastore_federation_client_example_go123_test.go index 8b60254d130a..a29ef2b10794 100644 --- a/metastore/apiv1alpha/dataproc_metastore_federation_client_example_go123_test.go +++ b/metastore/apiv1alpha/dataproc_metastore_federation_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1alpha/dataproc_metastore_federation_client_example_test.go b/metastore/apiv1alpha/dataproc_metastore_federation_client_example_test.go index cad7a72e3ab7..63f28d7e7e4e 100644 --- a/metastore/apiv1alpha/dataproc_metastore_federation_client_example_test.go +++ b/metastore/apiv1alpha/dataproc_metastore_federation_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1alpha/doc.go b/metastore/apiv1alpha/doc.go index 29fba56fc736..fa7e81a12ce6 100755 --- a/metastore/apiv1alpha/doc.go +++ b/metastore/apiv1alpha/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1alpha/helpers.go b/metastore/apiv1alpha/helpers.go index 76e24fee5486..5dee27176a59 100755 --- a/metastore/apiv1alpha/helpers.go +++ b/metastore/apiv1alpha/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1beta/auxiliary.go b/metastore/apiv1beta/auxiliary.go index 306e815b4782..e4808e13b701 100755 --- a/metastore/apiv1beta/auxiliary.go +++ b/metastore/apiv1beta/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1beta/auxiliary_go123.go b/metastore/apiv1beta/auxiliary_go123.go index d45f3341b408..55f7eadd7ad7 100755 --- a/metastore/apiv1beta/auxiliary_go123.go +++ b/metastore/apiv1beta/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1beta/dataproc_metastore_client.go b/metastore/apiv1beta/dataproc_metastore_client.go index 8eeeb4256153..dd68aae9aa99 100755 --- a/metastore/apiv1beta/dataproc_metastore_client.go +++ b/metastore/apiv1beta/dataproc_metastore_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1beta/dataproc_metastore_client_example_go123_test.go b/metastore/apiv1beta/dataproc_metastore_client_example_go123_test.go index d59d2c52d377..44d0163cdc08 100644 --- a/metastore/apiv1beta/dataproc_metastore_client_example_go123_test.go +++ b/metastore/apiv1beta/dataproc_metastore_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1beta/dataproc_metastore_client_example_test.go b/metastore/apiv1beta/dataproc_metastore_client_example_test.go index 553af27e3fd2..68270c9eed52 100644 --- a/metastore/apiv1beta/dataproc_metastore_client_example_test.go +++ b/metastore/apiv1beta/dataproc_metastore_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1beta/dataproc_metastore_federation_client.go b/metastore/apiv1beta/dataproc_metastore_federation_client.go index c736b6f4f9b1..43e7354c164d 100755 --- a/metastore/apiv1beta/dataproc_metastore_federation_client.go +++ b/metastore/apiv1beta/dataproc_metastore_federation_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1beta/dataproc_metastore_federation_client_example_go123_test.go b/metastore/apiv1beta/dataproc_metastore_federation_client_example_go123_test.go index e280566a3349..3195f09dc44c 100644 --- a/metastore/apiv1beta/dataproc_metastore_federation_client_example_go123_test.go +++ b/metastore/apiv1beta/dataproc_metastore_federation_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1beta/dataproc_metastore_federation_client_example_test.go b/metastore/apiv1beta/dataproc_metastore_federation_client_example_test.go index 21a6d39e8c24..562f8b66c398 100644 --- a/metastore/apiv1beta/dataproc_metastore_federation_client_example_test.go +++ b/metastore/apiv1beta/dataproc_metastore_federation_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1beta/doc.go b/metastore/apiv1beta/doc.go index 6f7cca45e681..f5518b5c8298 100755 --- a/metastore/apiv1beta/doc.go +++ b/metastore/apiv1beta/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/metastore/apiv1beta/helpers.go b/metastore/apiv1beta/helpers.go index 76e24fee5486..5dee27176a59 100755 --- a/metastore/apiv1beta/helpers.go +++ b/metastore/apiv1beta/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/migrationcenter/apiv1/auxiliary.go b/migrationcenter/apiv1/auxiliary.go index 315602d35a14..d8d1c98f0ac6 100755 --- a/migrationcenter/apiv1/auxiliary.go +++ b/migrationcenter/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/migrationcenter/apiv1/auxiliary_go123.go b/migrationcenter/apiv1/auxiliary_go123.go index b3408fbf99f2..e37e7b5ecc9e 100755 --- a/migrationcenter/apiv1/auxiliary_go123.go +++ b/migrationcenter/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/migrationcenter/apiv1/doc.go b/migrationcenter/apiv1/doc.go index cb0c477d180a..ceb5cf68f490 100755 --- a/migrationcenter/apiv1/doc.go +++ b/migrationcenter/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/migrationcenter/apiv1/helpers.go b/migrationcenter/apiv1/helpers.go index 2e05896acc69..6e9114bf3d48 100755 --- a/migrationcenter/apiv1/helpers.go +++ b/migrationcenter/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/migrationcenter/apiv1/migration_center_client.go b/migrationcenter/apiv1/migration_center_client.go index 5783977e2784..b4d94f3489d0 100755 --- a/migrationcenter/apiv1/migration_center_client.go +++ b/migrationcenter/apiv1/migration_center_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/migrationcenter/apiv1/migration_center_client_example_go123_test.go b/migrationcenter/apiv1/migration_center_client_example_go123_test.go index 65eecad55419..8fadc0c41ee5 100644 --- a/migrationcenter/apiv1/migration_center_client_example_go123_test.go +++ b/migrationcenter/apiv1/migration_center_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/migrationcenter/apiv1/migration_center_client_example_test.go b/migrationcenter/apiv1/migration_center_client_example_test.go index 413bc460bd85..844fa289dec8 100644 --- a/migrationcenter/apiv1/migration_center_client_example_test.go +++ b/migrationcenter/apiv1/migration_center_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/apiv3/v2/alert_policy_client.go b/monitoring/apiv3/v2/alert_policy_client.go index c099e6fa9b74..9a9408f19bff 100755 --- a/monitoring/apiv3/v2/alert_policy_client.go +++ b/monitoring/apiv3/v2/alert_policy_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/apiv3/v2/alert_policy_client_example_go123_test.go b/monitoring/apiv3/v2/alert_policy_client_example_go123_test.go index 401fdecb855b..dbd66591fd29 100644 --- a/monitoring/apiv3/v2/alert_policy_client_example_go123_test.go +++ b/monitoring/apiv3/v2/alert_policy_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/apiv3/v2/alert_policy_client_example_test.go b/monitoring/apiv3/v2/alert_policy_client_example_test.go index 228c087b7ed0..0af6f6e81ee3 100644 --- a/monitoring/apiv3/v2/alert_policy_client_example_test.go +++ b/monitoring/apiv3/v2/alert_policy_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/apiv3/v2/auxiliary.go b/monitoring/apiv3/v2/auxiliary.go index 52c29f957e9c..8dc9634588a7 100755 --- a/monitoring/apiv3/v2/auxiliary.go +++ b/monitoring/apiv3/v2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/apiv3/v2/auxiliary_go123.go b/monitoring/apiv3/v2/auxiliary_go123.go index 2982e1f84d5e..bf559553b75e 100755 --- a/monitoring/apiv3/v2/auxiliary_go123.go +++ b/monitoring/apiv3/v2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/apiv3/v2/doc.go b/monitoring/apiv3/v2/doc.go index 633cd6d97753..1d5136edaffe 100755 --- a/monitoring/apiv3/v2/doc.go +++ b/monitoring/apiv3/v2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/apiv3/v2/group_client.go b/monitoring/apiv3/v2/group_client.go index e7e51bf789ca..a45e1aec2785 100755 --- a/monitoring/apiv3/v2/group_client.go +++ b/monitoring/apiv3/v2/group_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/apiv3/v2/group_client_example_go123_test.go b/monitoring/apiv3/v2/group_client_example_go123_test.go index 688c65b8ace0..cfb785032fe2 100644 --- a/monitoring/apiv3/v2/group_client_example_go123_test.go +++ b/monitoring/apiv3/v2/group_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/apiv3/v2/group_client_example_test.go b/monitoring/apiv3/v2/group_client_example_test.go index f53e08425cb5..a1b4188c6980 100644 --- a/monitoring/apiv3/v2/group_client_example_test.go +++ b/monitoring/apiv3/v2/group_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/apiv3/v2/helpers.go b/monitoring/apiv3/v2/helpers.go index 7eb0121796c0..6719cac86354 100755 --- a/monitoring/apiv3/v2/helpers.go +++ b/monitoring/apiv3/v2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/apiv3/v2/metric_client.go b/monitoring/apiv3/v2/metric_client.go index f5d405050c53..29eb4849d230 100755 --- a/monitoring/apiv3/v2/metric_client.go +++ b/monitoring/apiv3/v2/metric_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/apiv3/v2/metric_client_example_go123_test.go b/monitoring/apiv3/v2/metric_client_example_go123_test.go index 09081082a019..410d3a9ca0a2 100644 --- a/monitoring/apiv3/v2/metric_client_example_go123_test.go +++ b/monitoring/apiv3/v2/metric_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/apiv3/v2/metric_client_example_test.go b/monitoring/apiv3/v2/metric_client_example_test.go index fcee61943c69..c73394eb1525 100644 --- a/monitoring/apiv3/v2/metric_client_example_test.go +++ b/monitoring/apiv3/v2/metric_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/apiv3/v2/notification_channel_client.go b/monitoring/apiv3/v2/notification_channel_client.go index ad64cb1292a0..3b36b219e537 100755 --- a/monitoring/apiv3/v2/notification_channel_client.go +++ b/monitoring/apiv3/v2/notification_channel_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/apiv3/v2/notification_channel_client_example_go123_test.go b/monitoring/apiv3/v2/notification_channel_client_example_go123_test.go index 03e5bb330fee..0fbe72f8dda4 100644 --- a/monitoring/apiv3/v2/notification_channel_client_example_go123_test.go +++ b/monitoring/apiv3/v2/notification_channel_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/apiv3/v2/notification_channel_client_example_test.go b/monitoring/apiv3/v2/notification_channel_client_example_test.go index 4f621a0e5041..6d5f37495191 100644 --- a/monitoring/apiv3/v2/notification_channel_client_example_test.go +++ b/monitoring/apiv3/v2/notification_channel_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/apiv3/v2/query_client.go b/monitoring/apiv3/v2/query_client.go index dcd19e698522..f792f2bd7e6c 100755 --- a/monitoring/apiv3/v2/query_client.go +++ b/monitoring/apiv3/v2/query_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/apiv3/v2/query_client_example_go123_test.go b/monitoring/apiv3/v2/query_client_example_go123_test.go index 7bef0d77675c..4d0c8c9883f8 100644 --- a/monitoring/apiv3/v2/query_client_example_go123_test.go +++ b/monitoring/apiv3/v2/query_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/apiv3/v2/query_client_example_test.go b/monitoring/apiv3/v2/query_client_example_test.go index 9492c6649ad1..1821ce95ad56 100644 --- a/monitoring/apiv3/v2/query_client_example_test.go +++ b/monitoring/apiv3/v2/query_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/apiv3/v2/service_monitoring_client.go b/monitoring/apiv3/v2/service_monitoring_client.go index 206b7e4c1131..7dc66e373073 100755 --- a/monitoring/apiv3/v2/service_monitoring_client.go +++ b/monitoring/apiv3/v2/service_monitoring_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/apiv3/v2/service_monitoring_client_example_go123_test.go b/monitoring/apiv3/v2/service_monitoring_client_example_go123_test.go index a0c2ecf881e3..3feb217218d1 100644 --- a/monitoring/apiv3/v2/service_monitoring_client_example_go123_test.go +++ b/monitoring/apiv3/v2/service_monitoring_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/apiv3/v2/service_monitoring_client_example_test.go b/monitoring/apiv3/v2/service_monitoring_client_example_test.go index 24991e365cbc..90ee3e8b8665 100644 --- a/monitoring/apiv3/v2/service_monitoring_client_example_test.go +++ b/monitoring/apiv3/v2/service_monitoring_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/apiv3/v2/snooze_client.go b/monitoring/apiv3/v2/snooze_client.go index ce238659ed90..5b76a486bb13 100755 --- a/monitoring/apiv3/v2/snooze_client.go +++ b/monitoring/apiv3/v2/snooze_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/apiv3/v2/snooze_client_example_go123_test.go b/monitoring/apiv3/v2/snooze_client_example_go123_test.go index 91e89a0ff0d4..5772c79b8555 100644 --- a/monitoring/apiv3/v2/snooze_client_example_go123_test.go +++ b/monitoring/apiv3/v2/snooze_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/apiv3/v2/snooze_client_example_test.go b/monitoring/apiv3/v2/snooze_client_example_test.go index c023841414ba..da470265afb7 100644 --- a/monitoring/apiv3/v2/snooze_client_example_test.go +++ b/monitoring/apiv3/v2/snooze_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/apiv3/v2/uptime_check_client.go b/monitoring/apiv3/v2/uptime_check_client.go index 6f0c7feca5a1..df0ec29575fd 100755 --- a/monitoring/apiv3/v2/uptime_check_client.go +++ b/monitoring/apiv3/v2/uptime_check_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/apiv3/v2/uptime_check_client_example_go123_test.go b/monitoring/apiv3/v2/uptime_check_client_example_go123_test.go index b4cce21fa192..49b995e54c82 100644 --- a/monitoring/apiv3/v2/uptime_check_client_example_go123_test.go +++ b/monitoring/apiv3/v2/uptime_check_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/apiv3/v2/uptime_check_client_example_test.go b/monitoring/apiv3/v2/uptime_check_client_example_test.go index 056e5ea5e979..7807c64669b3 100644 --- a/monitoring/apiv3/v2/uptime_check_client_example_test.go +++ b/monitoring/apiv3/v2/uptime_check_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/dashboard/apiv1/auxiliary.go b/monitoring/dashboard/apiv1/auxiliary.go index e6140a213c69..2e8bd9cad929 100755 --- a/monitoring/dashboard/apiv1/auxiliary.go +++ b/monitoring/dashboard/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/dashboard/apiv1/auxiliary_go123.go b/monitoring/dashboard/apiv1/auxiliary_go123.go index ac53410c8a1d..5758c1fff0a0 100755 --- a/monitoring/dashboard/apiv1/auxiliary_go123.go +++ b/monitoring/dashboard/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/dashboard/apiv1/dashboards_client.go b/monitoring/dashboard/apiv1/dashboards_client.go index 7644024f2904..eddb70738268 100755 --- a/monitoring/dashboard/apiv1/dashboards_client.go +++ b/monitoring/dashboard/apiv1/dashboards_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/dashboard/apiv1/dashboards_client_example_go123_test.go b/monitoring/dashboard/apiv1/dashboards_client_example_go123_test.go index 807e81ff3156..c3ca12a82746 100644 --- a/monitoring/dashboard/apiv1/dashboards_client_example_go123_test.go +++ b/monitoring/dashboard/apiv1/dashboards_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/dashboard/apiv1/dashboards_client_example_test.go b/monitoring/dashboard/apiv1/dashboards_client_example_test.go index 7ae84055b042..b42d3a6e214f 100644 --- a/monitoring/dashboard/apiv1/dashboards_client_example_test.go +++ b/monitoring/dashboard/apiv1/dashboards_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/dashboard/apiv1/doc.go b/monitoring/dashboard/apiv1/doc.go index d5a7e8f61e26..972bdb33feaa 100755 --- a/monitoring/dashboard/apiv1/doc.go +++ b/monitoring/dashboard/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/dashboard/apiv1/helpers.go b/monitoring/dashboard/apiv1/helpers.go index d0e548e4dd4a..9453caca1b00 100755 --- a/monitoring/dashboard/apiv1/helpers.go +++ b/monitoring/dashboard/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/metricsscope/apiv1/auxiliary.go b/monitoring/metricsscope/apiv1/auxiliary.go index e920eb8ece9e..e3ea52588038 100755 --- a/monitoring/metricsscope/apiv1/auxiliary.go +++ b/monitoring/metricsscope/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/metricsscope/apiv1/auxiliary_go123.go b/monitoring/metricsscope/apiv1/auxiliary_go123.go index 305145a42927..9b0bf995208c 100755 --- a/monitoring/metricsscope/apiv1/auxiliary_go123.go +++ b/monitoring/metricsscope/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/metricsscope/apiv1/doc.go b/monitoring/metricsscope/apiv1/doc.go index a8d60c9f3cb0..3e51c443d94c 100755 --- a/monitoring/metricsscope/apiv1/doc.go +++ b/monitoring/metricsscope/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/metricsscope/apiv1/helpers.go b/monitoring/metricsscope/apiv1/helpers.go index 54190d32b6e9..7ab78d4d3e3c 100755 --- a/monitoring/metricsscope/apiv1/helpers.go +++ b/monitoring/metricsscope/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/metricsscope/apiv1/metrics_scopes_client.go b/monitoring/metricsscope/apiv1/metrics_scopes_client.go index 1110d977a443..87dbcd37f7d0 100755 --- a/monitoring/metricsscope/apiv1/metrics_scopes_client.go +++ b/monitoring/metricsscope/apiv1/metrics_scopes_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/metricsscope/apiv1/metrics_scopes_client_example_go123_test.go b/monitoring/metricsscope/apiv1/metrics_scopes_client_example_go123_test.go index 0a69f19886c9..98bb0183389a 100644 --- a/monitoring/metricsscope/apiv1/metrics_scopes_client_example_go123_test.go +++ b/monitoring/metricsscope/apiv1/metrics_scopes_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/monitoring/metricsscope/apiv1/metrics_scopes_client_example_test.go b/monitoring/metricsscope/apiv1/metrics_scopes_client_example_test.go index 5edff89beba3..7933198374a2 100644 --- a/monitoring/metricsscope/apiv1/metrics_scopes_client_example_test.go +++ b/monitoring/metricsscope/apiv1/metrics_scopes_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/netapp/apiv1/auxiliary.go b/netapp/apiv1/auxiliary.go index 2bea7586f051..ba1934edb6de 100755 --- a/netapp/apiv1/auxiliary.go +++ b/netapp/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/netapp/apiv1/auxiliary_go123.go b/netapp/apiv1/auxiliary_go123.go index 8afc06f3ce4c..1910fff6c4ef 100755 --- a/netapp/apiv1/auxiliary_go123.go +++ b/netapp/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/netapp/apiv1/doc.go b/netapp/apiv1/doc.go index 5cfee64add1a..8c12df482701 100755 --- a/netapp/apiv1/doc.go +++ b/netapp/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/netapp/apiv1/helpers.go b/netapp/apiv1/helpers.go index c9e9f79e9bd9..9f2491adedbc 100755 --- a/netapp/apiv1/helpers.go +++ b/netapp/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/netapp/apiv1/net_app_client.go b/netapp/apiv1/net_app_client.go index 034e6208245c..a2a6ab94c9aa 100755 --- a/netapp/apiv1/net_app_client.go +++ b/netapp/apiv1/net_app_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/netapp/apiv1/net_app_client_example_go123_test.go b/netapp/apiv1/net_app_client_example_go123_test.go index 1779edf0bbf9..38fc696b23ce 100644 --- a/netapp/apiv1/net_app_client_example_go123_test.go +++ b/netapp/apiv1/net_app_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/netapp/apiv1/net_app_client_example_test.go b/netapp/apiv1/net_app_client_example_test.go index eeb5bd9d1624..05f1542954ab 100644 --- a/netapp/apiv1/net_app_client_example_test.go +++ b/netapp/apiv1/net_app_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkconnectivity/apiv1/auxiliary.go b/networkconnectivity/apiv1/auxiliary.go index 0a01c98602f4..8a20c0a064e4 100755 --- a/networkconnectivity/apiv1/auxiliary.go +++ b/networkconnectivity/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkconnectivity/apiv1/auxiliary_go123.go b/networkconnectivity/apiv1/auxiliary_go123.go index 9f45fc08c2ad..e7ea9a75abe2 100755 --- a/networkconnectivity/apiv1/auxiliary_go123.go +++ b/networkconnectivity/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkconnectivity/apiv1/doc.go b/networkconnectivity/apiv1/doc.go index 8a0bda6956fc..815a09a759d4 100755 --- a/networkconnectivity/apiv1/doc.go +++ b/networkconnectivity/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkconnectivity/apiv1/helpers.go b/networkconnectivity/apiv1/helpers.go index bb8aab88a618..381c51e1e885 100755 --- a/networkconnectivity/apiv1/helpers.go +++ b/networkconnectivity/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkconnectivity/apiv1/hub_client.go b/networkconnectivity/apiv1/hub_client.go index 33d1c6718256..3650458b96e8 100755 --- a/networkconnectivity/apiv1/hub_client.go +++ b/networkconnectivity/apiv1/hub_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkconnectivity/apiv1/hub_client_example_go123_test.go b/networkconnectivity/apiv1/hub_client_example_go123_test.go index dba46ee081c4..848ee924df18 100644 --- a/networkconnectivity/apiv1/hub_client_example_go123_test.go +++ b/networkconnectivity/apiv1/hub_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkconnectivity/apiv1/hub_client_example_test.go b/networkconnectivity/apiv1/hub_client_example_test.go index a66b7aa10bbb..541df243f015 100644 --- a/networkconnectivity/apiv1/hub_client_example_test.go +++ b/networkconnectivity/apiv1/hub_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkconnectivity/apiv1/policy_based_routing_client.go b/networkconnectivity/apiv1/policy_based_routing_client.go index a74ec1464ed9..a235ae705942 100755 --- a/networkconnectivity/apiv1/policy_based_routing_client.go +++ b/networkconnectivity/apiv1/policy_based_routing_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkconnectivity/apiv1/policy_based_routing_client_example_go123_test.go b/networkconnectivity/apiv1/policy_based_routing_client_example_go123_test.go index 9c3e7be5cdc0..a30dc284b1a2 100644 --- a/networkconnectivity/apiv1/policy_based_routing_client_example_go123_test.go +++ b/networkconnectivity/apiv1/policy_based_routing_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkconnectivity/apiv1/policy_based_routing_client_example_test.go b/networkconnectivity/apiv1/policy_based_routing_client_example_test.go index b1dd11872ded..40655559f071 100644 --- a/networkconnectivity/apiv1/policy_based_routing_client_example_test.go +++ b/networkconnectivity/apiv1/policy_based_routing_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkconnectivity/apiv1alpha1/auxiliary.go b/networkconnectivity/apiv1alpha1/auxiliary.go index 8b57bb340483..f5192a3db941 100755 --- a/networkconnectivity/apiv1alpha1/auxiliary.go +++ b/networkconnectivity/apiv1alpha1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkconnectivity/apiv1alpha1/auxiliary_go123.go b/networkconnectivity/apiv1alpha1/auxiliary_go123.go index 205f0775a251..c1c2afc9e3f4 100755 --- a/networkconnectivity/apiv1alpha1/auxiliary_go123.go +++ b/networkconnectivity/apiv1alpha1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkconnectivity/apiv1alpha1/doc.go b/networkconnectivity/apiv1alpha1/doc.go index 4e489c9fcd68..cea134f774ac 100755 --- a/networkconnectivity/apiv1alpha1/doc.go +++ b/networkconnectivity/apiv1alpha1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkconnectivity/apiv1alpha1/helpers.go b/networkconnectivity/apiv1alpha1/helpers.go index 7d438850fefd..1c533bb9a0cb 100755 --- a/networkconnectivity/apiv1alpha1/helpers.go +++ b/networkconnectivity/apiv1alpha1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkconnectivity/apiv1alpha1/hub_client.go b/networkconnectivity/apiv1alpha1/hub_client.go index 20e583d5f15c..e7b872528f3f 100755 --- a/networkconnectivity/apiv1alpha1/hub_client.go +++ b/networkconnectivity/apiv1alpha1/hub_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkconnectivity/apiv1alpha1/hub_client_example_go123_test.go b/networkconnectivity/apiv1alpha1/hub_client_example_go123_test.go index ce457e805e68..3d4d83bcd0d3 100644 --- a/networkconnectivity/apiv1alpha1/hub_client_example_go123_test.go +++ b/networkconnectivity/apiv1alpha1/hub_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkconnectivity/apiv1alpha1/hub_client_example_test.go b/networkconnectivity/apiv1alpha1/hub_client_example_test.go index fb20fde6238e..8dc8ef2938ab 100644 --- a/networkconnectivity/apiv1alpha1/hub_client_example_test.go +++ b/networkconnectivity/apiv1alpha1/hub_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkmanagement/apiv1/auxiliary.go b/networkmanagement/apiv1/auxiliary.go index 87094ddc8495..37093a81fffb 100755 --- a/networkmanagement/apiv1/auxiliary.go +++ b/networkmanagement/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkmanagement/apiv1/auxiliary_go123.go b/networkmanagement/apiv1/auxiliary_go123.go index 59e54eb9f884..6152a6a44dea 100755 --- a/networkmanagement/apiv1/auxiliary_go123.go +++ b/networkmanagement/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkmanagement/apiv1/doc.go b/networkmanagement/apiv1/doc.go index c753d9459dee..ceaa7e39bd4c 100755 --- a/networkmanagement/apiv1/doc.go +++ b/networkmanagement/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkmanagement/apiv1/helpers.go b/networkmanagement/apiv1/helpers.go index f3fc22aa88a8..a541442a39dc 100755 --- a/networkmanagement/apiv1/helpers.go +++ b/networkmanagement/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkmanagement/apiv1/reachability_client.go b/networkmanagement/apiv1/reachability_client.go index 29f0fffd81b0..a037e25e9541 100755 --- a/networkmanagement/apiv1/reachability_client.go +++ b/networkmanagement/apiv1/reachability_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkmanagement/apiv1/reachability_client_example_go123_test.go b/networkmanagement/apiv1/reachability_client_example_go123_test.go index 0a313b214eb7..7728cd1af3b1 100644 --- a/networkmanagement/apiv1/reachability_client_example_go123_test.go +++ b/networkmanagement/apiv1/reachability_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkmanagement/apiv1/reachability_client_example_test.go b/networkmanagement/apiv1/reachability_client_example_test.go index 1100507f6aa8..269b476ea906 100644 --- a/networkmanagement/apiv1/reachability_client_example_test.go +++ b/networkmanagement/apiv1/reachability_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networksecurity/apiv1beta1/auxiliary.go b/networksecurity/apiv1beta1/auxiliary.go index 94736a46f0ce..c4404bcb0f41 100755 --- a/networksecurity/apiv1beta1/auxiliary.go +++ b/networksecurity/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networksecurity/apiv1beta1/auxiliary_go123.go b/networksecurity/apiv1beta1/auxiliary_go123.go index 00f321cfe530..09f8c79bedc4 100755 --- a/networksecurity/apiv1beta1/auxiliary_go123.go +++ b/networksecurity/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networksecurity/apiv1beta1/doc.go b/networksecurity/apiv1beta1/doc.go index 314bd6c40d28..44008c5adb4f 100755 --- a/networksecurity/apiv1beta1/doc.go +++ b/networksecurity/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networksecurity/apiv1beta1/helpers.go b/networksecurity/apiv1beta1/helpers.go index 1fbe416e2854..6fa831523376 100755 --- a/networksecurity/apiv1beta1/helpers.go +++ b/networksecurity/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networksecurity/apiv1beta1/network_security_client.go b/networksecurity/apiv1beta1/network_security_client.go index 7d714ba68cc3..c03415df46b2 100755 --- a/networksecurity/apiv1beta1/network_security_client.go +++ b/networksecurity/apiv1beta1/network_security_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networksecurity/apiv1beta1/network_security_client_example_go123_test.go b/networksecurity/apiv1beta1/network_security_client_example_go123_test.go index 0e1cca187234..20d5f5252882 100644 --- a/networksecurity/apiv1beta1/network_security_client_example_go123_test.go +++ b/networksecurity/apiv1beta1/network_security_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networksecurity/apiv1beta1/network_security_client_example_test.go b/networksecurity/apiv1beta1/network_security_client_example_test.go index 32e41e509cf6..db8c62eb67d5 100644 --- a/networksecurity/apiv1beta1/network_security_client_example_test.go +++ b/networksecurity/apiv1beta1/network_security_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkservices/apiv1/auxiliary.go b/networkservices/apiv1/auxiliary.go index 62ae6cec7f8b..cd42feeeb9b4 100755 --- a/networkservices/apiv1/auxiliary.go +++ b/networkservices/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkservices/apiv1/auxiliary_go123.go b/networkservices/apiv1/auxiliary_go123.go index b26a738d8d5c..899b588df03c 100755 --- a/networkservices/apiv1/auxiliary_go123.go +++ b/networkservices/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkservices/apiv1/dep_client.go b/networkservices/apiv1/dep_client.go index 7d1be7bc9ffa..13be383de438 100755 --- a/networkservices/apiv1/dep_client.go +++ b/networkservices/apiv1/dep_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkservices/apiv1/dep_client_example_go123_test.go b/networkservices/apiv1/dep_client_example_go123_test.go index f7a0961efc99..bcaac8275b4a 100644 --- a/networkservices/apiv1/dep_client_example_go123_test.go +++ b/networkservices/apiv1/dep_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkservices/apiv1/dep_client_example_test.go b/networkservices/apiv1/dep_client_example_test.go index 2cdcce18afe7..4fd795edcc6e 100644 --- a/networkservices/apiv1/dep_client_example_test.go +++ b/networkservices/apiv1/dep_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkservices/apiv1/doc.go b/networkservices/apiv1/doc.go index 85bf07229059..6f440a0a4f41 100755 --- a/networkservices/apiv1/doc.go +++ b/networkservices/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkservices/apiv1/helpers.go b/networkservices/apiv1/helpers.go index 5ee1815371b4..83fdc19c6912 100755 --- a/networkservices/apiv1/helpers.go +++ b/networkservices/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkservices/apiv1/network_services_client.go b/networkservices/apiv1/network_services_client.go index 8e02fb9f739d..d126ae24bf97 100755 --- a/networkservices/apiv1/network_services_client.go +++ b/networkservices/apiv1/network_services_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkservices/apiv1/network_services_client_example_go123_test.go b/networkservices/apiv1/network_services_client_example_go123_test.go index 8148025e44a8..9fd684ab1359 100644 --- a/networkservices/apiv1/network_services_client_example_go123_test.go +++ b/networkservices/apiv1/network_services_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/networkservices/apiv1/network_services_client_example_test.go b/networkservices/apiv1/network_services_client_example_test.go index 5097393ff3af..0b703c3af4b7 100644 --- a/networkservices/apiv1/network_services_client_example_test.go +++ b/networkservices/apiv1/network_services_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/notebooks/apiv1/auxiliary.go b/notebooks/apiv1/auxiliary.go index c19262be4820..31d91e727038 100755 --- a/notebooks/apiv1/auxiliary.go +++ b/notebooks/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/notebooks/apiv1/auxiliary_go123.go b/notebooks/apiv1/auxiliary_go123.go index 4cf844f843f9..adb961f7f5aa 100755 --- a/notebooks/apiv1/auxiliary_go123.go +++ b/notebooks/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/notebooks/apiv1/doc.go b/notebooks/apiv1/doc.go index 145d151d1467..ba1acf0cead7 100755 --- a/notebooks/apiv1/doc.go +++ b/notebooks/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/notebooks/apiv1/helpers.go b/notebooks/apiv1/helpers.go index 7c127f4ecf88..49d10fa45684 100755 --- a/notebooks/apiv1/helpers.go +++ b/notebooks/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/notebooks/apiv1/managed_notebook_client.go b/notebooks/apiv1/managed_notebook_client.go index 0f910d0c89cb..4300e273ab90 100755 --- a/notebooks/apiv1/managed_notebook_client.go +++ b/notebooks/apiv1/managed_notebook_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/notebooks/apiv1/managed_notebook_client_example_go123_test.go b/notebooks/apiv1/managed_notebook_client_example_go123_test.go index 138bdd7e81fe..8f83378af739 100644 --- a/notebooks/apiv1/managed_notebook_client_example_go123_test.go +++ b/notebooks/apiv1/managed_notebook_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/notebooks/apiv1/managed_notebook_client_example_test.go b/notebooks/apiv1/managed_notebook_client_example_test.go index d3ab923231a1..fac652d0b46b 100644 --- a/notebooks/apiv1/managed_notebook_client_example_test.go +++ b/notebooks/apiv1/managed_notebook_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/notebooks/apiv1/notebook_client.go b/notebooks/apiv1/notebook_client.go index 82d4352a7951..e8799f53bb95 100755 --- a/notebooks/apiv1/notebook_client.go +++ b/notebooks/apiv1/notebook_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/notebooks/apiv1/notebook_client_example_go123_test.go b/notebooks/apiv1/notebook_client_example_go123_test.go index a30a8a95b5e4..971f5ead4c70 100644 --- a/notebooks/apiv1/notebook_client_example_go123_test.go +++ b/notebooks/apiv1/notebook_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/notebooks/apiv1/notebook_client_example_test.go b/notebooks/apiv1/notebook_client_example_test.go index 9f95f2e7a986..f7ed9d1a4b2c 100644 --- a/notebooks/apiv1/notebook_client_example_test.go +++ b/notebooks/apiv1/notebook_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/notebooks/apiv1beta1/auxiliary.go b/notebooks/apiv1beta1/auxiliary.go index 7c0ec2da23e0..3556e7ed8f88 100755 --- a/notebooks/apiv1beta1/auxiliary.go +++ b/notebooks/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/notebooks/apiv1beta1/auxiliary_go123.go b/notebooks/apiv1beta1/auxiliary_go123.go index 216edef39c58..e77b2f5fa63b 100755 --- a/notebooks/apiv1beta1/auxiliary_go123.go +++ b/notebooks/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/notebooks/apiv1beta1/doc.go b/notebooks/apiv1beta1/doc.go index f82d87db7fe3..4128b42066bb 100755 --- a/notebooks/apiv1beta1/doc.go +++ b/notebooks/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/notebooks/apiv1beta1/helpers.go b/notebooks/apiv1beta1/helpers.go index e0f25a02b66e..d002ba969f09 100755 --- a/notebooks/apiv1beta1/helpers.go +++ b/notebooks/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/notebooks/apiv1beta1/notebook_client.go b/notebooks/apiv1beta1/notebook_client.go index 8673b4b28991..6376331eb13d 100755 --- a/notebooks/apiv1beta1/notebook_client.go +++ b/notebooks/apiv1beta1/notebook_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/notebooks/apiv1beta1/notebook_client_example_go123_test.go b/notebooks/apiv1beta1/notebook_client_example_go123_test.go index 1ca037106763..5699045abdea 100644 --- a/notebooks/apiv1beta1/notebook_client_example_go123_test.go +++ b/notebooks/apiv1beta1/notebook_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/notebooks/apiv1beta1/notebook_client_example_test.go b/notebooks/apiv1beta1/notebook_client_example_test.go index 85e34c00eb88..8ac0cdc84cf5 100644 --- a/notebooks/apiv1beta1/notebook_client_example_test.go +++ b/notebooks/apiv1beta1/notebook_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/notebooks/apiv2/auxiliary.go b/notebooks/apiv2/auxiliary.go index d2482a0e4d8d..49b811fc4a5b 100755 --- a/notebooks/apiv2/auxiliary.go +++ b/notebooks/apiv2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/notebooks/apiv2/auxiliary_go123.go b/notebooks/apiv2/auxiliary_go123.go index 1d2442c83be7..4dd5ff1fdbf6 100755 --- a/notebooks/apiv2/auxiliary_go123.go +++ b/notebooks/apiv2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/notebooks/apiv2/doc.go b/notebooks/apiv2/doc.go index 03d32c0efa84..5a5ec6ba88c4 100755 --- a/notebooks/apiv2/doc.go +++ b/notebooks/apiv2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/notebooks/apiv2/helpers.go b/notebooks/apiv2/helpers.go index e0f25a02b66e..d002ba969f09 100755 --- a/notebooks/apiv2/helpers.go +++ b/notebooks/apiv2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/notebooks/apiv2/notebook_client.go b/notebooks/apiv2/notebook_client.go index c677b5f46120..f3928001c162 100755 --- a/notebooks/apiv2/notebook_client.go +++ b/notebooks/apiv2/notebook_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/notebooks/apiv2/notebook_client_example_go123_test.go b/notebooks/apiv2/notebook_client_example_go123_test.go index 307349ab6c81..4ee71a132735 100644 --- a/notebooks/apiv2/notebook_client_example_go123_test.go +++ b/notebooks/apiv2/notebook_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/notebooks/apiv2/notebook_client_example_test.go b/notebooks/apiv2/notebook_client_example_test.go index c068f888f183..6fcc61003dda 100644 --- a/notebooks/apiv2/notebook_client_example_test.go +++ b/notebooks/apiv2/notebook_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/optimization/apiv1/auxiliary.go b/optimization/apiv1/auxiliary.go index e2d7e76ecbe1..632a151483ea 100755 --- a/optimization/apiv1/auxiliary.go +++ b/optimization/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/optimization/apiv1/auxiliary_go123.go b/optimization/apiv1/auxiliary_go123.go index 47773bf26a03..a753913214d4 100755 --- a/optimization/apiv1/auxiliary_go123.go +++ b/optimization/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/optimization/apiv1/doc.go b/optimization/apiv1/doc.go index 7faf64600189..7b6852d94007 100755 --- a/optimization/apiv1/doc.go +++ b/optimization/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/optimization/apiv1/fleet_routing_client.go b/optimization/apiv1/fleet_routing_client.go index 553f16419b65..60998a805f64 100755 --- a/optimization/apiv1/fleet_routing_client.go +++ b/optimization/apiv1/fleet_routing_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/optimization/apiv1/fleet_routing_client_example_go123_test.go b/optimization/apiv1/fleet_routing_client_example_go123_test.go index f9354ab1e677..95341b43d421 100644 --- a/optimization/apiv1/fleet_routing_client_example_go123_test.go +++ b/optimization/apiv1/fleet_routing_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/optimization/apiv1/fleet_routing_client_example_test.go b/optimization/apiv1/fleet_routing_client_example_test.go index 2c97e415387c..5053dac82c2f 100644 --- a/optimization/apiv1/fleet_routing_client_example_test.go +++ b/optimization/apiv1/fleet_routing_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/optimization/apiv1/helpers.go b/optimization/apiv1/helpers.go index 58c095955c45..3ef30b5c3a56 100755 --- a/optimization/apiv1/helpers.go +++ b/optimization/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/oracledatabase/apiv1/auxiliary.go b/oracledatabase/apiv1/auxiliary.go index 6110dc74f0db..08c3a46d81af 100755 --- a/oracledatabase/apiv1/auxiliary.go +++ b/oracledatabase/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/oracledatabase/apiv1/auxiliary_go123.go b/oracledatabase/apiv1/auxiliary_go123.go index 4868a2c7b9ba..80cdf8da4d6b 100755 --- a/oracledatabase/apiv1/auxiliary_go123.go +++ b/oracledatabase/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/oracledatabase/apiv1/doc.go b/oracledatabase/apiv1/doc.go index 1607ce281ff8..557acfa58c7f 100755 --- a/oracledatabase/apiv1/doc.go +++ b/oracledatabase/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/oracledatabase/apiv1/helpers.go b/oracledatabase/apiv1/helpers.go index 2b8fb8e12a8f..ba67802fba98 100755 --- a/oracledatabase/apiv1/helpers.go +++ b/oracledatabase/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/oracledatabase/apiv1/oracle_database_client.go b/oracledatabase/apiv1/oracle_database_client.go index 21a5e1a37b6d..71da1911d065 100755 --- a/oracledatabase/apiv1/oracle_database_client.go +++ b/oracledatabase/apiv1/oracle_database_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/oracledatabase/apiv1/oracle_database_client_example_go123_test.go b/oracledatabase/apiv1/oracle_database_client_example_go123_test.go index c3b6c6e00634..a1e931848bdb 100644 --- a/oracledatabase/apiv1/oracle_database_client_example_go123_test.go +++ b/oracledatabase/apiv1/oracle_database_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/oracledatabase/apiv1/oracle_database_client_example_test.go b/oracledatabase/apiv1/oracle_database_client_example_test.go index 80882d111ba9..e04b19d706ec 100644 --- a/oracledatabase/apiv1/oracle_database_client_example_test.go +++ b/oracledatabase/apiv1/oracle_database_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/oracledatabase/apiv1/oracledatabasepb/vm_cluster.pb.go b/oracledatabase/apiv1/oracledatabasepb/vm_cluster.pb.go index 364e99f249e1..5690786f0c2f 100755 --- a/oracledatabase/apiv1/oracledatabasepb/vm_cluster.pb.go +++ b/oracledatabase/apiv1/oracledatabasepb/vm_cluster.pb.go @@ -409,7 +409,7 @@ type CloudVmClusterProperties struct { Hostname string `protobuf:"bytes,25,opt,name=hostname,proto3" json:"hostname,omitempty"` // Required. Number of enabled CPU cores. CpuCoreCount int32 `protobuf:"varint,26,opt,name=cpu_core_count,json=cpuCoreCount,proto3" json:"cpu_core_count,omitempty"` - // Output only. Operating system version of the image. + // Optional. Operating system version of the image. SystemVersion string `protobuf:"bytes,27,opt,name=system_version,json=systemVersion,proto3" json:"system_version,omitempty"` // Output only. OCIDs of scan IPs. ScanIpIds []string `protobuf:"bytes,28,rep,name=scan_ip_ids,json=scanIpIds,proto3" json:"scan_ip_ids,omitempty"` @@ -905,7 +905,7 @@ var file_google_cloud_oracledatabase_v1_vm_cluster_proto_rawDesc = []byte{ 0x18, 0x1a, 0x20, 0x01, 0x28, 0x05, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x0c, 0x63, 0x70, 0x75, 0x43, 0x6f, 0x72, 0x65, 0x43, 0x6f, 0x75, 0x6e, 0x74, 0x12, 0x2a, 0x0a, 0x0e, 0x73, 0x79, 0x73, 0x74, 0x65, 0x6d, 0x5f, 0x76, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x18, 0x1b, 0x20, 0x01, 0x28, - 0x09, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x0d, 0x73, 0x79, 0x73, 0x74, 0x65, 0x6d, 0x56, 0x65, + 0x09, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x0d, 0x73, 0x79, 0x73, 0x74, 0x65, 0x6d, 0x56, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x12, 0x23, 0x0a, 0x0b, 0x73, 0x63, 0x61, 0x6e, 0x5f, 0x69, 0x70, 0x5f, 0x69, 0x64, 0x73, 0x18, 0x1c, 0x20, 0x03, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x03, 0x52, 0x09, 0x73, 0x63, 0x61, 0x6e, 0x49, 0x70, 0x49, 0x64, 0x73, 0x12, 0x30, 0x0a, 0x12, 0x73, 0x63, diff --git a/orchestration/airflow/service/apiv1/auxiliary.go b/orchestration/airflow/service/apiv1/auxiliary.go index 1a2f76950850..48a7f46efcc3 100755 --- a/orchestration/airflow/service/apiv1/auxiliary.go +++ b/orchestration/airflow/service/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/orchestration/airflow/service/apiv1/auxiliary_go123.go b/orchestration/airflow/service/apiv1/auxiliary_go123.go index 472d46f83c00..4ed8a8826c5f 100755 --- a/orchestration/airflow/service/apiv1/auxiliary_go123.go +++ b/orchestration/airflow/service/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/orchestration/airflow/service/apiv1/doc.go b/orchestration/airflow/service/apiv1/doc.go index d2a07ab61ffc..a1e8f45ba89f 100755 --- a/orchestration/airflow/service/apiv1/doc.go +++ b/orchestration/airflow/service/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/orchestration/airflow/service/apiv1/environments_client.go b/orchestration/airflow/service/apiv1/environments_client.go index 84888bc54551..49b0f659d11c 100755 --- a/orchestration/airflow/service/apiv1/environments_client.go +++ b/orchestration/airflow/service/apiv1/environments_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/orchestration/airflow/service/apiv1/environments_client_example_go123_test.go b/orchestration/airflow/service/apiv1/environments_client_example_go123_test.go index 0a8f393d9bb0..1bcd74625c4a 100644 --- a/orchestration/airflow/service/apiv1/environments_client_example_go123_test.go +++ b/orchestration/airflow/service/apiv1/environments_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/orchestration/airflow/service/apiv1/environments_client_example_test.go b/orchestration/airflow/service/apiv1/environments_client_example_test.go index e3badfc9e365..58d2bf7810e7 100644 --- a/orchestration/airflow/service/apiv1/environments_client_example_test.go +++ b/orchestration/airflow/service/apiv1/environments_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/orchestration/airflow/service/apiv1/helpers.go b/orchestration/airflow/service/apiv1/helpers.go index e4530c951433..7bb3bcd83736 100755 --- a/orchestration/airflow/service/apiv1/helpers.go +++ b/orchestration/airflow/service/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/orchestration/airflow/service/apiv1/image_versions_client.go b/orchestration/airflow/service/apiv1/image_versions_client.go index 28d6b900c94f..a293ef4ce3c5 100755 --- a/orchestration/airflow/service/apiv1/image_versions_client.go +++ b/orchestration/airflow/service/apiv1/image_versions_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/orchestration/airflow/service/apiv1/image_versions_client_example_go123_test.go b/orchestration/airflow/service/apiv1/image_versions_client_example_go123_test.go index 6a8ba30b0660..c5e2f573504b 100644 --- a/orchestration/airflow/service/apiv1/image_versions_client_example_go123_test.go +++ b/orchestration/airflow/service/apiv1/image_versions_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/orchestration/airflow/service/apiv1/image_versions_client_example_test.go b/orchestration/airflow/service/apiv1/image_versions_client_example_test.go index 52d3e9c91684..fc5af62e45d3 100644 --- a/orchestration/airflow/service/apiv1/image_versions_client_example_test.go +++ b/orchestration/airflow/service/apiv1/image_versions_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/orgpolicy/apiv2/auxiliary.go b/orgpolicy/apiv2/auxiliary.go index 817d54e3dd2c..ac2e62dd4a9d 100755 --- a/orgpolicy/apiv2/auxiliary.go +++ b/orgpolicy/apiv2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/orgpolicy/apiv2/auxiliary_go123.go b/orgpolicy/apiv2/auxiliary_go123.go index d48570c610e7..f90fd2b92a92 100755 --- a/orgpolicy/apiv2/auxiliary_go123.go +++ b/orgpolicy/apiv2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/orgpolicy/apiv2/doc.go b/orgpolicy/apiv2/doc.go index be2528042f22..c0e09a4789f8 100755 --- a/orgpolicy/apiv2/doc.go +++ b/orgpolicy/apiv2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/orgpolicy/apiv2/helpers.go b/orgpolicy/apiv2/helpers.go index eaef5b93ab2c..dd00ae879840 100755 --- a/orgpolicy/apiv2/helpers.go +++ b/orgpolicy/apiv2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/orgpolicy/apiv2/org_policy_client.go b/orgpolicy/apiv2/org_policy_client.go index 914c3b07da21..ed0beb3e39ca 100755 --- a/orgpolicy/apiv2/org_policy_client.go +++ b/orgpolicy/apiv2/org_policy_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/orgpolicy/apiv2/org_policy_client_example_go123_test.go b/orgpolicy/apiv2/org_policy_client_example_go123_test.go index 37653fe6adbf..8ff5e8b65701 100644 --- a/orgpolicy/apiv2/org_policy_client_example_go123_test.go +++ b/orgpolicy/apiv2/org_policy_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/orgpolicy/apiv2/org_policy_client_example_test.go b/orgpolicy/apiv2/org_policy_client_example_test.go index 38d34786a15a..e69d5c1272fc 100644 --- a/orgpolicy/apiv2/org_policy_client_example_test.go +++ b/orgpolicy/apiv2/org_policy_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/agentendpoint/apiv1/agent_endpoint_client.go b/osconfig/agentendpoint/apiv1/agent_endpoint_client.go index 0a9c4ffbda1e..e1f0230a0c3b 100755 --- a/osconfig/agentendpoint/apiv1/agent_endpoint_client.go +++ b/osconfig/agentendpoint/apiv1/agent_endpoint_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/agentendpoint/apiv1/agent_endpoint_client_example_go123_test.go b/osconfig/agentendpoint/apiv1/agent_endpoint_client_example_go123_test.go index 708dad66ab5f..8a89363874be 100644 --- a/osconfig/agentendpoint/apiv1/agent_endpoint_client_example_go123_test.go +++ b/osconfig/agentendpoint/apiv1/agent_endpoint_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/agentendpoint/apiv1/agent_endpoint_client_example_test.go b/osconfig/agentendpoint/apiv1/agent_endpoint_client_example_test.go index 656de410feea..a2033be1f8ac 100644 --- a/osconfig/agentendpoint/apiv1/agent_endpoint_client_example_test.go +++ b/osconfig/agentendpoint/apiv1/agent_endpoint_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/agentendpoint/apiv1/auxiliary.go b/osconfig/agentendpoint/apiv1/auxiliary.go index e88a1cdf19b8..809f37d7ddbf 100755 --- a/osconfig/agentendpoint/apiv1/auxiliary.go +++ b/osconfig/agentendpoint/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/agentendpoint/apiv1/auxiliary_go123.go b/osconfig/agentendpoint/apiv1/auxiliary_go123.go index cbe71eb09cb1..bf96cd90ed47 100755 --- a/osconfig/agentendpoint/apiv1/auxiliary_go123.go +++ b/osconfig/agentendpoint/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/agentendpoint/apiv1/doc.go b/osconfig/agentendpoint/apiv1/doc.go index 6f372c7899ed..40304d8e320d 100755 --- a/osconfig/agentendpoint/apiv1/doc.go +++ b/osconfig/agentendpoint/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/agentendpoint/apiv1/helpers.go b/osconfig/agentendpoint/apiv1/helpers.go index d0e407b6f415..9a8d5cea3b6d 100755 --- a/osconfig/agentendpoint/apiv1/helpers.go +++ b/osconfig/agentendpoint/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/agentendpoint/apiv1beta/agent_endpoint_client.go b/osconfig/agentendpoint/apiv1beta/agent_endpoint_client.go index e38d7f4eb339..96f3aa860ab9 100755 --- a/osconfig/agentendpoint/apiv1beta/agent_endpoint_client.go +++ b/osconfig/agentendpoint/apiv1beta/agent_endpoint_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/agentendpoint/apiv1beta/agent_endpoint_client_example_go123_test.go b/osconfig/agentendpoint/apiv1beta/agent_endpoint_client_example_go123_test.go index 708dad66ab5f..8a89363874be 100644 --- a/osconfig/agentendpoint/apiv1beta/agent_endpoint_client_example_go123_test.go +++ b/osconfig/agentendpoint/apiv1beta/agent_endpoint_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/agentendpoint/apiv1beta/agent_endpoint_client_example_test.go b/osconfig/agentendpoint/apiv1beta/agent_endpoint_client_example_test.go index a32ea4e63d90..3c4005e619a4 100644 --- a/osconfig/agentendpoint/apiv1beta/agent_endpoint_client_example_test.go +++ b/osconfig/agentendpoint/apiv1beta/agent_endpoint_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/agentendpoint/apiv1beta/auxiliary.go b/osconfig/agentendpoint/apiv1beta/auxiliary.go index e88a1cdf19b8..809f37d7ddbf 100755 --- a/osconfig/agentendpoint/apiv1beta/auxiliary.go +++ b/osconfig/agentendpoint/apiv1beta/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/agentendpoint/apiv1beta/auxiliary_go123.go b/osconfig/agentendpoint/apiv1beta/auxiliary_go123.go index cbe71eb09cb1..bf96cd90ed47 100755 --- a/osconfig/agentendpoint/apiv1beta/auxiliary_go123.go +++ b/osconfig/agentendpoint/apiv1beta/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/agentendpoint/apiv1beta/doc.go b/osconfig/agentendpoint/apiv1beta/doc.go index 629882970fa3..bce774caf4f6 100755 --- a/osconfig/agentendpoint/apiv1beta/doc.go +++ b/osconfig/agentendpoint/apiv1beta/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/agentendpoint/apiv1beta/helpers.go b/osconfig/agentendpoint/apiv1beta/helpers.go index d0e407b6f415..9a8d5cea3b6d 100755 --- a/osconfig/agentendpoint/apiv1beta/helpers.go +++ b/osconfig/agentendpoint/apiv1beta/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/apiv1/auxiliary.go b/osconfig/apiv1/auxiliary.go index 12635aa6b657..ae8c7fc5f70d 100755 --- a/osconfig/apiv1/auxiliary.go +++ b/osconfig/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/apiv1/auxiliary_go123.go b/osconfig/apiv1/auxiliary_go123.go index 3c92362f9809..b3fc96223909 100755 --- a/osconfig/apiv1/auxiliary_go123.go +++ b/osconfig/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/apiv1/doc.go b/osconfig/apiv1/doc.go index 6193efe348c4..4e7a26222cf1 100755 --- a/osconfig/apiv1/doc.go +++ b/osconfig/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/apiv1/helpers.go b/osconfig/apiv1/helpers.go index 18c5d7283e99..a53d79b5ed58 100755 --- a/osconfig/apiv1/helpers.go +++ b/osconfig/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/apiv1/os_config_client.go b/osconfig/apiv1/os_config_client.go index b66c4a318e66..956fcb3b4abf 100755 --- a/osconfig/apiv1/os_config_client.go +++ b/osconfig/apiv1/os_config_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/apiv1/os_config_client_example_go123_test.go b/osconfig/apiv1/os_config_client_example_go123_test.go index f99d6337b82d..93cf8cfa1954 100644 --- a/osconfig/apiv1/os_config_client_example_go123_test.go +++ b/osconfig/apiv1/os_config_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/apiv1/os_config_client_example_test.go b/osconfig/apiv1/os_config_client_example_test.go index 0fd407e85f1a..294eddd2a981 100644 --- a/osconfig/apiv1/os_config_client_example_test.go +++ b/osconfig/apiv1/os_config_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/apiv1/os_config_zonal_client.go b/osconfig/apiv1/os_config_zonal_client.go index ced705ca15dc..17d330006773 100755 --- a/osconfig/apiv1/os_config_zonal_client.go +++ b/osconfig/apiv1/os_config_zonal_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/apiv1/os_config_zonal_client_example_go123_test.go b/osconfig/apiv1/os_config_zonal_client_example_go123_test.go index cc69e094a628..f8513a439b25 100644 --- a/osconfig/apiv1/os_config_zonal_client_example_go123_test.go +++ b/osconfig/apiv1/os_config_zonal_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/apiv1/os_config_zonal_client_example_test.go b/osconfig/apiv1/os_config_zonal_client_example_test.go index 302afe4b0a92..8f70bfbe294f 100644 --- a/osconfig/apiv1/os_config_zonal_client_example_test.go +++ b/osconfig/apiv1/os_config_zonal_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/apiv1alpha/auxiliary.go b/osconfig/apiv1alpha/auxiliary.go index ac674d7dfbd5..741d92a5fd71 100755 --- a/osconfig/apiv1alpha/auxiliary.go +++ b/osconfig/apiv1alpha/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/apiv1alpha/auxiliary_go123.go b/osconfig/apiv1alpha/auxiliary_go123.go index e2b19170c21f..afb456faac37 100755 --- a/osconfig/apiv1alpha/auxiliary_go123.go +++ b/osconfig/apiv1alpha/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/apiv1alpha/doc.go b/osconfig/apiv1alpha/doc.go index 4bcd8b793d7e..756fa429446f 100755 --- a/osconfig/apiv1alpha/doc.go +++ b/osconfig/apiv1alpha/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/apiv1alpha/helpers.go b/osconfig/apiv1alpha/helpers.go index 18c5d7283e99..a53d79b5ed58 100755 --- a/osconfig/apiv1alpha/helpers.go +++ b/osconfig/apiv1alpha/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/apiv1alpha/os_config_zonal_client.go b/osconfig/apiv1alpha/os_config_zonal_client.go index e6c4bd5b16af..493d00cba50a 100755 --- a/osconfig/apiv1alpha/os_config_zonal_client.go +++ b/osconfig/apiv1alpha/os_config_zonal_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/apiv1alpha/os_config_zonal_client_example_go123_test.go b/osconfig/apiv1alpha/os_config_zonal_client_example_go123_test.go index 8a3d3d0220fd..ebd0a6c02b7a 100644 --- a/osconfig/apiv1alpha/os_config_zonal_client_example_go123_test.go +++ b/osconfig/apiv1alpha/os_config_zonal_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/apiv1alpha/os_config_zonal_client_example_test.go b/osconfig/apiv1alpha/os_config_zonal_client_example_test.go index aba80c68ee8e..1e98615baaaf 100644 --- a/osconfig/apiv1alpha/os_config_zonal_client_example_test.go +++ b/osconfig/apiv1alpha/os_config_zonal_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/apiv1beta/auxiliary.go b/osconfig/apiv1beta/auxiliary.go index e7ca0e5225c9..cb2fc545efb7 100755 --- a/osconfig/apiv1beta/auxiliary.go +++ b/osconfig/apiv1beta/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/apiv1beta/auxiliary_go123.go b/osconfig/apiv1beta/auxiliary_go123.go index 06d5f3395209..ae17ee76cfc8 100755 --- a/osconfig/apiv1beta/auxiliary_go123.go +++ b/osconfig/apiv1beta/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/apiv1beta/doc.go b/osconfig/apiv1beta/doc.go index 6028a761ab79..6544dd881b6a 100755 --- a/osconfig/apiv1beta/doc.go +++ b/osconfig/apiv1beta/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/apiv1beta/helpers.go b/osconfig/apiv1beta/helpers.go index 18c5d7283e99..a53d79b5ed58 100755 --- a/osconfig/apiv1beta/helpers.go +++ b/osconfig/apiv1beta/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/apiv1beta/os_config_client.go b/osconfig/apiv1beta/os_config_client.go index d44cdea24de0..e4bdbe115f37 100755 --- a/osconfig/apiv1beta/os_config_client.go +++ b/osconfig/apiv1beta/os_config_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/apiv1beta/os_config_client_example_go123_test.go b/osconfig/apiv1beta/os_config_client_example_go123_test.go index eac7f165876f..4c3c365afd92 100644 --- a/osconfig/apiv1beta/os_config_client_example_go123_test.go +++ b/osconfig/apiv1beta/os_config_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/osconfig/apiv1beta/os_config_client_example_test.go b/osconfig/apiv1beta/os_config_client_example_test.go index 353e480beae9..b0dc2e076cb5 100644 --- a/osconfig/apiv1beta/os_config_client_example_test.go +++ b/osconfig/apiv1beta/os_config_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/oslogin/apiv1/auxiliary.go b/oslogin/apiv1/auxiliary.go index 7ac009427e36..53f5f4a3175c 100755 --- a/oslogin/apiv1/auxiliary.go +++ b/oslogin/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/oslogin/apiv1/auxiliary_go123.go b/oslogin/apiv1/auxiliary_go123.go index 3f9148162ac5..f9bd8dfd8cc5 100755 --- a/oslogin/apiv1/auxiliary_go123.go +++ b/oslogin/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/oslogin/apiv1/doc.go b/oslogin/apiv1/doc.go index 5961fdefd2a5..e90024c04830 100755 --- a/oslogin/apiv1/doc.go +++ b/oslogin/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/oslogin/apiv1/helpers.go b/oslogin/apiv1/helpers.go index 1684ee8282bc..b3f2112adb8f 100755 --- a/oslogin/apiv1/helpers.go +++ b/oslogin/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/oslogin/apiv1/os_login_client.go b/oslogin/apiv1/os_login_client.go index 0234789cb1b9..3bfd7d331e69 100755 --- a/oslogin/apiv1/os_login_client.go +++ b/oslogin/apiv1/os_login_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/oslogin/apiv1/os_login_client_example_go123_test.go b/oslogin/apiv1/os_login_client_example_go123_test.go index 99e995f92125..aca98c70192d 100644 --- a/oslogin/apiv1/os_login_client_example_go123_test.go +++ b/oslogin/apiv1/os_login_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/oslogin/apiv1/os_login_client_example_test.go b/oslogin/apiv1/os_login_client_example_test.go index c508ef01bdb8..af213300493f 100644 --- a/oslogin/apiv1/os_login_client_example_test.go +++ b/oslogin/apiv1/os_login_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/oslogin/apiv1beta/auxiliary.go b/oslogin/apiv1beta/auxiliary.go index 7ac009427e36..53f5f4a3175c 100755 --- a/oslogin/apiv1beta/auxiliary.go +++ b/oslogin/apiv1beta/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/oslogin/apiv1beta/auxiliary_go123.go b/oslogin/apiv1beta/auxiliary_go123.go index 3f9148162ac5..f9bd8dfd8cc5 100755 --- a/oslogin/apiv1beta/auxiliary_go123.go +++ b/oslogin/apiv1beta/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/oslogin/apiv1beta/doc.go b/oslogin/apiv1beta/doc.go index c96f95b7ba58..8c6d682dd40c 100755 --- a/oslogin/apiv1beta/doc.go +++ b/oslogin/apiv1beta/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/oslogin/apiv1beta/helpers.go b/oslogin/apiv1beta/helpers.go index 1684ee8282bc..b3f2112adb8f 100755 --- a/oslogin/apiv1beta/helpers.go +++ b/oslogin/apiv1beta/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/oslogin/apiv1beta/os_login_client.go b/oslogin/apiv1beta/os_login_client.go index a508e42494bd..6a4115d9f777 100755 --- a/oslogin/apiv1beta/os_login_client.go +++ b/oslogin/apiv1beta/os_login_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/oslogin/apiv1beta/os_login_client_example_go123_test.go b/oslogin/apiv1beta/os_login_client_example_go123_test.go index 99e995f92125..aca98c70192d 100644 --- a/oslogin/apiv1beta/os_login_client_example_go123_test.go +++ b/oslogin/apiv1beta/os_login_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/oslogin/apiv1beta/os_login_client_example_test.go b/oslogin/apiv1beta/os_login_client_example_test.go index 3fd109f36924..62e8cc718ec4 100644 --- a/oslogin/apiv1beta/os_login_client_example_test.go +++ b/oslogin/apiv1beta/os_login_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/parallelstore/apiv1/auxiliary.go b/parallelstore/apiv1/auxiliary.go index ec28452b4171..7bd947b1f4b9 100755 --- a/parallelstore/apiv1/auxiliary.go +++ b/parallelstore/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/parallelstore/apiv1/auxiliary_go123.go b/parallelstore/apiv1/auxiliary_go123.go index f3b5777df2dd..df14b8be18d8 100755 --- a/parallelstore/apiv1/auxiliary_go123.go +++ b/parallelstore/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/parallelstore/apiv1/doc.go b/parallelstore/apiv1/doc.go index 32597734ad63..0fdb45d8a996 100755 --- a/parallelstore/apiv1/doc.go +++ b/parallelstore/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/parallelstore/apiv1/helpers.go b/parallelstore/apiv1/helpers.go index 68f46282b9bf..06f4f98427c6 100755 --- a/parallelstore/apiv1/helpers.go +++ b/parallelstore/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/parallelstore/apiv1/parallelstore_client.go b/parallelstore/apiv1/parallelstore_client.go index a34e27bfbe9e..04f63e8c5cdb 100755 --- a/parallelstore/apiv1/parallelstore_client.go +++ b/parallelstore/apiv1/parallelstore_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/parallelstore/apiv1/parallelstore_client_example_go123_test.go b/parallelstore/apiv1/parallelstore_client_example_go123_test.go index 358672f99616..bc221cc6813d 100644 --- a/parallelstore/apiv1/parallelstore_client_example_go123_test.go +++ b/parallelstore/apiv1/parallelstore_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/parallelstore/apiv1/parallelstore_client_example_test.go b/parallelstore/apiv1/parallelstore_client_example_test.go index e0bff45e42d3..4ae61815802c 100644 --- a/parallelstore/apiv1/parallelstore_client_example_test.go +++ b/parallelstore/apiv1/parallelstore_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/parallelstore/apiv1beta/auxiliary.go b/parallelstore/apiv1beta/auxiliary.go index 2b586861a6ca..efdcf0594ac2 100755 --- a/parallelstore/apiv1beta/auxiliary.go +++ b/parallelstore/apiv1beta/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/parallelstore/apiv1beta/auxiliary_go123.go b/parallelstore/apiv1beta/auxiliary_go123.go index 17eac5a2341f..c35c2083c42d 100755 --- a/parallelstore/apiv1beta/auxiliary_go123.go +++ b/parallelstore/apiv1beta/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/parallelstore/apiv1beta/doc.go b/parallelstore/apiv1beta/doc.go index 0e7cc927fff7..3eabb18f1e7a 100755 --- a/parallelstore/apiv1beta/doc.go +++ b/parallelstore/apiv1beta/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/parallelstore/apiv1beta/helpers.go b/parallelstore/apiv1beta/helpers.go index 68f46282b9bf..06f4f98427c6 100755 --- a/parallelstore/apiv1beta/helpers.go +++ b/parallelstore/apiv1beta/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/parallelstore/apiv1beta/parallelstore_client.go b/parallelstore/apiv1beta/parallelstore_client.go index 9ec46152b226..5c6d309f16b5 100755 --- a/parallelstore/apiv1beta/parallelstore_client.go +++ b/parallelstore/apiv1beta/parallelstore_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/parallelstore/apiv1beta/parallelstore_client_example_go123_test.go b/parallelstore/apiv1beta/parallelstore_client_example_go123_test.go index bf25e3a6c7bd..a42868e3c6fb 100644 --- a/parallelstore/apiv1beta/parallelstore_client_example_go123_test.go +++ b/parallelstore/apiv1beta/parallelstore_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/parallelstore/apiv1beta/parallelstore_client_example_test.go b/parallelstore/apiv1beta/parallelstore_client_example_test.go index 00306e090049..4a26ff00728a 100644 --- a/parallelstore/apiv1beta/parallelstore_client_example_test.go +++ b/parallelstore/apiv1beta/parallelstore_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/phishingprotection/apiv1beta1/auxiliary.go b/phishingprotection/apiv1beta1/auxiliary.go index 3f2da0adda37..392a40b7555d 100755 --- a/phishingprotection/apiv1beta1/auxiliary.go +++ b/phishingprotection/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/phishingprotection/apiv1beta1/auxiliary_go123.go b/phishingprotection/apiv1beta1/auxiliary_go123.go index deb7a95f8eac..412e7811d544 100755 --- a/phishingprotection/apiv1beta1/auxiliary_go123.go +++ b/phishingprotection/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/phishingprotection/apiv1beta1/doc.go b/phishingprotection/apiv1beta1/doc.go index 9d57010281c8..1c78db5d47f9 100755 --- a/phishingprotection/apiv1beta1/doc.go +++ b/phishingprotection/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/phishingprotection/apiv1beta1/helpers.go b/phishingprotection/apiv1beta1/helpers.go index b0722d80b03b..8b8baee08c68 100755 --- a/phishingprotection/apiv1beta1/helpers.go +++ b/phishingprotection/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/phishingprotection/apiv1beta1/phishing_protection_service_v1_beta1_client.go b/phishingprotection/apiv1beta1/phishing_protection_service_v1_beta1_client.go index 867a65fa9c2f..55c5d0a73e01 100755 --- a/phishingprotection/apiv1beta1/phishing_protection_service_v1_beta1_client.go +++ b/phishingprotection/apiv1beta1/phishing_protection_service_v1_beta1_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/phishingprotection/apiv1beta1/phishing_protection_service_v1_beta1_client_example_go123_test.go b/phishingprotection/apiv1beta1/phishing_protection_service_v1_beta1_client_example_go123_test.go index 5f08af45fb53..ff0b28dbf068 100644 --- a/phishingprotection/apiv1beta1/phishing_protection_service_v1_beta1_client_example_go123_test.go +++ b/phishingprotection/apiv1beta1/phishing_protection_service_v1_beta1_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/phishingprotection/apiv1beta1/phishing_protection_service_v1_beta1_client_example_test.go b/phishingprotection/apiv1beta1/phishing_protection_service_v1_beta1_client_example_test.go index 56e9cd43a5f9..43b9d49b6081 100644 --- a/phishingprotection/apiv1beta1/phishing_protection_service_v1_beta1_client_example_test.go +++ b/phishingprotection/apiv1beta1/phishing_protection_service_v1_beta1_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/policysimulator/apiv1/auxiliary.go b/policysimulator/apiv1/auxiliary.go index 597e9db022ae..47fe0300f744 100755 --- a/policysimulator/apiv1/auxiliary.go +++ b/policysimulator/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/policysimulator/apiv1/auxiliary_go123.go b/policysimulator/apiv1/auxiliary_go123.go index 336c05ce797b..189d09b78f22 100755 --- a/policysimulator/apiv1/auxiliary_go123.go +++ b/policysimulator/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/policysimulator/apiv1/doc.go b/policysimulator/apiv1/doc.go index 2e3f53057d2d..c54c01fb5be3 100755 --- a/policysimulator/apiv1/doc.go +++ b/policysimulator/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/policysimulator/apiv1/helpers.go b/policysimulator/apiv1/helpers.go index 9682e2cfe745..0dc01e570339 100755 --- a/policysimulator/apiv1/helpers.go +++ b/policysimulator/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/policysimulator/apiv1/simulator_client.go b/policysimulator/apiv1/simulator_client.go index d9ff98d42739..03b99e3ba834 100755 --- a/policysimulator/apiv1/simulator_client.go +++ b/policysimulator/apiv1/simulator_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/policysimulator/apiv1/simulator_client_example_go123_test.go b/policysimulator/apiv1/simulator_client_example_go123_test.go index 1e174f2f40fc..a4b6ab54ce8e 100644 --- a/policysimulator/apiv1/simulator_client_example_go123_test.go +++ b/policysimulator/apiv1/simulator_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/policysimulator/apiv1/simulator_client_example_test.go b/policysimulator/apiv1/simulator_client_example_test.go index a5456673f278..e8e359129030 100644 --- a/policysimulator/apiv1/simulator_client_example_test.go +++ b/policysimulator/apiv1/simulator_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/policytroubleshooter/apiv1/auxiliary.go b/policytroubleshooter/apiv1/auxiliary.go index 8ad3439f3d86..1728cc6a7798 100755 --- a/policytroubleshooter/apiv1/auxiliary.go +++ b/policytroubleshooter/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/policytroubleshooter/apiv1/auxiliary_go123.go b/policytroubleshooter/apiv1/auxiliary_go123.go index e1ba278b080e..dcb554cda28e 100755 --- a/policytroubleshooter/apiv1/auxiliary_go123.go +++ b/policytroubleshooter/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/policytroubleshooter/apiv1/doc.go b/policytroubleshooter/apiv1/doc.go index fa058fe4b931..c3af9eb63955 100755 --- a/policytroubleshooter/apiv1/doc.go +++ b/policytroubleshooter/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/policytroubleshooter/apiv1/helpers.go b/policytroubleshooter/apiv1/helpers.go index f7b2bf658fae..1e0473b80c38 100755 --- a/policytroubleshooter/apiv1/helpers.go +++ b/policytroubleshooter/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/policytroubleshooter/apiv1/iam_checker_client.go b/policytroubleshooter/apiv1/iam_checker_client.go index cb014f07263b..1577f40fad4f 100755 --- a/policytroubleshooter/apiv1/iam_checker_client.go +++ b/policytroubleshooter/apiv1/iam_checker_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/policytroubleshooter/apiv1/iam_checker_client_example_go123_test.go b/policytroubleshooter/apiv1/iam_checker_client_example_go123_test.go index 5b85a321d040..1935fb0224ef 100644 --- a/policytroubleshooter/apiv1/iam_checker_client_example_go123_test.go +++ b/policytroubleshooter/apiv1/iam_checker_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/policytroubleshooter/apiv1/iam_checker_client_example_test.go b/policytroubleshooter/apiv1/iam_checker_client_example_test.go index e785d9cb0daa..65de70c3777e 100644 --- a/policytroubleshooter/apiv1/iam_checker_client_example_test.go +++ b/policytroubleshooter/apiv1/iam_checker_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/policytroubleshooter/iam/apiv3/auxiliary.go b/policytroubleshooter/iam/apiv3/auxiliary.go index d09ad9188791..5c6bd22896e5 100755 --- a/policytroubleshooter/iam/apiv3/auxiliary.go +++ b/policytroubleshooter/iam/apiv3/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/policytroubleshooter/iam/apiv3/auxiliary_go123.go b/policytroubleshooter/iam/apiv3/auxiliary_go123.go index 2ef3c5939acf..35d710187283 100755 --- a/policytroubleshooter/iam/apiv3/auxiliary_go123.go +++ b/policytroubleshooter/iam/apiv3/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/policytroubleshooter/iam/apiv3/doc.go b/policytroubleshooter/iam/apiv3/doc.go index ded3458da0f0..6824e1d756ea 100755 --- a/policytroubleshooter/iam/apiv3/doc.go +++ b/policytroubleshooter/iam/apiv3/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/policytroubleshooter/iam/apiv3/helpers.go b/policytroubleshooter/iam/apiv3/helpers.go index 84c1e4418a56..ed5d787cc06c 100755 --- a/policytroubleshooter/iam/apiv3/helpers.go +++ b/policytroubleshooter/iam/apiv3/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/policytroubleshooter/iam/apiv3/policy_troubleshooter_client.go b/policytroubleshooter/iam/apiv3/policy_troubleshooter_client.go index c0da9e8a8aa7..a770b450de8e 100755 --- a/policytroubleshooter/iam/apiv3/policy_troubleshooter_client.go +++ b/policytroubleshooter/iam/apiv3/policy_troubleshooter_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/policytroubleshooter/iam/apiv3/policy_troubleshooter_client_example_go123_test.go b/policytroubleshooter/iam/apiv3/policy_troubleshooter_client_example_go123_test.go index a5c65571017c..67c7bdc4b2ae 100644 --- a/policytroubleshooter/iam/apiv3/policy_troubleshooter_client_example_go123_test.go +++ b/policytroubleshooter/iam/apiv3/policy_troubleshooter_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/policytroubleshooter/iam/apiv3/policy_troubleshooter_client_example_test.go b/policytroubleshooter/iam/apiv3/policy_troubleshooter_client_example_test.go index b243bbf96caa..9ed15e009650 100644 --- a/policytroubleshooter/iam/apiv3/policy_troubleshooter_client_example_test.go +++ b/policytroubleshooter/iam/apiv3/policy_troubleshooter_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/privatecatalog/apiv1beta1/auxiliary.go b/privatecatalog/apiv1beta1/auxiliary.go index 4f63d7f6ead7..7c5486ca8676 100755 --- a/privatecatalog/apiv1beta1/auxiliary.go +++ b/privatecatalog/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/privatecatalog/apiv1beta1/auxiliary_go123.go b/privatecatalog/apiv1beta1/auxiliary_go123.go index cbabe29d8740..c46da6c15491 100755 --- a/privatecatalog/apiv1beta1/auxiliary_go123.go +++ b/privatecatalog/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/privatecatalog/apiv1beta1/doc.go b/privatecatalog/apiv1beta1/doc.go index 8fd4738b7b16..f1ccf4ed4a50 100755 --- a/privatecatalog/apiv1beta1/doc.go +++ b/privatecatalog/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/privatecatalog/apiv1beta1/helpers.go b/privatecatalog/apiv1beta1/helpers.go index 36e37c22f525..c7f2578433a9 100755 --- a/privatecatalog/apiv1beta1/helpers.go +++ b/privatecatalog/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/privatecatalog/apiv1beta1/private_catalog_client.go b/privatecatalog/apiv1beta1/private_catalog_client.go index 4262deb08473..70a60a9e3054 100755 --- a/privatecatalog/apiv1beta1/private_catalog_client.go +++ b/privatecatalog/apiv1beta1/private_catalog_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/privatecatalog/apiv1beta1/private_catalog_client_example_go123_test.go b/privatecatalog/apiv1beta1/private_catalog_client_example_go123_test.go index 94972a1c96b0..3a6553f82c34 100644 --- a/privatecatalog/apiv1beta1/private_catalog_client_example_go123_test.go +++ b/privatecatalog/apiv1beta1/private_catalog_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/privatecatalog/apiv1beta1/private_catalog_client_example_test.go b/privatecatalog/apiv1beta1/private_catalog_client_example_test.go index 21f89547cfc0..6b4dd40acfff 100644 --- a/privatecatalog/apiv1beta1/private_catalog_client_example_test.go +++ b/privatecatalog/apiv1beta1/private_catalog_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/privilegedaccessmanager/apiv1/auxiliary.go b/privilegedaccessmanager/apiv1/auxiliary.go index 17c94363a3ae..f6c7ea01ecae 100755 --- a/privilegedaccessmanager/apiv1/auxiliary.go +++ b/privilegedaccessmanager/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/privilegedaccessmanager/apiv1/auxiliary_go123.go b/privilegedaccessmanager/apiv1/auxiliary_go123.go index 06bccc84d9ce..75b35b0a8711 100755 --- a/privilegedaccessmanager/apiv1/auxiliary_go123.go +++ b/privilegedaccessmanager/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/privilegedaccessmanager/apiv1/doc.go b/privilegedaccessmanager/apiv1/doc.go index 7e428bb71ceb..39139635c7f5 100755 --- a/privilegedaccessmanager/apiv1/doc.go +++ b/privilegedaccessmanager/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/privilegedaccessmanager/apiv1/helpers.go b/privilegedaccessmanager/apiv1/helpers.go index b306e81b70ac..a8a282862e0b 100755 --- a/privilegedaccessmanager/apiv1/helpers.go +++ b/privilegedaccessmanager/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/privilegedaccessmanager/apiv1/privileged_access_manager_client.go b/privilegedaccessmanager/apiv1/privileged_access_manager_client.go index e3a3b703bd0b..e84fd9243e7e 100755 --- a/privilegedaccessmanager/apiv1/privileged_access_manager_client.go +++ b/privilegedaccessmanager/apiv1/privileged_access_manager_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/privilegedaccessmanager/apiv1/privileged_access_manager_client_example_go123_test.go b/privilegedaccessmanager/apiv1/privileged_access_manager_client_example_go123_test.go index 84f73794dc50..628437171759 100644 --- a/privilegedaccessmanager/apiv1/privileged_access_manager_client_example_go123_test.go +++ b/privilegedaccessmanager/apiv1/privileged_access_manager_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/privilegedaccessmanager/apiv1/privileged_access_manager_client_example_test.go b/privilegedaccessmanager/apiv1/privileged_access_manager_client_example_test.go index 85636aa83a28..eb64df8e654c 100644 --- a/privilegedaccessmanager/apiv1/privileged_access_manager_client_example_test.go +++ b/privilegedaccessmanager/apiv1/privileged_access_manager_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsub/apiv1/auxiliary.go b/pubsub/apiv1/auxiliary.go index 46380a0e05da..6a4cd19ec2dc 100755 --- a/pubsub/apiv1/auxiliary.go +++ b/pubsub/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsub/apiv1/auxiliary_go123.go b/pubsub/apiv1/auxiliary_go123.go index c7a04ffb92e9..d449e7bedff6 100755 --- a/pubsub/apiv1/auxiliary_go123.go +++ b/pubsub/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsub/apiv1/doc.go b/pubsub/apiv1/doc.go index 03aeef34e391..d3eaec33ee21 100755 --- a/pubsub/apiv1/doc.go +++ b/pubsub/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsub/apiv1/helpers.go b/pubsub/apiv1/helpers.go index 942aeb294a07..54abe920aca9 100755 --- a/pubsub/apiv1/helpers.go +++ b/pubsub/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsub/apiv1/publisher_client.go b/pubsub/apiv1/publisher_client.go index 0417a2a16276..ac986410fc4d 100755 --- a/pubsub/apiv1/publisher_client.go +++ b/pubsub/apiv1/publisher_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsub/apiv1/publisher_client_example_go123_test.go b/pubsub/apiv1/publisher_client_example_go123_test.go index 0fb0c1276c31..a352ca861e3b 100644 --- a/pubsub/apiv1/publisher_client_example_go123_test.go +++ b/pubsub/apiv1/publisher_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsub/apiv1/publisher_client_example_test.go b/pubsub/apiv1/publisher_client_example_test.go index 09391a8f3ca8..714809ae468e 100644 --- a/pubsub/apiv1/publisher_client_example_test.go +++ b/pubsub/apiv1/publisher_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsub/apiv1/schema_client.go b/pubsub/apiv1/schema_client.go index 0fd29804bb8e..0cc01c52d9d7 100755 --- a/pubsub/apiv1/schema_client.go +++ b/pubsub/apiv1/schema_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsub/apiv1/schema_client_example_go123_test.go b/pubsub/apiv1/schema_client_example_go123_test.go index c11f9f0c5027..024ebcb22dc1 100644 --- a/pubsub/apiv1/schema_client_example_go123_test.go +++ b/pubsub/apiv1/schema_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsub/apiv1/schema_client_example_test.go b/pubsub/apiv1/schema_client_example_test.go index fb946b146402..db0f0f6ffb48 100644 --- a/pubsub/apiv1/schema_client_example_test.go +++ b/pubsub/apiv1/schema_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsub/apiv1/subscriber_client.go b/pubsub/apiv1/subscriber_client.go index 38dc0fcb34e6..b89aa4ec2f61 100755 --- a/pubsub/apiv1/subscriber_client.go +++ b/pubsub/apiv1/subscriber_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsub/apiv1/subscriber_client_example_go123_test.go b/pubsub/apiv1/subscriber_client_example_go123_test.go index d686289e1572..2053e4bd2c1e 100644 --- a/pubsub/apiv1/subscriber_client_example_go123_test.go +++ b/pubsub/apiv1/subscriber_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsub/apiv1/subscriber_client_example_test.go b/pubsub/apiv1/subscriber_client_example_test.go index d0780573c770..e0919c9cf126 100644 --- a/pubsub/apiv1/subscriber_client_example_test.go +++ b/pubsub/apiv1/subscriber_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsublite/apiv1/admin_client.go b/pubsublite/apiv1/admin_client.go index faff4cc118ca..5dab7d0e2447 100755 --- a/pubsublite/apiv1/admin_client.go +++ b/pubsublite/apiv1/admin_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsublite/apiv1/admin_client_example_go123_test.go b/pubsublite/apiv1/admin_client_example_go123_test.go index 0acf43b0ad3b..7b9fc184f5ea 100644 --- a/pubsublite/apiv1/admin_client_example_go123_test.go +++ b/pubsublite/apiv1/admin_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsublite/apiv1/admin_client_example_test.go b/pubsublite/apiv1/admin_client_example_test.go index 668bab37dd48..634d528eabef 100644 --- a/pubsublite/apiv1/admin_client_example_test.go +++ b/pubsublite/apiv1/admin_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsublite/apiv1/auxiliary.go b/pubsublite/apiv1/auxiliary.go index 508b78f36291..c72185921555 100755 --- a/pubsublite/apiv1/auxiliary.go +++ b/pubsublite/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsublite/apiv1/auxiliary_go123.go b/pubsublite/apiv1/auxiliary_go123.go index 714ad284d5a3..7e057bb2d0fa 100755 --- a/pubsublite/apiv1/auxiliary_go123.go +++ b/pubsublite/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsublite/apiv1/cursor_client.go b/pubsublite/apiv1/cursor_client.go index 54791c076495..64094043fd40 100755 --- a/pubsublite/apiv1/cursor_client.go +++ b/pubsublite/apiv1/cursor_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsublite/apiv1/cursor_client_example_go123_test.go b/pubsublite/apiv1/cursor_client_example_go123_test.go index 478d7d20f5b8..3401a29ea2ff 100644 --- a/pubsublite/apiv1/cursor_client_example_go123_test.go +++ b/pubsublite/apiv1/cursor_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsublite/apiv1/cursor_client_example_test.go b/pubsublite/apiv1/cursor_client_example_test.go index 71d033f30172..febd95d80fbb 100644 --- a/pubsublite/apiv1/cursor_client_example_test.go +++ b/pubsublite/apiv1/cursor_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsublite/apiv1/doc.go b/pubsublite/apiv1/doc.go index 7338cc07405e..8dcc125ec921 100755 --- a/pubsublite/apiv1/doc.go +++ b/pubsublite/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsublite/apiv1/helpers.go b/pubsublite/apiv1/helpers.go index fb967a09324f..484670b32cd0 100755 --- a/pubsublite/apiv1/helpers.go +++ b/pubsublite/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsublite/apiv1/partition_assignment_client.go b/pubsublite/apiv1/partition_assignment_client.go index 458e6d697893..9d053b553ef7 100755 --- a/pubsublite/apiv1/partition_assignment_client.go +++ b/pubsublite/apiv1/partition_assignment_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsublite/apiv1/partition_assignment_client_example_go123_test.go b/pubsublite/apiv1/partition_assignment_client_example_go123_test.go index 1392e678b791..c4f5075a80db 100644 --- a/pubsublite/apiv1/partition_assignment_client_example_go123_test.go +++ b/pubsublite/apiv1/partition_assignment_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsublite/apiv1/partition_assignment_client_example_test.go b/pubsublite/apiv1/partition_assignment_client_example_test.go index c755b6c309e3..9f8662ab518a 100644 --- a/pubsublite/apiv1/partition_assignment_client_example_test.go +++ b/pubsublite/apiv1/partition_assignment_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsublite/apiv1/publisher_client.go b/pubsublite/apiv1/publisher_client.go index bc48eb02c86f..f1017fd46fb0 100755 --- a/pubsublite/apiv1/publisher_client.go +++ b/pubsublite/apiv1/publisher_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsublite/apiv1/publisher_client_example_go123_test.go b/pubsublite/apiv1/publisher_client_example_go123_test.go index 749bbad0c1e4..9ad2b42f019a 100644 --- a/pubsublite/apiv1/publisher_client_example_go123_test.go +++ b/pubsublite/apiv1/publisher_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsublite/apiv1/publisher_client_example_test.go b/pubsublite/apiv1/publisher_client_example_test.go index 1d9cac820aee..b7ff85734197 100644 --- a/pubsublite/apiv1/publisher_client_example_test.go +++ b/pubsublite/apiv1/publisher_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsublite/apiv1/subscriber_client.go b/pubsublite/apiv1/subscriber_client.go index ece2f5eca826..0309ce657058 100755 --- a/pubsublite/apiv1/subscriber_client.go +++ b/pubsublite/apiv1/subscriber_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsublite/apiv1/subscriber_client_example_go123_test.go b/pubsublite/apiv1/subscriber_client_example_go123_test.go index c327323e65d0..597074a5f0dd 100644 --- a/pubsublite/apiv1/subscriber_client_example_go123_test.go +++ b/pubsublite/apiv1/subscriber_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsublite/apiv1/subscriber_client_example_test.go b/pubsublite/apiv1/subscriber_client_example_test.go index 6c5c5c5cf92e..ff268b8cefdd 100644 --- a/pubsublite/apiv1/subscriber_client_example_test.go +++ b/pubsublite/apiv1/subscriber_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsublite/apiv1/topic_stats_client.go b/pubsublite/apiv1/topic_stats_client.go index c0cf4fd7f44c..eb5bb608fad5 100755 --- a/pubsublite/apiv1/topic_stats_client.go +++ b/pubsublite/apiv1/topic_stats_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsublite/apiv1/topic_stats_client_example_go123_test.go b/pubsublite/apiv1/topic_stats_client_example_go123_test.go index 3040a2e6d258..03c714f57060 100644 --- a/pubsublite/apiv1/topic_stats_client_example_go123_test.go +++ b/pubsublite/apiv1/topic_stats_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/pubsublite/apiv1/topic_stats_client_example_test.go b/pubsublite/apiv1/topic_stats_client_example_test.go index bd23dd8a908e..4fc4c0cbeb49 100644 --- a/pubsublite/apiv1/topic_stats_client_example_test.go +++ b/pubsublite/apiv1/topic_stats_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/rapidmigrationassessment/apiv1/auxiliary.go b/rapidmigrationassessment/apiv1/auxiliary.go index efaa9b664f0a..ede3f1c276f3 100755 --- a/rapidmigrationassessment/apiv1/auxiliary.go +++ b/rapidmigrationassessment/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/rapidmigrationassessment/apiv1/auxiliary_go123.go b/rapidmigrationassessment/apiv1/auxiliary_go123.go index 806d7ef091dc..8a4ada8c1452 100755 --- a/rapidmigrationassessment/apiv1/auxiliary_go123.go +++ b/rapidmigrationassessment/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/rapidmigrationassessment/apiv1/doc.go b/rapidmigrationassessment/apiv1/doc.go index cc7855bfe22c..acf20f177dd6 100755 --- a/rapidmigrationassessment/apiv1/doc.go +++ b/rapidmigrationassessment/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/rapidmigrationassessment/apiv1/helpers.go b/rapidmigrationassessment/apiv1/helpers.go index 312badb4a8a9..465bf12b3731 100755 --- a/rapidmigrationassessment/apiv1/helpers.go +++ b/rapidmigrationassessment/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/rapidmigrationassessment/apiv1/rapid_migration_assessment_client.go b/rapidmigrationassessment/apiv1/rapid_migration_assessment_client.go index 3e088ccec92c..db9219a9d826 100755 --- a/rapidmigrationassessment/apiv1/rapid_migration_assessment_client.go +++ b/rapidmigrationassessment/apiv1/rapid_migration_assessment_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/rapidmigrationassessment/apiv1/rapid_migration_assessment_client_example_go123_test.go b/rapidmigrationassessment/apiv1/rapid_migration_assessment_client_example_go123_test.go index 9e31045eef85..ac50c3a9b4b1 100644 --- a/rapidmigrationassessment/apiv1/rapid_migration_assessment_client_example_go123_test.go +++ b/rapidmigrationassessment/apiv1/rapid_migration_assessment_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/rapidmigrationassessment/apiv1/rapid_migration_assessment_client_example_test.go b/rapidmigrationassessment/apiv1/rapid_migration_assessment_client_example_test.go index 1d48421696ea..ab3f21d712ff 100644 --- a/rapidmigrationassessment/apiv1/rapid_migration_assessment_client_example_test.go +++ b/rapidmigrationassessment/apiv1/rapid_migration_assessment_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recaptchaenterprise/apiv1/auxiliary.go b/recaptchaenterprise/apiv1/auxiliary.go index 423f42102c82..95a93bf5c448 100755 --- a/recaptchaenterprise/apiv1/auxiliary.go +++ b/recaptchaenterprise/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recaptchaenterprise/apiv1/auxiliary_go123.go b/recaptchaenterprise/apiv1/auxiliary_go123.go index 1dd6aa84a9b8..def4a6ad6064 100755 --- a/recaptchaenterprise/apiv1/auxiliary_go123.go +++ b/recaptchaenterprise/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recaptchaenterprise/apiv1/doc.go b/recaptchaenterprise/apiv1/doc.go index ff37dceaadfe..e98b812ecd77 100755 --- a/recaptchaenterprise/apiv1/doc.go +++ b/recaptchaenterprise/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recaptchaenterprise/apiv1/helpers.go b/recaptchaenterprise/apiv1/helpers.go index 96fe0400a154..7c0ffb566e20 100755 --- a/recaptchaenterprise/apiv1/helpers.go +++ b/recaptchaenterprise/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recaptchaenterprise/apiv1/recaptcha_enterprise_client.go b/recaptchaenterprise/apiv1/recaptcha_enterprise_client.go index b5885f005e09..9ba8bca780b2 100755 --- a/recaptchaenterprise/apiv1/recaptcha_enterprise_client.go +++ b/recaptchaenterprise/apiv1/recaptcha_enterprise_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recaptchaenterprise/apiv1/recaptcha_enterprise_client_example_go123_test.go b/recaptchaenterprise/apiv1/recaptcha_enterprise_client_example_go123_test.go index 954b6fcfe954..6b5c1c40760e 100644 --- a/recaptchaenterprise/apiv1/recaptcha_enterprise_client_example_go123_test.go +++ b/recaptchaenterprise/apiv1/recaptcha_enterprise_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recaptchaenterprise/apiv1/recaptcha_enterprise_client_example_test.go b/recaptchaenterprise/apiv1/recaptcha_enterprise_client_example_test.go index c621b9f1ad97..4669db579c2f 100644 --- a/recaptchaenterprise/apiv1/recaptcha_enterprise_client_example_test.go +++ b/recaptchaenterprise/apiv1/recaptcha_enterprise_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recaptchaenterprise/apiv1beta1/auxiliary.go b/recaptchaenterprise/apiv1beta1/auxiliary.go index f1c7f3833c77..55710438278e 100755 --- a/recaptchaenterprise/apiv1beta1/auxiliary.go +++ b/recaptchaenterprise/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recaptchaenterprise/apiv1beta1/auxiliary_go123.go b/recaptchaenterprise/apiv1beta1/auxiliary_go123.go index 709b617817fc..0f7358a7555b 100755 --- a/recaptchaenterprise/apiv1beta1/auxiliary_go123.go +++ b/recaptchaenterprise/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recaptchaenterprise/apiv1beta1/doc.go b/recaptchaenterprise/apiv1beta1/doc.go index d95a000bd343..5361e1c7c4d2 100755 --- a/recaptchaenterprise/apiv1beta1/doc.go +++ b/recaptchaenterprise/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recaptchaenterprise/apiv1beta1/helpers.go b/recaptchaenterprise/apiv1beta1/helpers.go index 300167fad331..470dc3a5a152 100755 --- a/recaptchaenterprise/apiv1beta1/helpers.go +++ b/recaptchaenterprise/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recaptchaenterprise/apiv1beta1/recaptcha_enterprise_service_v1_beta1_client.go b/recaptchaenterprise/apiv1beta1/recaptcha_enterprise_service_v1_beta1_client.go index 15f5f59d2019..2389de8d73df 100755 --- a/recaptchaenterprise/apiv1beta1/recaptcha_enterprise_service_v1_beta1_client.go +++ b/recaptchaenterprise/apiv1beta1/recaptcha_enterprise_service_v1_beta1_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recaptchaenterprise/apiv1beta1/recaptcha_enterprise_service_v1_beta1_client_example_go123_test.go b/recaptchaenterprise/apiv1beta1/recaptcha_enterprise_service_v1_beta1_client_example_go123_test.go index 0688cfe62a4d..cd6e2ddaae31 100644 --- a/recaptchaenterprise/apiv1beta1/recaptcha_enterprise_service_v1_beta1_client_example_go123_test.go +++ b/recaptchaenterprise/apiv1beta1/recaptcha_enterprise_service_v1_beta1_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recaptchaenterprise/apiv1beta1/recaptcha_enterprise_service_v1_beta1_client_example_test.go b/recaptchaenterprise/apiv1beta1/recaptcha_enterprise_service_v1_beta1_client_example_test.go index 4f38a04c61d2..f111c8fea0ff 100644 --- a/recaptchaenterprise/apiv1beta1/recaptcha_enterprise_service_v1_beta1_client_example_test.go +++ b/recaptchaenterprise/apiv1beta1/recaptcha_enterprise_service_v1_beta1_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommendationengine/apiv1beta1/auxiliary.go b/recommendationengine/apiv1beta1/auxiliary.go index d0e3944a777d..928e5aa1c611 100755 --- a/recommendationengine/apiv1beta1/auxiliary.go +++ b/recommendationengine/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommendationengine/apiv1beta1/auxiliary_go123.go b/recommendationengine/apiv1beta1/auxiliary_go123.go index eaa54bc7cd37..3ee61c3ab7fe 100755 --- a/recommendationengine/apiv1beta1/auxiliary_go123.go +++ b/recommendationengine/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommendationengine/apiv1beta1/catalog_client.go b/recommendationengine/apiv1beta1/catalog_client.go index f039d35ca747..60ba08e63986 100755 --- a/recommendationengine/apiv1beta1/catalog_client.go +++ b/recommendationengine/apiv1beta1/catalog_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommendationengine/apiv1beta1/catalog_client_example_go123_test.go b/recommendationengine/apiv1beta1/catalog_client_example_go123_test.go index d5ce1407656a..346e6ebb1121 100644 --- a/recommendationengine/apiv1beta1/catalog_client_example_go123_test.go +++ b/recommendationengine/apiv1beta1/catalog_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommendationengine/apiv1beta1/catalog_client_example_test.go b/recommendationengine/apiv1beta1/catalog_client_example_test.go index 28c8fb66313f..be421b16a937 100644 --- a/recommendationengine/apiv1beta1/catalog_client_example_test.go +++ b/recommendationengine/apiv1beta1/catalog_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommendationengine/apiv1beta1/doc.go b/recommendationengine/apiv1beta1/doc.go index 2ff43995af12..cc0433c9e964 100755 --- a/recommendationengine/apiv1beta1/doc.go +++ b/recommendationengine/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommendationengine/apiv1beta1/helpers.go b/recommendationengine/apiv1beta1/helpers.go index fbfc12b34a7d..d8ddf9333d8f 100755 --- a/recommendationengine/apiv1beta1/helpers.go +++ b/recommendationengine/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommendationengine/apiv1beta1/prediction_api_key_registry_client.go b/recommendationengine/apiv1beta1/prediction_api_key_registry_client.go index 9193cd28c6e1..1578893a3ba3 100755 --- a/recommendationengine/apiv1beta1/prediction_api_key_registry_client.go +++ b/recommendationengine/apiv1beta1/prediction_api_key_registry_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommendationengine/apiv1beta1/prediction_api_key_registry_client_example_go123_test.go b/recommendationengine/apiv1beta1/prediction_api_key_registry_client_example_go123_test.go index 591c997ef964..58692e6ac37e 100644 --- a/recommendationengine/apiv1beta1/prediction_api_key_registry_client_example_go123_test.go +++ b/recommendationengine/apiv1beta1/prediction_api_key_registry_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommendationengine/apiv1beta1/prediction_api_key_registry_client_example_test.go b/recommendationengine/apiv1beta1/prediction_api_key_registry_client_example_test.go index bdd0034e6b25..c8552550d7e2 100644 --- a/recommendationengine/apiv1beta1/prediction_api_key_registry_client_example_test.go +++ b/recommendationengine/apiv1beta1/prediction_api_key_registry_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommendationengine/apiv1beta1/prediction_client.go b/recommendationengine/apiv1beta1/prediction_client.go index 29224caadffd..101baac95023 100755 --- a/recommendationengine/apiv1beta1/prediction_client.go +++ b/recommendationengine/apiv1beta1/prediction_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommendationengine/apiv1beta1/prediction_client_example_go123_test.go b/recommendationengine/apiv1beta1/prediction_client_example_go123_test.go index 989b859e1388..1f5afcf4b1ce 100644 --- a/recommendationengine/apiv1beta1/prediction_client_example_go123_test.go +++ b/recommendationengine/apiv1beta1/prediction_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommendationengine/apiv1beta1/prediction_client_example_test.go b/recommendationengine/apiv1beta1/prediction_client_example_test.go index c544fc7f8f85..b6d86579ea54 100644 --- a/recommendationengine/apiv1beta1/prediction_client_example_test.go +++ b/recommendationengine/apiv1beta1/prediction_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommendationengine/apiv1beta1/user_event_client.go b/recommendationengine/apiv1beta1/user_event_client.go index 827afdd1896d..fbbb59f50e3a 100755 --- a/recommendationengine/apiv1beta1/user_event_client.go +++ b/recommendationengine/apiv1beta1/user_event_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommendationengine/apiv1beta1/user_event_client_example_go123_test.go b/recommendationengine/apiv1beta1/user_event_client_example_go123_test.go index aac7edb35a5f..562e898c5828 100644 --- a/recommendationengine/apiv1beta1/user_event_client_example_go123_test.go +++ b/recommendationengine/apiv1beta1/user_event_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommendationengine/apiv1beta1/user_event_client_example_test.go b/recommendationengine/apiv1beta1/user_event_client_example_test.go index 4a789ab182bf..cf764ea35a0d 100644 --- a/recommendationengine/apiv1beta1/user_event_client_example_test.go +++ b/recommendationengine/apiv1beta1/user_event_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommender/apiv1/auxiliary.go b/recommender/apiv1/auxiliary.go index 5c796bbd27bc..7a0a5c371dfc 100755 --- a/recommender/apiv1/auxiliary.go +++ b/recommender/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommender/apiv1/auxiliary_go123.go b/recommender/apiv1/auxiliary_go123.go index 10c86b7fb28d..18c46d24d187 100755 --- a/recommender/apiv1/auxiliary_go123.go +++ b/recommender/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommender/apiv1/doc.go b/recommender/apiv1/doc.go index a172e85c2cb6..83642359f474 100755 --- a/recommender/apiv1/doc.go +++ b/recommender/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommender/apiv1/helpers.go b/recommender/apiv1/helpers.go index c8e247309e0d..c0ba92b72c90 100755 --- a/recommender/apiv1/helpers.go +++ b/recommender/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommender/apiv1/recommender_client.go b/recommender/apiv1/recommender_client.go index 04ba9d995687..ba9591715e13 100755 --- a/recommender/apiv1/recommender_client.go +++ b/recommender/apiv1/recommender_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommender/apiv1/recommender_client_example_go123_test.go b/recommender/apiv1/recommender_client_example_go123_test.go index 89c55f629116..73a44f6d6a6a 100644 --- a/recommender/apiv1/recommender_client_example_go123_test.go +++ b/recommender/apiv1/recommender_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommender/apiv1/recommender_client_example_test.go b/recommender/apiv1/recommender_client_example_test.go index 3f5807a155e7..5cb1d8f6942f 100644 --- a/recommender/apiv1/recommender_client_example_test.go +++ b/recommender/apiv1/recommender_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommender/apiv1beta1/auxiliary.go b/recommender/apiv1beta1/auxiliary.go index 2ac9fc762cc4..dd9b7fdd37c1 100755 --- a/recommender/apiv1beta1/auxiliary.go +++ b/recommender/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommender/apiv1beta1/auxiliary_go123.go b/recommender/apiv1beta1/auxiliary_go123.go index f6772e800d31..af693eafd2b4 100755 --- a/recommender/apiv1beta1/auxiliary_go123.go +++ b/recommender/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommender/apiv1beta1/doc.go b/recommender/apiv1beta1/doc.go index 9b433aa1ad74..473f884685a6 100755 --- a/recommender/apiv1beta1/doc.go +++ b/recommender/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommender/apiv1beta1/helpers.go b/recommender/apiv1beta1/helpers.go index c8e247309e0d..c0ba92b72c90 100755 --- a/recommender/apiv1beta1/helpers.go +++ b/recommender/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommender/apiv1beta1/recommender_client.go b/recommender/apiv1beta1/recommender_client.go index 245508aee91d..321eb78120f2 100755 --- a/recommender/apiv1beta1/recommender_client.go +++ b/recommender/apiv1beta1/recommender_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommender/apiv1beta1/recommender_client_example_go123_test.go b/recommender/apiv1beta1/recommender_client_example_go123_test.go index 01dee216ab54..70a187155261 100644 --- a/recommender/apiv1beta1/recommender_client_example_go123_test.go +++ b/recommender/apiv1beta1/recommender_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/recommender/apiv1beta1/recommender_client_example_test.go b/recommender/apiv1beta1/recommender_client_example_test.go index ac111982d49b..6ae62b9a5608 100644 --- a/recommender/apiv1beta1/recommender_client_example_test.go +++ b/recommender/apiv1beta1/recommender_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/redis/apiv1/auxiliary.go b/redis/apiv1/auxiliary.go index 3c133aaa93ae..2815a948e460 100755 --- a/redis/apiv1/auxiliary.go +++ b/redis/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/redis/apiv1/auxiliary_go123.go b/redis/apiv1/auxiliary_go123.go index 65d36cf69882..0f3affd2ffba 100755 --- a/redis/apiv1/auxiliary_go123.go +++ b/redis/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/redis/apiv1/cloud_redis_client.go b/redis/apiv1/cloud_redis_client.go index 1ec572996001..0498f997a814 100755 --- a/redis/apiv1/cloud_redis_client.go +++ b/redis/apiv1/cloud_redis_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/redis/apiv1/cloud_redis_client_example_go123_test.go b/redis/apiv1/cloud_redis_client_example_go123_test.go index ef61f02f5ae2..fca32a8d7fb7 100644 --- a/redis/apiv1/cloud_redis_client_example_go123_test.go +++ b/redis/apiv1/cloud_redis_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/redis/apiv1/cloud_redis_client_example_test.go b/redis/apiv1/cloud_redis_client_example_test.go index 4126fc20e4a4..7661966b0cfd 100644 --- a/redis/apiv1/cloud_redis_client_example_test.go +++ b/redis/apiv1/cloud_redis_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/redis/apiv1/doc.go b/redis/apiv1/doc.go index ef2fed3dcd5e..dfce5128628a 100755 --- a/redis/apiv1/doc.go +++ b/redis/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/redis/apiv1/helpers.go b/redis/apiv1/helpers.go index 079925209a55..a51d8c93d17c 100755 --- a/redis/apiv1/helpers.go +++ b/redis/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/redis/apiv1beta1/auxiliary.go b/redis/apiv1beta1/auxiliary.go index 49b919466c60..c1453f7edd44 100755 --- a/redis/apiv1beta1/auxiliary.go +++ b/redis/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/redis/apiv1beta1/auxiliary_go123.go b/redis/apiv1beta1/auxiliary_go123.go index bf6fee3b7b5a..ee935e00166e 100755 --- a/redis/apiv1beta1/auxiliary_go123.go +++ b/redis/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/redis/apiv1beta1/cloud_redis_client.go b/redis/apiv1beta1/cloud_redis_client.go index 4a32afbbd522..35dd79393dad 100755 --- a/redis/apiv1beta1/cloud_redis_client.go +++ b/redis/apiv1beta1/cloud_redis_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/redis/apiv1beta1/cloud_redis_client_example_go123_test.go b/redis/apiv1beta1/cloud_redis_client_example_go123_test.go index f8b255ca065b..74a34df5b45d 100644 --- a/redis/apiv1beta1/cloud_redis_client_example_go123_test.go +++ b/redis/apiv1beta1/cloud_redis_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/redis/apiv1beta1/cloud_redis_client_example_test.go b/redis/apiv1beta1/cloud_redis_client_example_test.go index 5f94948dde8d..45afe632d460 100644 --- a/redis/apiv1beta1/cloud_redis_client_example_test.go +++ b/redis/apiv1beta1/cloud_redis_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/redis/apiv1beta1/doc.go b/redis/apiv1beta1/doc.go index 6a7b0e7e3b29..0410caf044b8 100755 --- a/redis/apiv1beta1/doc.go +++ b/redis/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/redis/apiv1beta1/helpers.go b/redis/apiv1beta1/helpers.go index 079925209a55..a51d8c93d17c 100755 --- a/redis/apiv1beta1/helpers.go +++ b/redis/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/redis/cluster/apiv1/auxiliary.go b/redis/cluster/apiv1/auxiliary.go index 51fd332ec1c4..b949336d7820 100755 --- a/redis/cluster/apiv1/auxiliary.go +++ b/redis/cluster/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/redis/cluster/apiv1/auxiliary_go123.go b/redis/cluster/apiv1/auxiliary_go123.go index fa21837954dd..d953265178ff 100755 --- a/redis/cluster/apiv1/auxiliary_go123.go +++ b/redis/cluster/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/redis/cluster/apiv1/cloud_redis_cluster_client.go b/redis/cluster/apiv1/cloud_redis_cluster_client.go index 6bf6dd5ba7bc..130508eda4be 100755 --- a/redis/cluster/apiv1/cloud_redis_cluster_client.go +++ b/redis/cluster/apiv1/cloud_redis_cluster_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/redis/cluster/apiv1/cloud_redis_cluster_client_example_go123_test.go b/redis/cluster/apiv1/cloud_redis_cluster_client_example_go123_test.go index 44cb19f18239..eb21aa19c553 100644 --- a/redis/cluster/apiv1/cloud_redis_cluster_client_example_go123_test.go +++ b/redis/cluster/apiv1/cloud_redis_cluster_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/redis/cluster/apiv1/cloud_redis_cluster_client_example_test.go b/redis/cluster/apiv1/cloud_redis_cluster_client_example_test.go index 037ee7a29f1e..ede31be88350 100644 --- a/redis/cluster/apiv1/cloud_redis_cluster_client_example_test.go +++ b/redis/cluster/apiv1/cloud_redis_cluster_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/redis/cluster/apiv1/doc.go b/redis/cluster/apiv1/doc.go index 1c592dd16e3e..a95046e31e3b 100755 --- a/redis/cluster/apiv1/doc.go +++ b/redis/cluster/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/redis/cluster/apiv1/helpers.go b/redis/cluster/apiv1/helpers.go index f9ed4b56e665..7ce91f58a878 100755 --- a/redis/cluster/apiv1/helpers.go +++ b/redis/cluster/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv2/auxiliary.go b/resourcemanager/apiv2/auxiliary.go index f5f98174b427..b3912418fb74 100755 --- a/resourcemanager/apiv2/auxiliary.go +++ b/resourcemanager/apiv2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv2/auxiliary_go123.go b/resourcemanager/apiv2/auxiliary_go123.go index 28680d28a694..195f60146af3 100755 --- a/resourcemanager/apiv2/auxiliary_go123.go +++ b/resourcemanager/apiv2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv2/doc.go b/resourcemanager/apiv2/doc.go index 88dc718d831d..7219e7362c10 100755 --- a/resourcemanager/apiv2/doc.go +++ b/resourcemanager/apiv2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv2/folders_client.go b/resourcemanager/apiv2/folders_client.go index 6dedd6330c51..98411090540f 100755 --- a/resourcemanager/apiv2/folders_client.go +++ b/resourcemanager/apiv2/folders_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv2/folders_client_example_go123_test.go b/resourcemanager/apiv2/folders_client_example_go123_test.go index 5a73f7da27d5..31cd2e4d2e2f 100644 --- a/resourcemanager/apiv2/folders_client_example_go123_test.go +++ b/resourcemanager/apiv2/folders_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv2/folders_client_example_test.go b/resourcemanager/apiv2/folders_client_example_test.go index 0d4f2ec69c89..d6d6c0785f9c 100644 --- a/resourcemanager/apiv2/folders_client_example_test.go +++ b/resourcemanager/apiv2/folders_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv2/helpers.go b/resourcemanager/apiv2/helpers.go index c1de93186fe3..5a9a4a1c349b 100755 --- a/resourcemanager/apiv2/helpers.go +++ b/resourcemanager/apiv2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv3/auxiliary.go b/resourcemanager/apiv3/auxiliary.go index b46711885241..ee9f1db8e1be 100755 --- a/resourcemanager/apiv3/auxiliary.go +++ b/resourcemanager/apiv3/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv3/auxiliary_go123.go b/resourcemanager/apiv3/auxiliary_go123.go index c6f75665028a..5e6f3a20500a 100755 --- a/resourcemanager/apiv3/auxiliary_go123.go +++ b/resourcemanager/apiv3/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv3/doc.go b/resourcemanager/apiv3/doc.go index 714039dba756..f22a6449b596 100755 --- a/resourcemanager/apiv3/doc.go +++ b/resourcemanager/apiv3/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv3/folders_client.go b/resourcemanager/apiv3/folders_client.go index cda03a8efea1..4a8ea1590a38 100755 --- a/resourcemanager/apiv3/folders_client.go +++ b/resourcemanager/apiv3/folders_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv3/folders_client_example_go123_test.go b/resourcemanager/apiv3/folders_client_example_go123_test.go index 9110d4b6123e..24b132b192b5 100644 --- a/resourcemanager/apiv3/folders_client_example_go123_test.go +++ b/resourcemanager/apiv3/folders_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv3/folders_client_example_test.go b/resourcemanager/apiv3/folders_client_example_test.go index 112e8e126a14..33470af90346 100644 --- a/resourcemanager/apiv3/folders_client_example_test.go +++ b/resourcemanager/apiv3/folders_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv3/helpers.go b/resourcemanager/apiv3/helpers.go index c1de93186fe3..5a9a4a1c349b 100755 --- a/resourcemanager/apiv3/helpers.go +++ b/resourcemanager/apiv3/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv3/organizations_client.go b/resourcemanager/apiv3/organizations_client.go index d69bdbb0260b..6457dcf1b3c5 100755 --- a/resourcemanager/apiv3/organizations_client.go +++ b/resourcemanager/apiv3/organizations_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv3/organizations_client_example_go123_test.go b/resourcemanager/apiv3/organizations_client_example_go123_test.go index 63061816cc22..1490d519144a 100644 --- a/resourcemanager/apiv3/organizations_client_example_go123_test.go +++ b/resourcemanager/apiv3/organizations_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv3/organizations_client_example_test.go b/resourcemanager/apiv3/organizations_client_example_test.go index ad04dd206e40..dfb4690a116b 100644 --- a/resourcemanager/apiv3/organizations_client_example_test.go +++ b/resourcemanager/apiv3/organizations_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv3/projects_client.go b/resourcemanager/apiv3/projects_client.go index 00edb7c536cf..826b808aae84 100755 --- a/resourcemanager/apiv3/projects_client.go +++ b/resourcemanager/apiv3/projects_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv3/projects_client_example_go123_test.go b/resourcemanager/apiv3/projects_client_example_go123_test.go index 47d121fc93fb..7b3eedafe4fe 100644 --- a/resourcemanager/apiv3/projects_client_example_go123_test.go +++ b/resourcemanager/apiv3/projects_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv3/projects_client_example_test.go b/resourcemanager/apiv3/projects_client_example_test.go index 15329db3dafa..c57e08ed9f59 100644 --- a/resourcemanager/apiv3/projects_client_example_test.go +++ b/resourcemanager/apiv3/projects_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv3/tag_bindings_client.go b/resourcemanager/apiv3/tag_bindings_client.go index dd15ec716344..273e537fcffc 100755 --- a/resourcemanager/apiv3/tag_bindings_client.go +++ b/resourcemanager/apiv3/tag_bindings_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv3/tag_bindings_client_example_go123_test.go b/resourcemanager/apiv3/tag_bindings_client_example_go123_test.go index 1f260e119c5e..0f96427338e6 100644 --- a/resourcemanager/apiv3/tag_bindings_client_example_go123_test.go +++ b/resourcemanager/apiv3/tag_bindings_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv3/tag_bindings_client_example_test.go b/resourcemanager/apiv3/tag_bindings_client_example_test.go index ed4b058b4400..bd2f15de3477 100644 --- a/resourcemanager/apiv3/tag_bindings_client_example_test.go +++ b/resourcemanager/apiv3/tag_bindings_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv3/tag_holds_client.go b/resourcemanager/apiv3/tag_holds_client.go index fea5fb275546..7e77c7ffbc10 100755 --- a/resourcemanager/apiv3/tag_holds_client.go +++ b/resourcemanager/apiv3/tag_holds_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv3/tag_holds_client_example_go123_test.go b/resourcemanager/apiv3/tag_holds_client_example_go123_test.go index ab6495e781fe..8afeb7a0648e 100644 --- a/resourcemanager/apiv3/tag_holds_client_example_go123_test.go +++ b/resourcemanager/apiv3/tag_holds_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv3/tag_holds_client_example_test.go b/resourcemanager/apiv3/tag_holds_client_example_test.go index 6c267c0a4842..b48a13b0ba05 100644 --- a/resourcemanager/apiv3/tag_holds_client_example_test.go +++ b/resourcemanager/apiv3/tag_holds_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv3/tag_keys_client.go b/resourcemanager/apiv3/tag_keys_client.go index f68ff2cf2e81..91055518fbee 100755 --- a/resourcemanager/apiv3/tag_keys_client.go +++ b/resourcemanager/apiv3/tag_keys_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv3/tag_keys_client_example_go123_test.go b/resourcemanager/apiv3/tag_keys_client_example_go123_test.go index 0950d0580666..53743fb64cb7 100644 --- a/resourcemanager/apiv3/tag_keys_client_example_go123_test.go +++ b/resourcemanager/apiv3/tag_keys_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv3/tag_keys_client_example_test.go b/resourcemanager/apiv3/tag_keys_client_example_test.go index 770f517ad00a..1b8e3b605a76 100644 --- a/resourcemanager/apiv3/tag_keys_client_example_test.go +++ b/resourcemanager/apiv3/tag_keys_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv3/tag_values_client.go b/resourcemanager/apiv3/tag_values_client.go index 913a2863c941..bb0ebcd7e5bd 100755 --- a/resourcemanager/apiv3/tag_values_client.go +++ b/resourcemanager/apiv3/tag_values_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv3/tag_values_client_example_go123_test.go b/resourcemanager/apiv3/tag_values_client_example_go123_test.go index e7bcadfbe234..965930c06c25 100644 --- a/resourcemanager/apiv3/tag_values_client_example_go123_test.go +++ b/resourcemanager/apiv3/tag_values_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcemanager/apiv3/tag_values_client_example_test.go b/resourcemanager/apiv3/tag_values_client_example_test.go index 9267ad694b57..d8be7af6b473 100644 --- a/resourcemanager/apiv3/tag_values_client_example_test.go +++ b/resourcemanager/apiv3/tag_values_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcesettings/apiv1/auxiliary.go b/resourcesettings/apiv1/auxiliary.go index 4f189c7e7274..5eda7deebcb4 100755 --- a/resourcesettings/apiv1/auxiliary.go +++ b/resourcesettings/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcesettings/apiv1/auxiliary_go123.go b/resourcesettings/apiv1/auxiliary_go123.go index c7c6ddae6a25..0ad7362693f8 100755 --- a/resourcesettings/apiv1/auxiliary_go123.go +++ b/resourcesettings/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcesettings/apiv1/doc.go b/resourcesettings/apiv1/doc.go index 969102c12f7a..99e6e76205ee 100755 --- a/resourcesettings/apiv1/doc.go +++ b/resourcesettings/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcesettings/apiv1/helpers.go b/resourcesettings/apiv1/helpers.go index 144c816ee5bd..d839b4bdbb3e 100755 --- a/resourcesettings/apiv1/helpers.go +++ b/resourcesettings/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcesettings/apiv1/resource_settings_client.go b/resourcesettings/apiv1/resource_settings_client.go index eb0c2b0c9eb3..1de77060fefe 100755 --- a/resourcesettings/apiv1/resource_settings_client.go +++ b/resourcesettings/apiv1/resource_settings_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcesettings/apiv1/resource_settings_client_example_go123_test.go b/resourcesettings/apiv1/resource_settings_client_example_go123_test.go index 041196dabb3c..ec82e3fc39fd 100644 --- a/resourcesettings/apiv1/resource_settings_client_example_go123_test.go +++ b/resourcesettings/apiv1/resource_settings_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/resourcesettings/apiv1/resource_settings_client_example_test.go b/resourcesettings/apiv1/resource_settings_client_example_test.go index edf362b9bac7..780fcb7551d8 100644 --- a/resourcesettings/apiv1/resource_settings_client_example_test.go +++ b/resourcesettings/apiv1/resource_settings_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/analytics_client.go b/retail/apiv2/analytics_client.go index a8d692ed0328..50b41c1e8788 100755 --- a/retail/apiv2/analytics_client.go +++ b/retail/apiv2/analytics_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/analytics_client_example_go123_test.go b/retail/apiv2/analytics_client_example_go123_test.go index 37785621cb28..22ef3e5ee92b 100644 --- a/retail/apiv2/analytics_client_example_go123_test.go +++ b/retail/apiv2/analytics_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/analytics_client_example_test.go b/retail/apiv2/analytics_client_example_test.go index be23e8cf35be..f74384b26f58 100644 --- a/retail/apiv2/analytics_client_example_test.go +++ b/retail/apiv2/analytics_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/auxiliary.go b/retail/apiv2/auxiliary.go index d59c5a41860e..11e402338d27 100755 --- a/retail/apiv2/auxiliary.go +++ b/retail/apiv2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/auxiliary_go123.go b/retail/apiv2/auxiliary_go123.go index f9d3ce19cb5f..558974f8df43 100755 --- a/retail/apiv2/auxiliary_go123.go +++ b/retail/apiv2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/catalog_client.go b/retail/apiv2/catalog_client.go index f9e9fe61bbe5..df497a02546b 100755 --- a/retail/apiv2/catalog_client.go +++ b/retail/apiv2/catalog_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/catalog_client_example_go123_test.go b/retail/apiv2/catalog_client_example_go123_test.go index 3260fa310bad..f54ddad97975 100644 --- a/retail/apiv2/catalog_client_example_go123_test.go +++ b/retail/apiv2/catalog_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/catalog_client_example_test.go b/retail/apiv2/catalog_client_example_test.go index 63aaf352a8f3..aec013993985 100644 --- a/retail/apiv2/catalog_client_example_test.go +++ b/retail/apiv2/catalog_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/completion_client.go b/retail/apiv2/completion_client.go index 86dd2338ba0c..389855b67924 100755 --- a/retail/apiv2/completion_client.go +++ b/retail/apiv2/completion_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/completion_client_example_go123_test.go b/retail/apiv2/completion_client_example_go123_test.go index 412fb3d32aff..d80fa0e1fc9c 100644 --- a/retail/apiv2/completion_client_example_go123_test.go +++ b/retail/apiv2/completion_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/completion_client_example_test.go b/retail/apiv2/completion_client_example_test.go index 68a2af7e129a..487c70bead1e 100644 --- a/retail/apiv2/completion_client_example_test.go +++ b/retail/apiv2/completion_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/control_client.go b/retail/apiv2/control_client.go index c6c900982a85..219c702ec57e 100755 --- a/retail/apiv2/control_client.go +++ b/retail/apiv2/control_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/control_client_example_go123_test.go b/retail/apiv2/control_client_example_go123_test.go index 6414104b79ea..55c0f8887b19 100644 --- a/retail/apiv2/control_client_example_go123_test.go +++ b/retail/apiv2/control_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/control_client_example_test.go b/retail/apiv2/control_client_example_test.go index a1019261c686..50b52aa85b85 100644 --- a/retail/apiv2/control_client_example_test.go +++ b/retail/apiv2/control_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/doc.go b/retail/apiv2/doc.go index 5ab57f153bb7..4d050f1c6dc3 100755 --- a/retail/apiv2/doc.go +++ b/retail/apiv2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/generative_question_client.go b/retail/apiv2/generative_question_client.go index bac48bfe9007..db30d76f74c4 100755 --- a/retail/apiv2/generative_question_client.go +++ b/retail/apiv2/generative_question_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/generative_question_client_example_go123_test.go b/retail/apiv2/generative_question_client_example_go123_test.go index 740f32e0aeaf..edb2188b79b9 100644 --- a/retail/apiv2/generative_question_client_example_go123_test.go +++ b/retail/apiv2/generative_question_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/generative_question_client_example_test.go b/retail/apiv2/generative_question_client_example_test.go index 112deb8faf48..a991f80301ee 100644 --- a/retail/apiv2/generative_question_client_example_test.go +++ b/retail/apiv2/generative_question_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/helpers.go b/retail/apiv2/helpers.go index 4b0485f74073..5eb38c1dd922 100755 --- a/retail/apiv2/helpers.go +++ b/retail/apiv2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/model_client.go b/retail/apiv2/model_client.go index 791b8efb7048..a9a03a139774 100755 --- a/retail/apiv2/model_client.go +++ b/retail/apiv2/model_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/model_client_example_go123_test.go b/retail/apiv2/model_client_example_go123_test.go index e51668a91931..b29f06ad455b 100644 --- a/retail/apiv2/model_client_example_go123_test.go +++ b/retail/apiv2/model_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/model_client_example_test.go b/retail/apiv2/model_client_example_test.go index 3b3e6f1177c9..677f42085de2 100644 --- a/retail/apiv2/model_client_example_test.go +++ b/retail/apiv2/model_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/prediction_client.go b/retail/apiv2/prediction_client.go index d0396ff16183..7a64f4f8a156 100755 --- a/retail/apiv2/prediction_client.go +++ b/retail/apiv2/prediction_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/prediction_client_example_go123_test.go b/retail/apiv2/prediction_client_example_go123_test.go index 036635632b8e..fe3892d0cd31 100644 --- a/retail/apiv2/prediction_client_example_go123_test.go +++ b/retail/apiv2/prediction_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/prediction_client_example_test.go b/retail/apiv2/prediction_client_example_test.go index 5b840a7f954b..ccca2b5b5dc9 100644 --- a/retail/apiv2/prediction_client_example_test.go +++ b/retail/apiv2/prediction_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/product_client.go b/retail/apiv2/product_client.go index 12795f6d6b2c..ec49be376e2f 100755 --- a/retail/apiv2/product_client.go +++ b/retail/apiv2/product_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/product_client_example_go123_test.go b/retail/apiv2/product_client_example_go123_test.go index 9687ecd78f92..e7fdf7bd3eef 100644 --- a/retail/apiv2/product_client_example_go123_test.go +++ b/retail/apiv2/product_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/product_client_example_test.go b/retail/apiv2/product_client_example_test.go index deef2c9f56fa..854f15403445 100644 --- a/retail/apiv2/product_client_example_test.go +++ b/retail/apiv2/product_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/search_client.go b/retail/apiv2/search_client.go index 17fff521afac..103455623a8d 100755 --- a/retail/apiv2/search_client.go +++ b/retail/apiv2/search_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/search_client_example_go123_test.go b/retail/apiv2/search_client_example_go123_test.go index 22fbed5ab00c..39c0f7a78c19 100644 --- a/retail/apiv2/search_client_example_go123_test.go +++ b/retail/apiv2/search_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/search_client_example_test.go b/retail/apiv2/search_client_example_test.go index c65be84e7cd8..82fcef79bff3 100644 --- a/retail/apiv2/search_client_example_test.go +++ b/retail/apiv2/search_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/serving_config_client.go b/retail/apiv2/serving_config_client.go index 6aca03835598..0df10da62d79 100755 --- a/retail/apiv2/serving_config_client.go +++ b/retail/apiv2/serving_config_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/serving_config_client_example_go123_test.go b/retail/apiv2/serving_config_client_example_go123_test.go index 195ee5dfae31..9829c54e9870 100644 --- a/retail/apiv2/serving_config_client_example_go123_test.go +++ b/retail/apiv2/serving_config_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/serving_config_client_example_test.go b/retail/apiv2/serving_config_client_example_test.go index 5d9ce2ebdfc2..8040778af91f 100644 --- a/retail/apiv2/serving_config_client_example_test.go +++ b/retail/apiv2/serving_config_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/user_event_client.go b/retail/apiv2/user_event_client.go index 25386b13cfa5..e40b6536e5f2 100755 --- a/retail/apiv2/user_event_client.go +++ b/retail/apiv2/user_event_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/user_event_client_example_go123_test.go b/retail/apiv2/user_event_client_example_go123_test.go index 5cbfcadd402c..4972140641b4 100644 --- a/retail/apiv2/user_event_client_example_go123_test.go +++ b/retail/apiv2/user_event_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2/user_event_client_example_test.go b/retail/apiv2/user_event_client_example_test.go index 626142194b14..e0fdfe53b0c6 100644 --- a/retail/apiv2/user_event_client_example_test.go +++ b/retail/apiv2/user_event_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/analytics_client.go b/retail/apiv2alpha/analytics_client.go index e605bcca6a72..b807163f592f 100755 --- a/retail/apiv2alpha/analytics_client.go +++ b/retail/apiv2alpha/analytics_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/analytics_client_example_go123_test.go b/retail/apiv2alpha/analytics_client_example_go123_test.go index dd27211bfabf..5526f7c43b21 100644 --- a/retail/apiv2alpha/analytics_client_example_go123_test.go +++ b/retail/apiv2alpha/analytics_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/analytics_client_example_test.go b/retail/apiv2alpha/analytics_client_example_test.go index e61f4a620c12..7f53ffd4aed0 100644 --- a/retail/apiv2alpha/analytics_client_example_test.go +++ b/retail/apiv2alpha/analytics_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/auxiliary.go b/retail/apiv2alpha/auxiliary.go index 80ad400888be..c0488c069dd7 100755 --- a/retail/apiv2alpha/auxiliary.go +++ b/retail/apiv2alpha/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/auxiliary_go123.go b/retail/apiv2alpha/auxiliary_go123.go index 26ef74987d0a..9e241ed0fe11 100755 --- a/retail/apiv2alpha/auxiliary_go123.go +++ b/retail/apiv2alpha/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/branch_client.go b/retail/apiv2alpha/branch_client.go index bbc56753eeda..0d439455418f 100755 --- a/retail/apiv2alpha/branch_client.go +++ b/retail/apiv2alpha/branch_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/branch_client_example_go123_test.go b/retail/apiv2alpha/branch_client_example_go123_test.go index 1b1a0eefa17b..273f0393da44 100644 --- a/retail/apiv2alpha/branch_client_example_go123_test.go +++ b/retail/apiv2alpha/branch_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/branch_client_example_test.go b/retail/apiv2alpha/branch_client_example_test.go index aa8a94f08265..8c4e00a08c4d 100644 --- a/retail/apiv2alpha/branch_client_example_test.go +++ b/retail/apiv2alpha/branch_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/catalog_client.go b/retail/apiv2alpha/catalog_client.go index ef685d0288e8..3ea13a72851d 100755 --- a/retail/apiv2alpha/catalog_client.go +++ b/retail/apiv2alpha/catalog_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/catalog_client_example_go123_test.go b/retail/apiv2alpha/catalog_client_example_go123_test.go index c293a2d520be..13df824d2d1a 100644 --- a/retail/apiv2alpha/catalog_client_example_go123_test.go +++ b/retail/apiv2alpha/catalog_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/catalog_client_example_test.go b/retail/apiv2alpha/catalog_client_example_test.go index 19d69533d3e3..d755c5f30e67 100644 --- a/retail/apiv2alpha/catalog_client_example_test.go +++ b/retail/apiv2alpha/catalog_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/completion_client.go b/retail/apiv2alpha/completion_client.go index 1ad88cc27d42..da01011b54a9 100755 --- a/retail/apiv2alpha/completion_client.go +++ b/retail/apiv2alpha/completion_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/completion_client_example_go123_test.go b/retail/apiv2alpha/completion_client_example_go123_test.go index a84776e91243..ce6662036d38 100644 --- a/retail/apiv2alpha/completion_client_example_go123_test.go +++ b/retail/apiv2alpha/completion_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/completion_client_example_test.go b/retail/apiv2alpha/completion_client_example_test.go index 0024b725f54c..dc92fee11b81 100644 --- a/retail/apiv2alpha/completion_client_example_test.go +++ b/retail/apiv2alpha/completion_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/control_client.go b/retail/apiv2alpha/control_client.go index a7e467c12d13..59e9d2f147ac 100755 --- a/retail/apiv2alpha/control_client.go +++ b/retail/apiv2alpha/control_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/control_client_example_go123_test.go b/retail/apiv2alpha/control_client_example_go123_test.go index e19b162bbb06..c5b89b6edf34 100644 --- a/retail/apiv2alpha/control_client_example_go123_test.go +++ b/retail/apiv2alpha/control_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/control_client_example_test.go b/retail/apiv2alpha/control_client_example_test.go index 50ee8d317e77..97cc8e829135 100644 --- a/retail/apiv2alpha/control_client_example_test.go +++ b/retail/apiv2alpha/control_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/doc.go b/retail/apiv2alpha/doc.go index d09e32d01de8..a2cacb802550 100755 --- a/retail/apiv2alpha/doc.go +++ b/retail/apiv2alpha/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/generative_question_client.go b/retail/apiv2alpha/generative_question_client.go index 305d158217cf..1f4f65254fb4 100755 --- a/retail/apiv2alpha/generative_question_client.go +++ b/retail/apiv2alpha/generative_question_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/generative_question_client_example_go123_test.go b/retail/apiv2alpha/generative_question_client_example_go123_test.go index d809d7b9a24c..a59a4bf8ccef 100644 --- a/retail/apiv2alpha/generative_question_client_example_go123_test.go +++ b/retail/apiv2alpha/generative_question_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/generative_question_client_example_test.go b/retail/apiv2alpha/generative_question_client_example_test.go index dc242c51807f..aa9140add47e 100644 --- a/retail/apiv2alpha/generative_question_client_example_test.go +++ b/retail/apiv2alpha/generative_question_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/helpers.go b/retail/apiv2alpha/helpers.go index 4b0485f74073..5eb38c1dd922 100755 --- a/retail/apiv2alpha/helpers.go +++ b/retail/apiv2alpha/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/merchant_center_account_link_client.go b/retail/apiv2alpha/merchant_center_account_link_client.go index 5b79b8b5a06a..3267fc8008e1 100755 --- a/retail/apiv2alpha/merchant_center_account_link_client.go +++ b/retail/apiv2alpha/merchant_center_account_link_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/merchant_center_account_link_client_example_go123_test.go b/retail/apiv2alpha/merchant_center_account_link_client_example_go123_test.go index 7ed42e4a4ffe..3b8faf9fe936 100644 --- a/retail/apiv2alpha/merchant_center_account_link_client_example_go123_test.go +++ b/retail/apiv2alpha/merchant_center_account_link_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/merchant_center_account_link_client_example_test.go b/retail/apiv2alpha/merchant_center_account_link_client_example_test.go index 28b69d0a6117..862426b4785f 100644 --- a/retail/apiv2alpha/merchant_center_account_link_client_example_test.go +++ b/retail/apiv2alpha/merchant_center_account_link_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/model_client.go b/retail/apiv2alpha/model_client.go index 3596948d79a4..bfbecfbc9848 100755 --- a/retail/apiv2alpha/model_client.go +++ b/retail/apiv2alpha/model_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/model_client_example_go123_test.go b/retail/apiv2alpha/model_client_example_go123_test.go index 65b3dda449d0..f36c13e7836b 100644 --- a/retail/apiv2alpha/model_client_example_go123_test.go +++ b/retail/apiv2alpha/model_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/model_client_example_test.go b/retail/apiv2alpha/model_client_example_test.go index 860802a39947..bc0e3e2f53a9 100644 --- a/retail/apiv2alpha/model_client_example_test.go +++ b/retail/apiv2alpha/model_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/prediction_client.go b/retail/apiv2alpha/prediction_client.go index 9983aae2a3ec..2ae98d4e797f 100755 --- a/retail/apiv2alpha/prediction_client.go +++ b/retail/apiv2alpha/prediction_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/prediction_client_example_go123_test.go b/retail/apiv2alpha/prediction_client_example_go123_test.go index bd344d6a7876..7d3419af5cd8 100644 --- a/retail/apiv2alpha/prediction_client_example_go123_test.go +++ b/retail/apiv2alpha/prediction_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/prediction_client_example_test.go b/retail/apiv2alpha/prediction_client_example_test.go index 04ecd7ed0155..b3103b01acbd 100644 --- a/retail/apiv2alpha/prediction_client_example_test.go +++ b/retail/apiv2alpha/prediction_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/product_client.go b/retail/apiv2alpha/product_client.go index f985d38a26f7..0db2b208a698 100755 --- a/retail/apiv2alpha/product_client.go +++ b/retail/apiv2alpha/product_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/product_client_example_go123_test.go b/retail/apiv2alpha/product_client_example_go123_test.go index cd9a1c9797b4..53eef4d2ce74 100644 --- a/retail/apiv2alpha/product_client_example_go123_test.go +++ b/retail/apiv2alpha/product_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/product_client_example_test.go b/retail/apiv2alpha/product_client_example_test.go index 61c79a418948..8ba62ab6e880 100644 --- a/retail/apiv2alpha/product_client_example_test.go +++ b/retail/apiv2alpha/product_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/project_client.go b/retail/apiv2alpha/project_client.go index 7e054ecfad12..0ef0708067c5 100755 --- a/retail/apiv2alpha/project_client.go +++ b/retail/apiv2alpha/project_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/project_client_example_go123_test.go b/retail/apiv2alpha/project_client_example_go123_test.go index 3176c98efce4..479c6f06c46a 100644 --- a/retail/apiv2alpha/project_client_example_go123_test.go +++ b/retail/apiv2alpha/project_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/project_client_example_test.go b/retail/apiv2alpha/project_client_example_test.go index f32c6aa594e2..66dff1e31ed0 100644 --- a/retail/apiv2alpha/project_client_example_test.go +++ b/retail/apiv2alpha/project_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/search_client.go b/retail/apiv2alpha/search_client.go index 9ddae2ce4c5e..e673ce076e9a 100755 --- a/retail/apiv2alpha/search_client.go +++ b/retail/apiv2alpha/search_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/search_client_example_go123_test.go b/retail/apiv2alpha/search_client_example_go123_test.go index 9b67a6145f36..7c154326be85 100644 --- a/retail/apiv2alpha/search_client_example_go123_test.go +++ b/retail/apiv2alpha/search_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/search_client_example_test.go b/retail/apiv2alpha/search_client_example_test.go index 8a2f307a62de..0c70e22cb082 100644 --- a/retail/apiv2alpha/search_client_example_test.go +++ b/retail/apiv2alpha/search_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/serving_config_client.go b/retail/apiv2alpha/serving_config_client.go index 2a35e418403f..261da975c00e 100755 --- a/retail/apiv2alpha/serving_config_client.go +++ b/retail/apiv2alpha/serving_config_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/serving_config_client_example_go123_test.go b/retail/apiv2alpha/serving_config_client_example_go123_test.go index 77c15195e50b..e183e71c1c2a 100644 --- a/retail/apiv2alpha/serving_config_client_example_go123_test.go +++ b/retail/apiv2alpha/serving_config_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/serving_config_client_example_test.go b/retail/apiv2alpha/serving_config_client_example_test.go index fb62a32e4db2..de1d580c03ca 100644 --- a/retail/apiv2alpha/serving_config_client_example_test.go +++ b/retail/apiv2alpha/serving_config_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/user_event_client.go b/retail/apiv2alpha/user_event_client.go index 0102d7579a60..3857a701b1dc 100755 --- a/retail/apiv2alpha/user_event_client.go +++ b/retail/apiv2alpha/user_event_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/user_event_client_example_go123_test.go b/retail/apiv2alpha/user_event_client_example_go123_test.go index 7e570aca6cdb..8f3a700fc559 100644 --- a/retail/apiv2alpha/user_event_client_example_go123_test.go +++ b/retail/apiv2alpha/user_event_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2alpha/user_event_client_example_test.go b/retail/apiv2alpha/user_event_client_example_test.go index b82cecd1c58b..1b5287428257 100644 --- a/retail/apiv2alpha/user_event_client_example_test.go +++ b/retail/apiv2alpha/user_event_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/analytics_client.go b/retail/apiv2beta/analytics_client.go index ab1aa777ddc0..2adc63dd4d90 100755 --- a/retail/apiv2beta/analytics_client.go +++ b/retail/apiv2beta/analytics_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/analytics_client_example_go123_test.go b/retail/apiv2beta/analytics_client_example_go123_test.go index 97836dca0c88..23b7b70a9505 100644 --- a/retail/apiv2beta/analytics_client_example_go123_test.go +++ b/retail/apiv2beta/analytics_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/analytics_client_example_test.go b/retail/apiv2beta/analytics_client_example_test.go index 357f9203857a..6ffbd94ff7ba 100644 --- a/retail/apiv2beta/analytics_client_example_test.go +++ b/retail/apiv2beta/analytics_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/auxiliary.go b/retail/apiv2beta/auxiliary.go index d87ce071fd45..3243127079ca 100755 --- a/retail/apiv2beta/auxiliary.go +++ b/retail/apiv2beta/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/auxiliary_go123.go b/retail/apiv2beta/auxiliary_go123.go index a3c1b870ebf4..6757d218da72 100755 --- a/retail/apiv2beta/auxiliary_go123.go +++ b/retail/apiv2beta/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/catalog_client.go b/retail/apiv2beta/catalog_client.go index 95f0db870b0c..d32bb2520123 100755 --- a/retail/apiv2beta/catalog_client.go +++ b/retail/apiv2beta/catalog_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/catalog_client_example_go123_test.go b/retail/apiv2beta/catalog_client_example_go123_test.go index 7273b9141780..f4fe4e7da15a 100644 --- a/retail/apiv2beta/catalog_client_example_go123_test.go +++ b/retail/apiv2beta/catalog_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/catalog_client_example_test.go b/retail/apiv2beta/catalog_client_example_test.go index b91dadff4465..c66fcbaf7844 100644 --- a/retail/apiv2beta/catalog_client_example_test.go +++ b/retail/apiv2beta/catalog_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/completion_client.go b/retail/apiv2beta/completion_client.go index 6579c3d597a9..60df4897d600 100755 --- a/retail/apiv2beta/completion_client.go +++ b/retail/apiv2beta/completion_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/completion_client_example_go123_test.go b/retail/apiv2beta/completion_client_example_go123_test.go index f7db88f0bf9c..9eb397ccb456 100644 --- a/retail/apiv2beta/completion_client_example_go123_test.go +++ b/retail/apiv2beta/completion_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/completion_client_example_test.go b/retail/apiv2beta/completion_client_example_test.go index 0ce84e1ac895..73a811a832ec 100644 --- a/retail/apiv2beta/completion_client_example_test.go +++ b/retail/apiv2beta/completion_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/control_client.go b/retail/apiv2beta/control_client.go index 309da6d5ed48..fabd43bf1588 100755 --- a/retail/apiv2beta/control_client.go +++ b/retail/apiv2beta/control_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/control_client_example_go123_test.go b/retail/apiv2beta/control_client_example_go123_test.go index 456de216a085..00be1cb65dbb 100644 --- a/retail/apiv2beta/control_client_example_go123_test.go +++ b/retail/apiv2beta/control_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/control_client_example_test.go b/retail/apiv2beta/control_client_example_test.go index 40cae0cb1f08..276dc2665816 100644 --- a/retail/apiv2beta/control_client_example_test.go +++ b/retail/apiv2beta/control_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/doc.go b/retail/apiv2beta/doc.go index b921001339bd..c66a8ea76ed7 100755 --- a/retail/apiv2beta/doc.go +++ b/retail/apiv2beta/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/generative_question_client.go b/retail/apiv2beta/generative_question_client.go index 6742302cd481..ca7c86e5dcac 100755 --- a/retail/apiv2beta/generative_question_client.go +++ b/retail/apiv2beta/generative_question_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/generative_question_client_example_go123_test.go b/retail/apiv2beta/generative_question_client_example_go123_test.go index 52b4288f9509..e8956bf7092d 100644 --- a/retail/apiv2beta/generative_question_client_example_go123_test.go +++ b/retail/apiv2beta/generative_question_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/generative_question_client_example_test.go b/retail/apiv2beta/generative_question_client_example_test.go index ccbdfbdb0dfb..89a6287e525f 100644 --- a/retail/apiv2beta/generative_question_client_example_test.go +++ b/retail/apiv2beta/generative_question_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/helpers.go b/retail/apiv2beta/helpers.go index 4b0485f74073..5eb38c1dd922 100755 --- a/retail/apiv2beta/helpers.go +++ b/retail/apiv2beta/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/model_client.go b/retail/apiv2beta/model_client.go index a5721191b2e1..6051b10fdf4c 100755 --- a/retail/apiv2beta/model_client.go +++ b/retail/apiv2beta/model_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/model_client_example_go123_test.go b/retail/apiv2beta/model_client_example_go123_test.go index 4b884e839703..94a1ed6c8e5d 100644 --- a/retail/apiv2beta/model_client_example_go123_test.go +++ b/retail/apiv2beta/model_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/model_client_example_test.go b/retail/apiv2beta/model_client_example_test.go index a68da7e9b8f8..d8190133ab79 100644 --- a/retail/apiv2beta/model_client_example_test.go +++ b/retail/apiv2beta/model_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/prediction_client.go b/retail/apiv2beta/prediction_client.go index 874e9832b5f9..64c098d5eecf 100755 --- a/retail/apiv2beta/prediction_client.go +++ b/retail/apiv2beta/prediction_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/prediction_client_example_go123_test.go b/retail/apiv2beta/prediction_client_example_go123_test.go index 95b32db18a31..baa346f4549f 100644 --- a/retail/apiv2beta/prediction_client_example_go123_test.go +++ b/retail/apiv2beta/prediction_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/prediction_client_example_test.go b/retail/apiv2beta/prediction_client_example_test.go index 296bf6b839e7..d70607af0bc5 100644 --- a/retail/apiv2beta/prediction_client_example_test.go +++ b/retail/apiv2beta/prediction_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/product_client.go b/retail/apiv2beta/product_client.go index 14c796b50933..d252e94fd097 100755 --- a/retail/apiv2beta/product_client.go +++ b/retail/apiv2beta/product_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/product_client_example_go123_test.go b/retail/apiv2beta/product_client_example_go123_test.go index f46c1c0db076..9845e73934d9 100644 --- a/retail/apiv2beta/product_client_example_go123_test.go +++ b/retail/apiv2beta/product_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/product_client_example_test.go b/retail/apiv2beta/product_client_example_test.go index d6a4210ca788..8269af6429c1 100644 --- a/retail/apiv2beta/product_client_example_test.go +++ b/retail/apiv2beta/product_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/project_client.go b/retail/apiv2beta/project_client.go index 1904b9986903..5915741a08f4 100755 --- a/retail/apiv2beta/project_client.go +++ b/retail/apiv2beta/project_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/project_client_example_go123_test.go b/retail/apiv2beta/project_client_example_go123_test.go index 3deb5967a546..b6d6a84ea338 100644 --- a/retail/apiv2beta/project_client_example_go123_test.go +++ b/retail/apiv2beta/project_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/project_client_example_test.go b/retail/apiv2beta/project_client_example_test.go index d14db13f2d9e..d814660591df 100644 --- a/retail/apiv2beta/project_client_example_test.go +++ b/retail/apiv2beta/project_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/search_client.go b/retail/apiv2beta/search_client.go index 973981b813bd..32845d58b198 100755 --- a/retail/apiv2beta/search_client.go +++ b/retail/apiv2beta/search_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/search_client_example_go123_test.go b/retail/apiv2beta/search_client_example_go123_test.go index 757bcdd47a80..a29a0d4e788a 100644 --- a/retail/apiv2beta/search_client_example_go123_test.go +++ b/retail/apiv2beta/search_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/search_client_example_test.go b/retail/apiv2beta/search_client_example_test.go index 075c91f9d561..539fc087c50d 100644 --- a/retail/apiv2beta/search_client_example_test.go +++ b/retail/apiv2beta/search_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/serving_config_client.go b/retail/apiv2beta/serving_config_client.go index cbed529c0290..b946a74ceb1b 100755 --- a/retail/apiv2beta/serving_config_client.go +++ b/retail/apiv2beta/serving_config_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/serving_config_client_example_go123_test.go b/retail/apiv2beta/serving_config_client_example_go123_test.go index 1170b12efcb6..dc14e5d2b8c2 100644 --- a/retail/apiv2beta/serving_config_client_example_go123_test.go +++ b/retail/apiv2beta/serving_config_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/serving_config_client_example_test.go b/retail/apiv2beta/serving_config_client_example_test.go index e34adf18c00b..ac8ad42ff059 100644 --- a/retail/apiv2beta/serving_config_client_example_test.go +++ b/retail/apiv2beta/serving_config_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/user_event_client.go b/retail/apiv2beta/user_event_client.go index df68c3f4fc83..6682570411ce 100755 --- a/retail/apiv2beta/user_event_client.go +++ b/retail/apiv2beta/user_event_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/user_event_client_example_go123_test.go b/retail/apiv2beta/user_event_client_example_go123_test.go index 389dd8307a31..f68209506cc3 100644 --- a/retail/apiv2beta/user_event_client_example_go123_test.go +++ b/retail/apiv2beta/user_event_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/retail/apiv2beta/user_event_client_example_test.go b/retail/apiv2beta/user_event_client_example_test.go index 2415a5b3100d..649a74432cb9 100644 --- a/retail/apiv2beta/user_event_client_example_test.go +++ b/retail/apiv2beta/user_event_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/run/apiv2/auxiliary.go b/run/apiv2/auxiliary.go index 6be675d3eff7..81e200302176 100755 --- a/run/apiv2/auxiliary.go +++ b/run/apiv2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/run/apiv2/auxiliary_go123.go b/run/apiv2/auxiliary_go123.go index b72f0f11a11a..7f451d85576e 100755 --- a/run/apiv2/auxiliary_go123.go +++ b/run/apiv2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/run/apiv2/builds_client.go b/run/apiv2/builds_client.go index 89eb12b311a0..100b6869f08d 100755 --- a/run/apiv2/builds_client.go +++ b/run/apiv2/builds_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/run/apiv2/builds_client_example_go123_test.go b/run/apiv2/builds_client_example_go123_test.go index f6ccaa1d901b..b56debba36f2 100644 --- a/run/apiv2/builds_client_example_go123_test.go +++ b/run/apiv2/builds_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/run/apiv2/builds_client_example_test.go b/run/apiv2/builds_client_example_test.go index 0e8be9cad019..776ddb785b88 100644 --- a/run/apiv2/builds_client_example_test.go +++ b/run/apiv2/builds_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/run/apiv2/doc.go b/run/apiv2/doc.go index b7c1a889eb22..30739c99212e 100755 --- a/run/apiv2/doc.go +++ b/run/apiv2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/run/apiv2/executions_client.go b/run/apiv2/executions_client.go index 4758aa6d79ba..2ffb72cf56e2 100755 --- a/run/apiv2/executions_client.go +++ b/run/apiv2/executions_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/run/apiv2/executions_client_example_go123_test.go b/run/apiv2/executions_client_example_go123_test.go index 1b49d7c7bee1..27270d55b7c1 100644 --- a/run/apiv2/executions_client_example_go123_test.go +++ b/run/apiv2/executions_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/run/apiv2/executions_client_example_test.go b/run/apiv2/executions_client_example_test.go index 716e65e666ec..14ac2c4183a5 100644 --- a/run/apiv2/executions_client_example_test.go +++ b/run/apiv2/executions_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/run/apiv2/helpers.go b/run/apiv2/helpers.go index 61e32e7281a6..8c57e3dd1ac5 100755 --- a/run/apiv2/helpers.go +++ b/run/apiv2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/run/apiv2/jobs_client.go b/run/apiv2/jobs_client.go index 18aa63eae70f..67fc2fd403f6 100755 --- a/run/apiv2/jobs_client.go +++ b/run/apiv2/jobs_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/run/apiv2/jobs_client_example_go123_test.go b/run/apiv2/jobs_client_example_go123_test.go index 21253917ab1f..60499fbb0ccb 100644 --- a/run/apiv2/jobs_client_example_go123_test.go +++ b/run/apiv2/jobs_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/run/apiv2/jobs_client_example_test.go b/run/apiv2/jobs_client_example_test.go index 1c46ffa0d4d6..19f702e0889d 100644 --- a/run/apiv2/jobs_client_example_test.go +++ b/run/apiv2/jobs_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/run/apiv2/revisions_client.go b/run/apiv2/revisions_client.go index a8060f071fd4..2448df44b815 100755 --- a/run/apiv2/revisions_client.go +++ b/run/apiv2/revisions_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/run/apiv2/revisions_client_example_go123_test.go b/run/apiv2/revisions_client_example_go123_test.go index 578291f2038f..7364d8dabb49 100644 --- a/run/apiv2/revisions_client_example_go123_test.go +++ b/run/apiv2/revisions_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/run/apiv2/revisions_client_example_test.go b/run/apiv2/revisions_client_example_test.go index 062f73fc898b..c13ce02b0d57 100644 --- a/run/apiv2/revisions_client_example_test.go +++ b/run/apiv2/revisions_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/run/apiv2/services_client.go b/run/apiv2/services_client.go index 135a82dd316a..4695f6e99828 100755 --- a/run/apiv2/services_client.go +++ b/run/apiv2/services_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/run/apiv2/services_client_example_go123_test.go b/run/apiv2/services_client_example_go123_test.go index 9cae6f8ab12d..698988c76844 100644 --- a/run/apiv2/services_client_example_go123_test.go +++ b/run/apiv2/services_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/run/apiv2/services_client_example_test.go b/run/apiv2/services_client_example_test.go index c5e273a6752c..42674125cc39 100644 --- a/run/apiv2/services_client_example_test.go +++ b/run/apiv2/services_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/run/apiv2/tasks_client.go b/run/apiv2/tasks_client.go index f4314fc15137..eeb1ce328ce7 100755 --- a/run/apiv2/tasks_client.go +++ b/run/apiv2/tasks_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/run/apiv2/tasks_client_example_go123_test.go b/run/apiv2/tasks_client_example_go123_test.go index 351ef0c3ab96..175b5bbbc6a0 100644 --- a/run/apiv2/tasks_client_example_go123_test.go +++ b/run/apiv2/tasks_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/run/apiv2/tasks_client_example_test.go b/run/apiv2/tasks_client_example_test.go index 734367aa3332..c2b2de6ea959 100644 --- a/run/apiv2/tasks_client_example_test.go +++ b/run/apiv2/tasks_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/scheduler/apiv1/auxiliary.go b/scheduler/apiv1/auxiliary.go index 84abb53e16f4..f9e170a3996c 100755 --- a/scheduler/apiv1/auxiliary.go +++ b/scheduler/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/scheduler/apiv1/auxiliary_go123.go b/scheduler/apiv1/auxiliary_go123.go index 9cea34c60f97..e08d86fd625e 100755 --- a/scheduler/apiv1/auxiliary_go123.go +++ b/scheduler/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/scheduler/apiv1/cloud_scheduler_client.go b/scheduler/apiv1/cloud_scheduler_client.go index 2829c6e13e82..749d856bc35d 100755 --- a/scheduler/apiv1/cloud_scheduler_client.go +++ b/scheduler/apiv1/cloud_scheduler_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/scheduler/apiv1/cloud_scheduler_client_example_go123_test.go b/scheduler/apiv1/cloud_scheduler_client_example_go123_test.go index 3cd78d02b7d4..2fe12eaef129 100644 --- a/scheduler/apiv1/cloud_scheduler_client_example_go123_test.go +++ b/scheduler/apiv1/cloud_scheduler_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/scheduler/apiv1/cloud_scheduler_client_example_test.go b/scheduler/apiv1/cloud_scheduler_client_example_test.go index 802c2b740332..b8e396bac11a 100644 --- a/scheduler/apiv1/cloud_scheduler_client_example_test.go +++ b/scheduler/apiv1/cloud_scheduler_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/scheduler/apiv1/doc.go b/scheduler/apiv1/doc.go index 84688a7ab3b3..f5a770d3e01c 100755 --- a/scheduler/apiv1/doc.go +++ b/scheduler/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/scheduler/apiv1/helpers.go b/scheduler/apiv1/helpers.go index cb8bcbe9191b..0a997b4f16b2 100755 --- a/scheduler/apiv1/helpers.go +++ b/scheduler/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/scheduler/apiv1beta1/auxiliary.go b/scheduler/apiv1beta1/auxiliary.go index a202dd18a9aa..33e594345882 100755 --- a/scheduler/apiv1beta1/auxiliary.go +++ b/scheduler/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/scheduler/apiv1beta1/auxiliary_go123.go b/scheduler/apiv1beta1/auxiliary_go123.go index b4bbed5ba095..1f3f4eb64248 100755 --- a/scheduler/apiv1beta1/auxiliary_go123.go +++ b/scheduler/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/scheduler/apiv1beta1/cloud_scheduler_client.go b/scheduler/apiv1beta1/cloud_scheduler_client.go index e56e15a8ce56..23d68170f1dd 100755 --- a/scheduler/apiv1beta1/cloud_scheduler_client.go +++ b/scheduler/apiv1beta1/cloud_scheduler_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/scheduler/apiv1beta1/cloud_scheduler_client_example_go123_test.go b/scheduler/apiv1beta1/cloud_scheduler_client_example_go123_test.go index 7e0efab4c2d8..9f61a9d483fb 100644 --- a/scheduler/apiv1beta1/cloud_scheduler_client_example_go123_test.go +++ b/scheduler/apiv1beta1/cloud_scheduler_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/scheduler/apiv1beta1/cloud_scheduler_client_example_test.go b/scheduler/apiv1beta1/cloud_scheduler_client_example_test.go index d631154dd0c2..cfc433e4366e 100644 --- a/scheduler/apiv1beta1/cloud_scheduler_client_example_test.go +++ b/scheduler/apiv1beta1/cloud_scheduler_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/scheduler/apiv1beta1/doc.go b/scheduler/apiv1beta1/doc.go index 82d596932a3d..13f51ef22204 100755 --- a/scheduler/apiv1beta1/doc.go +++ b/scheduler/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/scheduler/apiv1beta1/helpers.go b/scheduler/apiv1beta1/helpers.go index cb8bcbe9191b..0a997b4f16b2 100755 --- a/scheduler/apiv1beta1/helpers.go +++ b/scheduler/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/secretmanager/apiv1/auxiliary.go b/secretmanager/apiv1/auxiliary.go index c77da15a3c5c..c0aa7e890e10 100755 --- a/secretmanager/apiv1/auxiliary.go +++ b/secretmanager/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/secretmanager/apiv1/auxiliary_go123.go b/secretmanager/apiv1/auxiliary_go123.go index bcfdbd0c0459..4c13b023532f 100755 --- a/secretmanager/apiv1/auxiliary_go123.go +++ b/secretmanager/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/secretmanager/apiv1/doc.go b/secretmanager/apiv1/doc.go index 3fc71844b303..fd4e8e4e813e 100755 --- a/secretmanager/apiv1/doc.go +++ b/secretmanager/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/secretmanager/apiv1/helpers.go b/secretmanager/apiv1/helpers.go index 93acf7aca6ae..345d764f9211 100755 --- a/secretmanager/apiv1/helpers.go +++ b/secretmanager/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/secretmanager/apiv1/secret_manager_client.go b/secretmanager/apiv1/secret_manager_client.go index fcfebde4a9ff..07ad025b94fb 100755 --- a/secretmanager/apiv1/secret_manager_client.go +++ b/secretmanager/apiv1/secret_manager_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/secretmanager/apiv1/secret_manager_client_example_go123_test.go b/secretmanager/apiv1/secret_manager_client_example_go123_test.go index 20624504df18..7be04f781794 100644 --- a/secretmanager/apiv1/secret_manager_client_example_go123_test.go +++ b/secretmanager/apiv1/secret_manager_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/secretmanager/apiv1/secret_manager_client_example_test.go b/secretmanager/apiv1/secret_manager_client_example_test.go index f24021fffdbb..a2db166bce57 100644 --- a/secretmanager/apiv1/secret_manager_client_example_test.go +++ b/secretmanager/apiv1/secret_manager_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/secretmanager/apiv1beta2/auxiliary.go b/secretmanager/apiv1beta2/auxiliary.go index 647f5ec5c5a9..3596f057a7ab 100755 --- a/secretmanager/apiv1beta2/auxiliary.go +++ b/secretmanager/apiv1beta2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/secretmanager/apiv1beta2/auxiliary_go123.go b/secretmanager/apiv1beta2/auxiliary_go123.go index 6e8f9d9b0cd8..1963de95f1cd 100755 --- a/secretmanager/apiv1beta2/auxiliary_go123.go +++ b/secretmanager/apiv1beta2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/secretmanager/apiv1beta2/doc.go b/secretmanager/apiv1beta2/doc.go index 9a3a431df7bb..4f75c42f848a 100755 --- a/secretmanager/apiv1beta2/doc.go +++ b/secretmanager/apiv1beta2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/secretmanager/apiv1beta2/helpers.go b/secretmanager/apiv1beta2/helpers.go index 93acf7aca6ae..345d764f9211 100755 --- a/secretmanager/apiv1beta2/helpers.go +++ b/secretmanager/apiv1beta2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/secretmanager/apiv1beta2/secret_manager_client.go b/secretmanager/apiv1beta2/secret_manager_client.go index 1d4068a9bed6..b754030cf52e 100755 --- a/secretmanager/apiv1beta2/secret_manager_client.go +++ b/secretmanager/apiv1beta2/secret_manager_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/secretmanager/apiv1beta2/secret_manager_client_example_go123_test.go b/secretmanager/apiv1beta2/secret_manager_client_example_go123_test.go index 223a70bfedac..080f17a1da20 100644 --- a/secretmanager/apiv1beta2/secret_manager_client_example_go123_test.go +++ b/secretmanager/apiv1beta2/secret_manager_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/secretmanager/apiv1beta2/secret_manager_client_example_test.go b/secretmanager/apiv1beta2/secret_manager_client_example_test.go index 8c8060da3e25..005fc2c190f0 100644 --- a/secretmanager/apiv1beta2/secret_manager_client_example_test.go +++ b/secretmanager/apiv1beta2/secret_manager_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securesourcemanager/apiv1/auxiliary.go b/securesourcemanager/apiv1/auxiliary.go index d520186ce113..5c4d2388cd3f 100755 --- a/securesourcemanager/apiv1/auxiliary.go +++ b/securesourcemanager/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securesourcemanager/apiv1/auxiliary_go123.go b/securesourcemanager/apiv1/auxiliary_go123.go index 395e4585eee9..50d0299fe264 100755 --- a/securesourcemanager/apiv1/auxiliary_go123.go +++ b/securesourcemanager/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securesourcemanager/apiv1/doc.go b/securesourcemanager/apiv1/doc.go index aae6d40ebec6..d5d276ea5ee5 100755 --- a/securesourcemanager/apiv1/doc.go +++ b/securesourcemanager/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securesourcemanager/apiv1/helpers.go b/securesourcemanager/apiv1/helpers.go index 77eeff28331e..4e270bc7cbf5 100755 --- a/securesourcemanager/apiv1/helpers.go +++ b/securesourcemanager/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securesourcemanager/apiv1/secure_source_manager_client.go b/securesourcemanager/apiv1/secure_source_manager_client.go index 4918a7b2f0da..662d50213627 100755 --- a/securesourcemanager/apiv1/secure_source_manager_client.go +++ b/securesourcemanager/apiv1/secure_source_manager_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securesourcemanager/apiv1/secure_source_manager_client_example_go123_test.go b/securesourcemanager/apiv1/secure_source_manager_client_example_go123_test.go index aa8de2ef0ef6..797be34e99ca 100644 --- a/securesourcemanager/apiv1/secure_source_manager_client_example_go123_test.go +++ b/securesourcemanager/apiv1/secure_source_manager_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securesourcemanager/apiv1/secure_source_manager_client_example_test.go b/securesourcemanager/apiv1/secure_source_manager_client_example_test.go index 86128dbbd763..a7caf15c44ae 100644 --- a/securesourcemanager/apiv1/secure_source_manager_client_example_test.go +++ b/securesourcemanager/apiv1/secure_source_manager_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/security/privateca/apiv1/auxiliary.go b/security/privateca/apiv1/auxiliary.go index e7663636a6cc..b4e87076564b 100755 --- a/security/privateca/apiv1/auxiliary.go +++ b/security/privateca/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/security/privateca/apiv1/auxiliary_go123.go b/security/privateca/apiv1/auxiliary_go123.go index f604314396b9..65ea33367d47 100755 --- a/security/privateca/apiv1/auxiliary_go123.go +++ b/security/privateca/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/security/privateca/apiv1/certificate_authority_client.go b/security/privateca/apiv1/certificate_authority_client.go index bba1e0706a79..a736c6f48d94 100755 --- a/security/privateca/apiv1/certificate_authority_client.go +++ b/security/privateca/apiv1/certificate_authority_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/security/privateca/apiv1/certificate_authority_client_example_go123_test.go b/security/privateca/apiv1/certificate_authority_client_example_go123_test.go index d4b0d06c5f51..c1c101531029 100644 --- a/security/privateca/apiv1/certificate_authority_client_example_go123_test.go +++ b/security/privateca/apiv1/certificate_authority_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/security/privateca/apiv1/certificate_authority_client_example_test.go b/security/privateca/apiv1/certificate_authority_client_example_test.go index 58f051aa0629..7951755c0601 100644 --- a/security/privateca/apiv1/certificate_authority_client_example_test.go +++ b/security/privateca/apiv1/certificate_authority_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/security/privateca/apiv1/doc.go b/security/privateca/apiv1/doc.go index 0766f382ac02..b5f2d19c2e0b 100755 --- a/security/privateca/apiv1/doc.go +++ b/security/privateca/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/security/privateca/apiv1/helpers.go b/security/privateca/apiv1/helpers.go index 8bd4842c2813..ad6b184b70ca 100755 --- a/security/privateca/apiv1/helpers.go +++ b/security/privateca/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/security/publicca/apiv1/auxiliary.go b/security/publicca/apiv1/auxiliary.go index 9fd6de677400..bcc5e66be486 100755 --- a/security/publicca/apiv1/auxiliary.go +++ b/security/publicca/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/security/publicca/apiv1/auxiliary_go123.go b/security/publicca/apiv1/auxiliary_go123.go index eff928ce9fda..7925f7020ded 100755 --- a/security/publicca/apiv1/auxiliary_go123.go +++ b/security/publicca/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/security/publicca/apiv1/doc.go b/security/publicca/apiv1/doc.go index 122d17098db9..0f092c514a54 100755 --- a/security/publicca/apiv1/doc.go +++ b/security/publicca/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/security/publicca/apiv1/helpers.go b/security/publicca/apiv1/helpers.go index 1675af5971cf..a4a0fef0bd30 100755 --- a/security/publicca/apiv1/helpers.go +++ b/security/publicca/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/security/publicca/apiv1/public_certificate_authority_client.go b/security/publicca/apiv1/public_certificate_authority_client.go index bc1b8a354771..d7bdb8ea0e3e 100755 --- a/security/publicca/apiv1/public_certificate_authority_client.go +++ b/security/publicca/apiv1/public_certificate_authority_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/security/publicca/apiv1/public_certificate_authority_client_example_go123_test.go b/security/publicca/apiv1/public_certificate_authority_client_example_go123_test.go index d750d6a824d8..7d04bd3e6034 100644 --- a/security/publicca/apiv1/public_certificate_authority_client_example_go123_test.go +++ b/security/publicca/apiv1/public_certificate_authority_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/security/publicca/apiv1/public_certificate_authority_client_example_test.go b/security/publicca/apiv1/public_certificate_authority_client_example_test.go index d813cfbb3c3d..7523a2fc2fc3 100644 --- a/security/publicca/apiv1/public_certificate_authority_client_example_test.go +++ b/security/publicca/apiv1/public_certificate_authority_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/security/publicca/apiv1beta1/auxiliary.go b/security/publicca/apiv1beta1/auxiliary.go index 9fd6de677400..bcc5e66be486 100755 --- a/security/publicca/apiv1beta1/auxiliary.go +++ b/security/publicca/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/security/publicca/apiv1beta1/auxiliary_go123.go b/security/publicca/apiv1beta1/auxiliary_go123.go index eff928ce9fda..7925f7020ded 100755 --- a/security/publicca/apiv1beta1/auxiliary_go123.go +++ b/security/publicca/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/security/publicca/apiv1beta1/doc.go b/security/publicca/apiv1beta1/doc.go index 1a6b7c7a24a8..f2895d4c852c 100755 --- a/security/publicca/apiv1beta1/doc.go +++ b/security/publicca/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/security/publicca/apiv1beta1/helpers.go b/security/publicca/apiv1beta1/helpers.go index 1675af5971cf..a4a0fef0bd30 100755 --- a/security/publicca/apiv1beta1/helpers.go +++ b/security/publicca/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/security/publicca/apiv1beta1/public_certificate_authority_client.go b/security/publicca/apiv1beta1/public_certificate_authority_client.go index a89388881ab1..243e99daaa29 100755 --- a/security/publicca/apiv1beta1/public_certificate_authority_client.go +++ b/security/publicca/apiv1beta1/public_certificate_authority_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/security/publicca/apiv1beta1/public_certificate_authority_client_example_go123_test.go b/security/publicca/apiv1beta1/public_certificate_authority_client_example_go123_test.go index d750d6a824d8..7d04bd3e6034 100644 --- a/security/publicca/apiv1beta1/public_certificate_authority_client_example_go123_test.go +++ b/security/publicca/apiv1beta1/public_certificate_authority_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/security/publicca/apiv1beta1/public_certificate_authority_client_example_test.go b/security/publicca/apiv1beta1/public_certificate_authority_client_example_test.go index a7b52daf3cbe..155755645986 100644 --- a/security/publicca/apiv1beta1/public_certificate_authority_client_example_test.go +++ b/security/publicca/apiv1beta1/public_certificate_authority_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/apiv1/auxiliary.go b/securitycenter/apiv1/auxiliary.go index 0a3650fd4f86..f83977aed72c 100755 --- a/securitycenter/apiv1/auxiliary.go +++ b/securitycenter/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/apiv1/auxiliary_go123.go b/securitycenter/apiv1/auxiliary_go123.go index fd4f4e3f2c85..a4c9d8d85721 100755 --- a/securitycenter/apiv1/auxiliary_go123.go +++ b/securitycenter/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/apiv1/doc.go b/securitycenter/apiv1/doc.go index 94303d3b3776..de317c5db2f5 100755 --- a/securitycenter/apiv1/doc.go +++ b/securitycenter/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/apiv1/helpers.go b/securitycenter/apiv1/helpers.go index 1825692c16a3..b8bdddedd84f 100755 --- a/securitycenter/apiv1/helpers.go +++ b/securitycenter/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/apiv1/security_center_client.go b/securitycenter/apiv1/security_center_client.go index 51b754b308f3..53d56d162f5c 100755 --- a/securitycenter/apiv1/security_center_client.go +++ b/securitycenter/apiv1/security_center_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/apiv1/security_center_client_example_go123_test.go b/securitycenter/apiv1/security_center_client_example_go123_test.go index 1cf63417ceff..70211f664aa8 100644 --- a/securitycenter/apiv1/security_center_client_example_go123_test.go +++ b/securitycenter/apiv1/security_center_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/apiv1/security_center_client_example_test.go b/securitycenter/apiv1/security_center_client_example_test.go index 0b40b99f8083..9fcc8a8b60a8 100644 --- a/securitycenter/apiv1/security_center_client_example_test.go +++ b/securitycenter/apiv1/security_center_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/apiv1beta1/auxiliary.go b/securitycenter/apiv1beta1/auxiliary.go index d4118ae6b7bc..506e009a6f16 100755 --- a/securitycenter/apiv1beta1/auxiliary.go +++ b/securitycenter/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/apiv1beta1/auxiliary_go123.go b/securitycenter/apiv1beta1/auxiliary_go123.go index 0e9b8b708f34..b576f47aaf3b 100755 --- a/securitycenter/apiv1beta1/auxiliary_go123.go +++ b/securitycenter/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/apiv1beta1/doc.go b/securitycenter/apiv1beta1/doc.go index d87c2c3f9f2c..1b137314683f 100755 --- a/securitycenter/apiv1beta1/doc.go +++ b/securitycenter/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/apiv1beta1/helpers.go b/securitycenter/apiv1beta1/helpers.go index 1825692c16a3..b8bdddedd84f 100755 --- a/securitycenter/apiv1beta1/helpers.go +++ b/securitycenter/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/apiv1beta1/security_center_client.go b/securitycenter/apiv1beta1/security_center_client.go index de0ce0067511..346044721524 100755 --- a/securitycenter/apiv1beta1/security_center_client.go +++ b/securitycenter/apiv1beta1/security_center_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/apiv1beta1/security_center_client_example_go123_test.go b/securitycenter/apiv1beta1/security_center_client_example_go123_test.go index 09d23c55421e..dd5a9c2cd531 100644 --- a/securitycenter/apiv1beta1/security_center_client_example_go123_test.go +++ b/securitycenter/apiv1beta1/security_center_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/apiv1beta1/security_center_client_example_test.go b/securitycenter/apiv1beta1/security_center_client_example_test.go index 26671b6454c7..3ccf3e4a4e2f 100644 --- a/securitycenter/apiv1beta1/security_center_client_example_test.go +++ b/securitycenter/apiv1beta1/security_center_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/apiv1p1beta1/auxiliary.go b/securitycenter/apiv1p1beta1/auxiliary.go index 6f5fc62e7681..d286eccc1cb1 100755 --- a/securitycenter/apiv1p1beta1/auxiliary.go +++ b/securitycenter/apiv1p1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/apiv1p1beta1/auxiliary_go123.go b/securitycenter/apiv1p1beta1/auxiliary_go123.go index 2806ca8def10..7210e2ab0988 100755 --- a/securitycenter/apiv1p1beta1/auxiliary_go123.go +++ b/securitycenter/apiv1p1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/apiv1p1beta1/doc.go b/securitycenter/apiv1p1beta1/doc.go index 61c0adb27dd2..6bf1dae0a3cd 100755 --- a/securitycenter/apiv1p1beta1/doc.go +++ b/securitycenter/apiv1p1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/apiv1p1beta1/helpers.go b/securitycenter/apiv1p1beta1/helpers.go index 1825692c16a3..b8bdddedd84f 100755 --- a/securitycenter/apiv1p1beta1/helpers.go +++ b/securitycenter/apiv1p1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/apiv1p1beta1/security_center_client.go b/securitycenter/apiv1p1beta1/security_center_client.go index 76217c5801a4..b2e20a72c340 100755 --- a/securitycenter/apiv1p1beta1/security_center_client.go +++ b/securitycenter/apiv1p1beta1/security_center_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/apiv1p1beta1/security_center_client_example_go123_test.go b/securitycenter/apiv1p1beta1/security_center_client_example_go123_test.go index 2e5a0a58951b..08c6c02a9273 100644 --- a/securitycenter/apiv1p1beta1/security_center_client_example_go123_test.go +++ b/securitycenter/apiv1p1beta1/security_center_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/apiv1p1beta1/security_center_client_example_test.go b/securitycenter/apiv1p1beta1/security_center_client_example_test.go index b7607d79c66b..3cfa68b06271 100644 --- a/securitycenter/apiv1p1beta1/security_center_client_example_test.go +++ b/securitycenter/apiv1p1beta1/security_center_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/apiv2/auxiliary.go b/securitycenter/apiv2/auxiliary.go index 55571324ff2d..64f58c424de1 100755 --- a/securitycenter/apiv2/auxiliary.go +++ b/securitycenter/apiv2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/apiv2/auxiliary_go123.go b/securitycenter/apiv2/auxiliary_go123.go index 7e91c2bb226d..6a739b71b0d8 100755 --- a/securitycenter/apiv2/auxiliary_go123.go +++ b/securitycenter/apiv2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/apiv2/doc.go b/securitycenter/apiv2/doc.go index 1aacd6c285fc..bf56ec0842ce 100755 --- a/securitycenter/apiv2/doc.go +++ b/securitycenter/apiv2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/apiv2/helpers.go b/securitycenter/apiv2/helpers.go index 1825692c16a3..b8bdddedd84f 100755 --- a/securitycenter/apiv2/helpers.go +++ b/securitycenter/apiv2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/apiv2/security_center_client.go b/securitycenter/apiv2/security_center_client.go index cfbac23883d3..049da26d4ad3 100755 --- a/securitycenter/apiv2/security_center_client.go +++ b/securitycenter/apiv2/security_center_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/apiv2/security_center_client_example_go123_test.go b/securitycenter/apiv2/security_center_client_example_go123_test.go index 020ca26e82fa..1dcaf6b9fbc7 100644 --- a/securitycenter/apiv2/security_center_client_example_go123_test.go +++ b/securitycenter/apiv2/security_center_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/apiv2/security_center_client_example_test.go b/securitycenter/apiv2/security_center_client_example_test.go index 8b896c13a1e1..94453d213f16 100644 --- a/securitycenter/apiv2/security_center_client_example_test.go +++ b/securitycenter/apiv2/security_center_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/settings/apiv1beta1/auxiliary.go b/securitycenter/settings/apiv1beta1/auxiliary.go index 6ed9e3b05de5..8bcff652a6d6 100755 --- a/securitycenter/settings/apiv1beta1/auxiliary.go +++ b/securitycenter/settings/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/settings/apiv1beta1/auxiliary_go123.go b/securitycenter/settings/apiv1beta1/auxiliary_go123.go index 378c700820e1..d1675f653987 100755 --- a/securitycenter/settings/apiv1beta1/auxiliary_go123.go +++ b/securitycenter/settings/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/settings/apiv1beta1/doc.go b/securitycenter/settings/apiv1beta1/doc.go index c04a47253c17..c499de51bdd1 100755 --- a/securitycenter/settings/apiv1beta1/doc.go +++ b/securitycenter/settings/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/settings/apiv1beta1/helpers.go b/securitycenter/settings/apiv1beta1/helpers.go index f4b5fb6edc22..bc54806e6ba8 100755 --- a/securitycenter/settings/apiv1beta1/helpers.go +++ b/securitycenter/settings/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/settings/apiv1beta1/security_center_settings_client.go b/securitycenter/settings/apiv1beta1/security_center_settings_client.go index de0be5d3c1f7..84a4c7d808ca 100755 --- a/securitycenter/settings/apiv1beta1/security_center_settings_client.go +++ b/securitycenter/settings/apiv1beta1/security_center_settings_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/settings/apiv1beta1/security_center_settings_client_example_go123_test.go b/securitycenter/settings/apiv1beta1/security_center_settings_client_example_go123_test.go index a160554454b8..08c4442d55dc 100644 --- a/securitycenter/settings/apiv1beta1/security_center_settings_client_example_go123_test.go +++ b/securitycenter/settings/apiv1beta1/security_center_settings_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycenter/settings/apiv1beta1/security_center_settings_client_example_test.go b/securitycenter/settings/apiv1beta1/security_center_settings_client_example_test.go index fac850572c1c..3cc3868b9210 100644 --- a/securitycenter/settings/apiv1beta1/security_center_settings_client_example_test.go +++ b/securitycenter/settings/apiv1beta1/security_center_settings_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycentermanagement/apiv1/auxiliary.go b/securitycentermanagement/apiv1/auxiliary.go index effa67681343..1cccb303edf1 100755 --- a/securitycentermanagement/apiv1/auxiliary.go +++ b/securitycentermanagement/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycentermanagement/apiv1/auxiliary_go123.go b/securitycentermanagement/apiv1/auxiliary_go123.go index f4e4535ba26b..31536f282dbb 100755 --- a/securitycentermanagement/apiv1/auxiliary_go123.go +++ b/securitycentermanagement/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycentermanagement/apiv1/doc.go b/securitycentermanagement/apiv1/doc.go index 6e09fde3c346..dac2ad5c5fb5 100755 --- a/securitycentermanagement/apiv1/doc.go +++ b/securitycentermanagement/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycentermanagement/apiv1/helpers.go b/securitycentermanagement/apiv1/helpers.go index 4699690635fc..97ab4fefc20b 100755 --- a/securitycentermanagement/apiv1/helpers.go +++ b/securitycentermanagement/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycentermanagement/apiv1/security_center_management_client.go b/securitycentermanagement/apiv1/security_center_management_client.go index ac3cdf3f7379..28f92041b504 100755 --- a/securitycentermanagement/apiv1/security_center_management_client.go +++ b/securitycentermanagement/apiv1/security_center_management_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycentermanagement/apiv1/security_center_management_client_example_go123_test.go b/securitycentermanagement/apiv1/security_center_management_client_example_go123_test.go index 53a3ca5ae64f..bb6933b51962 100644 --- a/securitycentermanagement/apiv1/security_center_management_client_example_go123_test.go +++ b/securitycentermanagement/apiv1/security_center_management_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securitycentermanagement/apiv1/security_center_management_client_example_test.go b/securitycentermanagement/apiv1/security_center_management_client_example_test.go index 01cfc66b5700..06f913ae0207 100644 --- a/securitycentermanagement/apiv1/security_center_management_client_example_test.go +++ b/securitycentermanagement/apiv1/security_center_management_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securityposture/apiv1/auxiliary.go b/securityposture/apiv1/auxiliary.go index 172702017ad4..507931d0fd7b 100755 --- a/securityposture/apiv1/auxiliary.go +++ b/securityposture/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securityposture/apiv1/auxiliary_go123.go b/securityposture/apiv1/auxiliary_go123.go index c54ed56c816a..7f6e89526fa3 100755 --- a/securityposture/apiv1/auxiliary_go123.go +++ b/securityposture/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securityposture/apiv1/doc.go b/securityposture/apiv1/doc.go index a7d01346657d..0bfc9b9aabcf 100755 --- a/securityposture/apiv1/doc.go +++ b/securityposture/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securityposture/apiv1/helpers.go b/securityposture/apiv1/helpers.go index 11a85035600c..31b9c42ce506 100755 --- a/securityposture/apiv1/helpers.go +++ b/securityposture/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securityposture/apiv1/security_posture_client.go b/securityposture/apiv1/security_posture_client.go index 31556ca90772..540f08401972 100755 --- a/securityposture/apiv1/security_posture_client.go +++ b/securityposture/apiv1/security_posture_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securityposture/apiv1/security_posture_client_example_go123_test.go b/securityposture/apiv1/security_posture_client_example_go123_test.go index de512571d226..58917b4426d7 100644 --- a/securityposture/apiv1/security_posture_client_example_go123_test.go +++ b/securityposture/apiv1/security_posture_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/securityposture/apiv1/security_posture_client_example_test.go b/securityposture/apiv1/security_posture_client_example_test.go index 774121977f44..05c6518739b1 100644 --- a/securityposture/apiv1/security_posture_client_example_test.go +++ b/securityposture/apiv1/security_posture_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicecontrol/apiv1/auxiliary.go b/servicecontrol/apiv1/auxiliary.go index c6bc1ad7d52c..3868f3ecefc7 100755 --- a/servicecontrol/apiv1/auxiliary.go +++ b/servicecontrol/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicecontrol/apiv1/auxiliary_go123.go b/servicecontrol/apiv1/auxiliary_go123.go index ae8058dfc890..15f994808d80 100755 --- a/servicecontrol/apiv1/auxiliary_go123.go +++ b/servicecontrol/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicecontrol/apiv1/doc.go b/servicecontrol/apiv1/doc.go index c15102ca2c67..0d1380563055 100755 --- a/servicecontrol/apiv1/doc.go +++ b/servicecontrol/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicecontrol/apiv1/helpers.go b/servicecontrol/apiv1/helpers.go index b0aa45052c7d..a55559f79fc1 100755 --- a/servicecontrol/apiv1/helpers.go +++ b/servicecontrol/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicecontrol/apiv1/quota_controller_client.go b/servicecontrol/apiv1/quota_controller_client.go index eea5f580c2ac..0af6bcd6a835 100755 --- a/servicecontrol/apiv1/quota_controller_client.go +++ b/servicecontrol/apiv1/quota_controller_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicecontrol/apiv1/quota_controller_client_example_go123_test.go b/servicecontrol/apiv1/quota_controller_client_example_go123_test.go index 0a52b4a8733a..c3361b175c92 100644 --- a/servicecontrol/apiv1/quota_controller_client_example_go123_test.go +++ b/servicecontrol/apiv1/quota_controller_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicecontrol/apiv1/quota_controller_client_example_test.go b/servicecontrol/apiv1/quota_controller_client_example_test.go index a9acb037f61c..8c56ae74af21 100644 --- a/servicecontrol/apiv1/quota_controller_client_example_test.go +++ b/servicecontrol/apiv1/quota_controller_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicecontrol/apiv1/service_controller_client.go b/servicecontrol/apiv1/service_controller_client.go index e79882316d06..4415d844226d 100755 --- a/servicecontrol/apiv1/service_controller_client.go +++ b/servicecontrol/apiv1/service_controller_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicecontrol/apiv1/service_controller_client_example_go123_test.go b/servicecontrol/apiv1/service_controller_client_example_go123_test.go index 0a52b4a8733a..c3361b175c92 100644 --- a/servicecontrol/apiv1/service_controller_client_example_go123_test.go +++ b/servicecontrol/apiv1/service_controller_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicecontrol/apiv1/service_controller_client_example_test.go b/servicecontrol/apiv1/service_controller_client_example_test.go index 6970dc73d9a9..2c36e79eea64 100644 --- a/servicecontrol/apiv1/service_controller_client_example_test.go +++ b/servicecontrol/apiv1/service_controller_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicedirectory/apiv1/auxiliary.go b/servicedirectory/apiv1/auxiliary.go index 39b38c50a159..f5e734a83b32 100755 --- a/servicedirectory/apiv1/auxiliary.go +++ b/servicedirectory/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicedirectory/apiv1/auxiliary_go123.go b/servicedirectory/apiv1/auxiliary_go123.go index 1c0d697d9efc..f8d44c471537 100755 --- a/servicedirectory/apiv1/auxiliary_go123.go +++ b/servicedirectory/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicedirectory/apiv1/doc.go b/servicedirectory/apiv1/doc.go index 8fd08ba3f044..79e310fce90b 100755 --- a/servicedirectory/apiv1/doc.go +++ b/servicedirectory/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicedirectory/apiv1/helpers.go b/servicedirectory/apiv1/helpers.go index 68bbb4348bfd..d40f44782f25 100755 --- a/servicedirectory/apiv1/helpers.go +++ b/servicedirectory/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicedirectory/apiv1/lookup_client.go b/servicedirectory/apiv1/lookup_client.go index a7fc84612085..c286fcde8315 100755 --- a/servicedirectory/apiv1/lookup_client.go +++ b/servicedirectory/apiv1/lookup_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicedirectory/apiv1/lookup_client_example_go123_test.go b/servicedirectory/apiv1/lookup_client_example_go123_test.go index 6d3829ec8429..6812faa1f16a 100644 --- a/servicedirectory/apiv1/lookup_client_example_go123_test.go +++ b/servicedirectory/apiv1/lookup_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicedirectory/apiv1/lookup_client_example_test.go b/servicedirectory/apiv1/lookup_client_example_test.go index 722c29031ea1..fd142861435e 100644 --- a/servicedirectory/apiv1/lookup_client_example_test.go +++ b/servicedirectory/apiv1/lookup_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicedirectory/apiv1/registration_client.go b/servicedirectory/apiv1/registration_client.go index 97144aa821f2..eb6b950d7ad8 100755 --- a/servicedirectory/apiv1/registration_client.go +++ b/servicedirectory/apiv1/registration_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicedirectory/apiv1/registration_client_example_go123_test.go b/servicedirectory/apiv1/registration_client_example_go123_test.go index 5f7619500a85..88683a1bfbd5 100644 --- a/servicedirectory/apiv1/registration_client_example_go123_test.go +++ b/servicedirectory/apiv1/registration_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicedirectory/apiv1/registration_client_example_test.go b/servicedirectory/apiv1/registration_client_example_test.go index 1c2c5d7ac2d6..bc2bd99e1e0d 100644 --- a/servicedirectory/apiv1/registration_client_example_test.go +++ b/servicedirectory/apiv1/registration_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicedirectory/apiv1beta1/auxiliary.go b/servicedirectory/apiv1beta1/auxiliary.go index d076a38e7383..8fae256a1269 100755 --- a/servicedirectory/apiv1beta1/auxiliary.go +++ b/servicedirectory/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicedirectory/apiv1beta1/auxiliary_go123.go b/servicedirectory/apiv1beta1/auxiliary_go123.go index b20c357a3e2a..cc0d38c5ac38 100755 --- a/servicedirectory/apiv1beta1/auxiliary_go123.go +++ b/servicedirectory/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicedirectory/apiv1beta1/doc.go b/servicedirectory/apiv1beta1/doc.go index 00d43a7323f8..bd87aadc712b 100755 --- a/servicedirectory/apiv1beta1/doc.go +++ b/servicedirectory/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicedirectory/apiv1beta1/helpers.go b/servicedirectory/apiv1beta1/helpers.go index 68bbb4348bfd..d40f44782f25 100755 --- a/servicedirectory/apiv1beta1/helpers.go +++ b/servicedirectory/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicedirectory/apiv1beta1/lookup_client.go b/servicedirectory/apiv1beta1/lookup_client.go index 6ef85ba37a79..36808ea2fd69 100755 --- a/servicedirectory/apiv1beta1/lookup_client.go +++ b/servicedirectory/apiv1beta1/lookup_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicedirectory/apiv1beta1/lookup_client_example_go123_test.go b/servicedirectory/apiv1beta1/lookup_client_example_go123_test.go index 0652271a82f3..6be4c67bae4c 100644 --- a/servicedirectory/apiv1beta1/lookup_client_example_go123_test.go +++ b/servicedirectory/apiv1beta1/lookup_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicedirectory/apiv1beta1/lookup_client_example_test.go b/servicedirectory/apiv1beta1/lookup_client_example_test.go index 03b2851161fc..424792d9e2ae 100644 --- a/servicedirectory/apiv1beta1/lookup_client_example_test.go +++ b/servicedirectory/apiv1beta1/lookup_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicedirectory/apiv1beta1/registration_client.go b/servicedirectory/apiv1beta1/registration_client.go index de468b532d5c..6474e987e3f3 100755 --- a/servicedirectory/apiv1beta1/registration_client.go +++ b/servicedirectory/apiv1beta1/registration_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicedirectory/apiv1beta1/registration_client_example_go123_test.go b/servicedirectory/apiv1beta1/registration_client_example_go123_test.go index 97cfee864000..231b9b41f1b1 100644 --- a/servicedirectory/apiv1beta1/registration_client_example_go123_test.go +++ b/servicedirectory/apiv1beta1/registration_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicedirectory/apiv1beta1/registration_client_example_test.go b/servicedirectory/apiv1beta1/registration_client_example_test.go index db663aa31f19..1ad346204538 100644 --- a/servicedirectory/apiv1beta1/registration_client_example_test.go +++ b/servicedirectory/apiv1beta1/registration_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicehealth/apiv1/auxiliary.go b/servicehealth/apiv1/auxiliary.go index 15a08a532117..de0320cdc2f8 100755 --- a/servicehealth/apiv1/auxiliary.go +++ b/servicehealth/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicehealth/apiv1/auxiliary_go123.go b/servicehealth/apiv1/auxiliary_go123.go index 48310a2ddb83..96426ca5f0bd 100755 --- a/servicehealth/apiv1/auxiliary_go123.go +++ b/servicehealth/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicehealth/apiv1/doc.go b/servicehealth/apiv1/doc.go index 104dcf133685..f068a6cb6dba 100755 --- a/servicehealth/apiv1/doc.go +++ b/servicehealth/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicehealth/apiv1/helpers.go b/servicehealth/apiv1/helpers.go index 55b4cae90600..4cbb24b0c7a5 100755 --- a/servicehealth/apiv1/helpers.go +++ b/servicehealth/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicehealth/apiv1/service_health_client.go b/servicehealth/apiv1/service_health_client.go index 6abc6c91f775..f9aa213b7c11 100755 --- a/servicehealth/apiv1/service_health_client.go +++ b/servicehealth/apiv1/service_health_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicehealth/apiv1/service_health_client_example_go123_test.go b/servicehealth/apiv1/service_health_client_example_go123_test.go index 996f85558c42..f1770506d0ac 100644 --- a/servicehealth/apiv1/service_health_client_example_go123_test.go +++ b/servicehealth/apiv1/service_health_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicehealth/apiv1/service_health_client_example_test.go b/servicehealth/apiv1/service_health_client_example_test.go index 06e8d90f225c..7eb43462ae90 100644 --- a/servicehealth/apiv1/service_health_client_example_test.go +++ b/servicehealth/apiv1/service_health_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicemanagement/apiv1/auxiliary.go b/servicemanagement/apiv1/auxiliary.go index f42dc237c34a..d89c536da14f 100755 --- a/servicemanagement/apiv1/auxiliary.go +++ b/servicemanagement/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicemanagement/apiv1/auxiliary_go123.go b/servicemanagement/apiv1/auxiliary_go123.go index dda67c0bfca2..78de3bd95c1b 100755 --- a/servicemanagement/apiv1/auxiliary_go123.go +++ b/servicemanagement/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicemanagement/apiv1/doc.go b/servicemanagement/apiv1/doc.go index a1492ab70e76..c6f783fccc2d 100755 --- a/servicemanagement/apiv1/doc.go +++ b/servicemanagement/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicemanagement/apiv1/helpers.go b/servicemanagement/apiv1/helpers.go index 440c1aaec189..03f5fc3eef40 100755 --- a/servicemanagement/apiv1/helpers.go +++ b/servicemanagement/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicemanagement/apiv1/service_manager_client.go b/servicemanagement/apiv1/service_manager_client.go index ebb64838bb8a..af720e401e59 100755 --- a/servicemanagement/apiv1/service_manager_client.go +++ b/servicemanagement/apiv1/service_manager_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicemanagement/apiv1/service_manager_client_example_go123_test.go b/servicemanagement/apiv1/service_manager_client_example_go123_test.go index e6d765466169..71a5b827e281 100644 --- a/servicemanagement/apiv1/service_manager_client_example_go123_test.go +++ b/servicemanagement/apiv1/service_manager_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/servicemanagement/apiv1/service_manager_client_example_test.go b/servicemanagement/apiv1/service_manager_client_example_test.go index 604791e19fa8..277beae7779c 100644 --- a/servicemanagement/apiv1/service_manager_client_example_test.go +++ b/servicemanagement/apiv1/service_manager_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/serviceusage/apiv1/auxiliary.go b/serviceusage/apiv1/auxiliary.go index 44d6e683684b..7e2b879d0cb5 100755 --- a/serviceusage/apiv1/auxiliary.go +++ b/serviceusage/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/serviceusage/apiv1/auxiliary_go123.go b/serviceusage/apiv1/auxiliary_go123.go index ac7a80134088..81191af3df60 100755 --- a/serviceusage/apiv1/auxiliary_go123.go +++ b/serviceusage/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/serviceusage/apiv1/doc.go b/serviceusage/apiv1/doc.go index ec87f473e1fa..2e71737daa96 100755 --- a/serviceusage/apiv1/doc.go +++ b/serviceusage/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/serviceusage/apiv1/helpers.go b/serviceusage/apiv1/helpers.go index a6a352f06869..21f99358650f 100755 --- a/serviceusage/apiv1/helpers.go +++ b/serviceusage/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/serviceusage/apiv1/service_usage_client.go b/serviceusage/apiv1/service_usage_client.go index 5b8a9f832d08..57a50af963c4 100755 --- a/serviceusage/apiv1/service_usage_client.go +++ b/serviceusage/apiv1/service_usage_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/serviceusage/apiv1/service_usage_client_example_go123_test.go b/serviceusage/apiv1/service_usage_client_example_go123_test.go index c27781afb2cd..4cb36956d332 100644 --- a/serviceusage/apiv1/service_usage_client_example_go123_test.go +++ b/serviceusage/apiv1/service_usage_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/serviceusage/apiv1/service_usage_client_example_test.go b/serviceusage/apiv1/service_usage_client_example_test.go index ba4f25423f34..f49012a6d3a3 100644 --- a/serviceusage/apiv1/service_usage_client_example_test.go +++ b/serviceusage/apiv1/service_usage_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shell/apiv1/auxiliary.go b/shell/apiv1/auxiliary.go index 64d5c153eea0..0cae38a33b03 100755 --- a/shell/apiv1/auxiliary.go +++ b/shell/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shell/apiv1/auxiliary_go123.go b/shell/apiv1/auxiliary_go123.go index e83d3ff859a0..87a5fd9aa866 100755 --- a/shell/apiv1/auxiliary_go123.go +++ b/shell/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shell/apiv1/cloud_shell_client.go b/shell/apiv1/cloud_shell_client.go index 23e33958d93a..caf1b2318f3e 100755 --- a/shell/apiv1/cloud_shell_client.go +++ b/shell/apiv1/cloud_shell_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shell/apiv1/cloud_shell_client_example_go123_test.go b/shell/apiv1/cloud_shell_client_example_go123_test.go index 5f9b8552bc90..69e457a6e101 100644 --- a/shell/apiv1/cloud_shell_client_example_go123_test.go +++ b/shell/apiv1/cloud_shell_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shell/apiv1/cloud_shell_client_example_test.go b/shell/apiv1/cloud_shell_client_example_test.go index 246d48900227..038265868e62 100644 --- a/shell/apiv1/cloud_shell_client_example_test.go +++ b/shell/apiv1/cloud_shell_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shell/apiv1/doc.go b/shell/apiv1/doc.go index 68e55ccb48e6..8568325ab05a 100755 --- a/shell/apiv1/doc.go +++ b/shell/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shell/apiv1/helpers.go b/shell/apiv1/helpers.go index c169fc135d81..49d5005d0afe 100755 --- a/shell/apiv1/helpers.go +++ b/shell/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/css/apiv1/account_labels_client.go b/shopping/css/apiv1/account_labels_client.go index f4bacc6b633a..fbec2dc91661 100755 --- a/shopping/css/apiv1/account_labels_client.go +++ b/shopping/css/apiv1/account_labels_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/css/apiv1/account_labels_client_example_go123_test.go b/shopping/css/apiv1/account_labels_client_example_go123_test.go index f7ee2809dec2..b6ff551be5bd 100644 --- a/shopping/css/apiv1/account_labels_client_example_go123_test.go +++ b/shopping/css/apiv1/account_labels_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/css/apiv1/account_labels_client_example_test.go b/shopping/css/apiv1/account_labels_client_example_test.go index a04bb901872d..406b960657a4 100644 --- a/shopping/css/apiv1/account_labels_client_example_test.go +++ b/shopping/css/apiv1/account_labels_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/css/apiv1/accounts_client.go b/shopping/css/apiv1/accounts_client.go index 30c40d6e5fe8..7f7f04694aaa 100755 --- a/shopping/css/apiv1/accounts_client.go +++ b/shopping/css/apiv1/accounts_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/css/apiv1/accounts_client_example_go123_test.go b/shopping/css/apiv1/accounts_client_example_go123_test.go index 2aebe3a6aca0..5d9bfc963343 100644 --- a/shopping/css/apiv1/accounts_client_example_go123_test.go +++ b/shopping/css/apiv1/accounts_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/css/apiv1/accounts_client_example_test.go b/shopping/css/apiv1/accounts_client_example_test.go index 1f4c4e84d698..11ad299e9449 100644 --- a/shopping/css/apiv1/accounts_client_example_test.go +++ b/shopping/css/apiv1/accounts_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/css/apiv1/auxiliary.go b/shopping/css/apiv1/auxiliary.go index c70421580329..0d6afc29d662 100755 --- a/shopping/css/apiv1/auxiliary.go +++ b/shopping/css/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/css/apiv1/auxiliary_go123.go b/shopping/css/apiv1/auxiliary_go123.go index 329286c1abae..25e0a09ed1f1 100755 --- a/shopping/css/apiv1/auxiliary_go123.go +++ b/shopping/css/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/css/apiv1/css_product_inputs_client.go b/shopping/css/apiv1/css_product_inputs_client.go index 5eddb8064e5e..d0430bbf1275 100755 --- a/shopping/css/apiv1/css_product_inputs_client.go +++ b/shopping/css/apiv1/css_product_inputs_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/css/apiv1/css_product_inputs_client_example_go123_test.go b/shopping/css/apiv1/css_product_inputs_client_example_go123_test.go index d2ab853f39c8..513e2fc6ed7f 100644 --- a/shopping/css/apiv1/css_product_inputs_client_example_go123_test.go +++ b/shopping/css/apiv1/css_product_inputs_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/css/apiv1/css_product_inputs_client_example_test.go b/shopping/css/apiv1/css_product_inputs_client_example_test.go index 847984991c09..bba6a33de57f 100644 --- a/shopping/css/apiv1/css_product_inputs_client_example_test.go +++ b/shopping/css/apiv1/css_product_inputs_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/css/apiv1/css_products_client.go b/shopping/css/apiv1/css_products_client.go index 1e7543d77941..ea0392a612d3 100755 --- a/shopping/css/apiv1/css_products_client.go +++ b/shopping/css/apiv1/css_products_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/css/apiv1/css_products_client_example_go123_test.go b/shopping/css/apiv1/css_products_client_example_go123_test.go index 8a9072684a3f..3e108b9845af 100644 --- a/shopping/css/apiv1/css_products_client_example_go123_test.go +++ b/shopping/css/apiv1/css_products_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/css/apiv1/css_products_client_example_test.go b/shopping/css/apiv1/css_products_client_example_test.go index 206e73b1d659..93e160ad4703 100644 --- a/shopping/css/apiv1/css_products_client_example_test.go +++ b/shopping/css/apiv1/css_products_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/css/apiv1/doc.go b/shopping/css/apiv1/doc.go index 02bac46c816d..c9b104519e2b 100755 --- a/shopping/css/apiv1/doc.go +++ b/shopping/css/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/css/apiv1/helpers.go b/shopping/css/apiv1/helpers.go index bc8deb8a5b67..41f74d7f588a 100755 --- a/shopping/css/apiv1/helpers.go +++ b/shopping/css/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/account_issue_client.go b/shopping/merchant/accounts/apiv1beta/account_issue_client.go index 432c5d3408db..57e4d195436c 100755 --- a/shopping/merchant/accounts/apiv1beta/account_issue_client.go +++ b/shopping/merchant/accounts/apiv1beta/account_issue_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/account_issue_client_example_go123_test.go b/shopping/merchant/accounts/apiv1beta/account_issue_client_example_go123_test.go index 7114060cd899..78883d995c90 100644 --- a/shopping/merchant/accounts/apiv1beta/account_issue_client_example_go123_test.go +++ b/shopping/merchant/accounts/apiv1beta/account_issue_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/account_issue_client_example_test.go b/shopping/merchant/accounts/apiv1beta/account_issue_client_example_test.go index dc8e7f13df98..8d70d98b8ea8 100644 --- a/shopping/merchant/accounts/apiv1beta/account_issue_client_example_test.go +++ b/shopping/merchant/accounts/apiv1beta/account_issue_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/account_tax_client.go b/shopping/merchant/accounts/apiv1beta/account_tax_client.go index b0a8e0c7604b..c9e6f77ccfb6 100755 --- a/shopping/merchant/accounts/apiv1beta/account_tax_client.go +++ b/shopping/merchant/accounts/apiv1beta/account_tax_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/account_tax_client_example_go123_test.go b/shopping/merchant/accounts/apiv1beta/account_tax_client_example_go123_test.go index b1ad34d59008..36e2a8007709 100644 --- a/shopping/merchant/accounts/apiv1beta/account_tax_client_example_go123_test.go +++ b/shopping/merchant/accounts/apiv1beta/account_tax_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/account_tax_client_example_test.go b/shopping/merchant/accounts/apiv1beta/account_tax_client_example_test.go index 339f579a1eff..12e8a27a0d13 100644 --- a/shopping/merchant/accounts/apiv1beta/account_tax_client_example_test.go +++ b/shopping/merchant/accounts/apiv1beta/account_tax_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/accounts_client.go b/shopping/merchant/accounts/apiv1beta/accounts_client.go index 9859168929a1..b4f98bfdaeb7 100755 --- a/shopping/merchant/accounts/apiv1beta/accounts_client.go +++ b/shopping/merchant/accounts/apiv1beta/accounts_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/accounts_client_example_go123_test.go b/shopping/merchant/accounts/apiv1beta/accounts_client_example_go123_test.go index 6f3be5cdac33..0cf6c62652ab 100644 --- a/shopping/merchant/accounts/apiv1beta/accounts_client_example_go123_test.go +++ b/shopping/merchant/accounts/apiv1beta/accounts_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/accounts_client_example_test.go b/shopping/merchant/accounts/apiv1beta/accounts_client_example_test.go index 396f30577dbf..c2f81dd80c08 100644 --- a/shopping/merchant/accounts/apiv1beta/accounts_client_example_test.go +++ b/shopping/merchant/accounts/apiv1beta/accounts_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/autofeed_settings_client.go b/shopping/merchant/accounts/apiv1beta/autofeed_settings_client.go index 5f33d29021da..961f443b2e5a 100755 --- a/shopping/merchant/accounts/apiv1beta/autofeed_settings_client.go +++ b/shopping/merchant/accounts/apiv1beta/autofeed_settings_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/autofeed_settings_client_example_go123_test.go b/shopping/merchant/accounts/apiv1beta/autofeed_settings_client_example_go123_test.go index 9ab990caf671..06a0cf1e4fcd 100644 --- a/shopping/merchant/accounts/apiv1beta/autofeed_settings_client_example_go123_test.go +++ b/shopping/merchant/accounts/apiv1beta/autofeed_settings_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/autofeed_settings_client_example_test.go b/shopping/merchant/accounts/apiv1beta/autofeed_settings_client_example_test.go index c0ab86b9526f..370ac0e3ea28 100644 --- a/shopping/merchant/accounts/apiv1beta/autofeed_settings_client_example_test.go +++ b/shopping/merchant/accounts/apiv1beta/autofeed_settings_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/auxiliary.go b/shopping/merchant/accounts/apiv1beta/auxiliary.go index dde6132d60af..3149042b8296 100755 --- a/shopping/merchant/accounts/apiv1beta/auxiliary.go +++ b/shopping/merchant/accounts/apiv1beta/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/auxiliary_go123.go b/shopping/merchant/accounts/apiv1beta/auxiliary_go123.go index e3c92a3a20ed..427d717951d4 100755 --- a/shopping/merchant/accounts/apiv1beta/auxiliary_go123.go +++ b/shopping/merchant/accounts/apiv1beta/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/business_identity_client.go b/shopping/merchant/accounts/apiv1beta/business_identity_client.go index c04f404acf75..2b3c9f8e50ff 100755 --- a/shopping/merchant/accounts/apiv1beta/business_identity_client.go +++ b/shopping/merchant/accounts/apiv1beta/business_identity_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/business_identity_client_example_go123_test.go b/shopping/merchant/accounts/apiv1beta/business_identity_client_example_go123_test.go index 9ab990caf671..06a0cf1e4fcd 100644 --- a/shopping/merchant/accounts/apiv1beta/business_identity_client_example_go123_test.go +++ b/shopping/merchant/accounts/apiv1beta/business_identity_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/business_identity_client_example_test.go b/shopping/merchant/accounts/apiv1beta/business_identity_client_example_test.go index f136b9c639fb..6ca853266a41 100644 --- a/shopping/merchant/accounts/apiv1beta/business_identity_client_example_test.go +++ b/shopping/merchant/accounts/apiv1beta/business_identity_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/business_info_client.go b/shopping/merchant/accounts/apiv1beta/business_info_client.go index 5d56a4d564ce..2860a642c938 100755 --- a/shopping/merchant/accounts/apiv1beta/business_info_client.go +++ b/shopping/merchant/accounts/apiv1beta/business_info_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/business_info_client_example_go123_test.go b/shopping/merchant/accounts/apiv1beta/business_info_client_example_go123_test.go index 9ab990caf671..06a0cf1e4fcd 100644 --- a/shopping/merchant/accounts/apiv1beta/business_info_client_example_go123_test.go +++ b/shopping/merchant/accounts/apiv1beta/business_info_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/business_info_client_example_test.go b/shopping/merchant/accounts/apiv1beta/business_info_client_example_test.go index 037883c474f2..0b5340d0bf91 100644 --- a/shopping/merchant/accounts/apiv1beta/business_info_client_example_test.go +++ b/shopping/merchant/accounts/apiv1beta/business_info_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/doc.go b/shopping/merchant/accounts/apiv1beta/doc.go index 7e49151a6c4c..c57490e0bc02 100755 --- a/shopping/merchant/accounts/apiv1beta/doc.go +++ b/shopping/merchant/accounts/apiv1beta/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/email_preferences_client.go b/shopping/merchant/accounts/apiv1beta/email_preferences_client.go index 9172d031dec9..c0f59805efa1 100755 --- a/shopping/merchant/accounts/apiv1beta/email_preferences_client.go +++ b/shopping/merchant/accounts/apiv1beta/email_preferences_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/email_preferences_client_example_go123_test.go b/shopping/merchant/accounts/apiv1beta/email_preferences_client_example_go123_test.go index 9ab990caf671..06a0cf1e4fcd 100644 --- a/shopping/merchant/accounts/apiv1beta/email_preferences_client_example_go123_test.go +++ b/shopping/merchant/accounts/apiv1beta/email_preferences_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/email_preferences_client_example_test.go b/shopping/merchant/accounts/apiv1beta/email_preferences_client_example_test.go index 87fcf4c77d28..e4ca77ace1d7 100644 --- a/shopping/merchant/accounts/apiv1beta/email_preferences_client_example_test.go +++ b/shopping/merchant/accounts/apiv1beta/email_preferences_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/helpers.go b/shopping/merchant/accounts/apiv1beta/helpers.go index c0427eac31ff..77dc3dc930ca 100755 --- a/shopping/merchant/accounts/apiv1beta/helpers.go +++ b/shopping/merchant/accounts/apiv1beta/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/homepage_client.go b/shopping/merchant/accounts/apiv1beta/homepage_client.go index ee78ecbe2e3b..d303c4024c62 100755 --- a/shopping/merchant/accounts/apiv1beta/homepage_client.go +++ b/shopping/merchant/accounts/apiv1beta/homepage_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/homepage_client_example_go123_test.go b/shopping/merchant/accounts/apiv1beta/homepage_client_example_go123_test.go index 9ab990caf671..06a0cf1e4fcd 100644 --- a/shopping/merchant/accounts/apiv1beta/homepage_client_example_go123_test.go +++ b/shopping/merchant/accounts/apiv1beta/homepage_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/homepage_client_example_test.go b/shopping/merchant/accounts/apiv1beta/homepage_client_example_test.go index f7a674ae4552..9ec088a9acc3 100644 --- a/shopping/merchant/accounts/apiv1beta/homepage_client_example_test.go +++ b/shopping/merchant/accounts/apiv1beta/homepage_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/online_return_policy_client.go b/shopping/merchant/accounts/apiv1beta/online_return_policy_client.go index fee1cf09f729..cbdd2c3341a7 100755 --- a/shopping/merchant/accounts/apiv1beta/online_return_policy_client.go +++ b/shopping/merchant/accounts/apiv1beta/online_return_policy_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/online_return_policy_client_example_go123_test.go b/shopping/merchant/accounts/apiv1beta/online_return_policy_client_example_go123_test.go index 179c610a9643..d87d12562958 100644 --- a/shopping/merchant/accounts/apiv1beta/online_return_policy_client_example_go123_test.go +++ b/shopping/merchant/accounts/apiv1beta/online_return_policy_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/online_return_policy_client_example_test.go b/shopping/merchant/accounts/apiv1beta/online_return_policy_client_example_test.go index 6e1a01a5cf41..7bda0f73817f 100644 --- a/shopping/merchant/accounts/apiv1beta/online_return_policy_client_example_test.go +++ b/shopping/merchant/accounts/apiv1beta/online_return_policy_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/programs_client.go b/shopping/merchant/accounts/apiv1beta/programs_client.go index 67cd06397545..9a2f26a7c5b1 100755 --- a/shopping/merchant/accounts/apiv1beta/programs_client.go +++ b/shopping/merchant/accounts/apiv1beta/programs_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/programs_client_example_go123_test.go b/shopping/merchant/accounts/apiv1beta/programs_client_example_go123_test.go index 9a7612f19886..356d5abb56de 100644 --- a/shopping/merchant/accounts/apiv1beta/programs_client_example_go123_test.go +++ b/shopping/merchant/accounts/apiv1beta/programs_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/programs_client_example_test.go b/shopping/merchant/accounts/apiv1beta/programs_client_example_test.go index 7e0574dae3a0..89e450beb684 100644 --- a/shopping/merchant/accounts/apiv1beta/programs_client_example_test.go +++ b/shopping/merchant/accounts/apiv1beta/programs_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/regions_client.go b/shopping/merchant/accounts/apiv1beta/regions_client.go index 00b9fef158e4..47e4868bd678 100755 --- a/shopping/merchant/accounts/apiv1beta/regions_client.go +++ b/shopping/merchant/accounts/apiv1beta/regions_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/regions_client_example_go123_test.go b/shopping/merchant/accounts/apiv1beta/regions_client_example_go123_test.go index 64d6e5297b0e..1c6f1530deed 100644 --- a/shopping/merchant/accounts/apiv1beta/regions_client_example_go123_test.go +++ b/shopping/merchant/accounts/apiv1beta/regions_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/regions_client_example_test.go b/shopping/merchant/accounts/apiv1beta/regions_client_example_test.go index 445c408aaf06..9ecb4bf2a9bc 100644 --- a/shopping/merchant/accounts/apiv1beta/regions_client_example_test.go +++ b/shopping/merchant/accounts/apiv1beta/regions_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/shipping_settings_client.go b/shopping/merchant/accounts/apiv1beta/shipping_settings_client.go index 80298decbc11..d02e3abc376a 100755 --- a/shopping/merchant/accounts/apiv1beta/shipping_settings_client.go +++ b/shopping/merchant/accounts/apiv1beta/shipping_settings_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/shipping_settings_client_example_go123_test.go b/shopping/merchant/accounts/apiv1beta/shipping_settings_client_example_go123_test.go index 9ab990caf671..06a0cf1e4fcd 100644 --- a/shopping/merchant/accounts/apiv1beta/shipping_settings_client_example_go123_test.go +++ b/shopping/merchant/accounts/apiv1beta/shipping_settings_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/shipping_settings_client_example_test.go b/shopping/merchant/accounts/apiv1beta/shipping_settings_client_example_test.go index e6e5ae8f7bd2..6da640d0e566 100644 --- a/shopping/merchant/accounts/apiv1beta/shipping_settings_client_example_test.go +++ b/shopping/merchant/accounts/apiv1beta/shipping_settings_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/terms_of_service_agreement_state_client.go b/shopping/merchant/accounts/apiv1beta/terms_of_service_agreement_state_client.go index 73dd02bcd90c..4737d7c2e28e 100755 --- a/shopping/merchant/accounts/apiv1beta/terms_of_service_agreement_state_client.go +++ b/shopping/merchant/accounts/apiv1beta/terms_of_service_agreement_state_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/terms_of_service_agreement_state_client_example_go123_test.go b/shopping/merchant/accounts/apiv1beta/terms_of_service_agreement_state_client_example_go123_test.go index 9ab990caf671..06a0cf1e4fcd 100644 --- a/shopping/merchant/accounts/apiv1beta/terms_of_service_agreement_state_client_example_go123_test.go +++ b/shopping/merchant/accounts/apiv1beta/terms_of_service_agreement_state_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/terms_of_service_agreement_state_client_example_test.go b/shopping/merchant/accounts/apiv1beta/terms_of_service_agreement_state_client_example_test.go index 29e88ea1bfeb..daddd6b70b23 100644 --- a/shopping/merchant/accounts/apiv1beta/terms_of_service_agreement_state_client_example_test.go +++ b/shopping/merchant/accounts/apiv1beta/terms_of_service_agreement_state_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/terms_of_service_client.go b/shopping/merchant/accounts/apiv1beta/terms_of_service_client.go index 246e1fae1fd1..cb7c4cf3d297 100755 --- a/shopping/merchant/accounts/apiv1beta/terms_of_service_client.go +++ b/shopping/merchant/accounts/apiv1beta/terms_of_service_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/terms_of_service_client_example_go123_test.go b/shopping/merchant/accounts/apiv1beta/terms_of_service_client_example_go123_test.go index 9ab990caf671..06a0cf1e4fcd 100644 --- a/shopping/merchant/accounts/apiv1beta/terms_of_service_client_example_go123_test.go +++ b/shopping/merchant/accounts/apiv1beta/terms_of_service_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/terms_of_service_client_example_test.go b/shopping/merchant/accounts/apiv1beta/terms_of_service_client_example_test.go index 00c0ac0b1abb..36cd4c830b8a 100644 --- a/shopping/merchant/accounts/apiv1beta/terms_of_service_client_example_test.go +++ b/shopping/merchant/accounts/apiv1beta/terms_of_service_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/user_client.go b/shopping/merchant/accounts/apiv1beta/user_client.go index 428c7f873e01..a0182709e434 100755 --- a/shopping/merchant/accounts/apiv1beta/user_client.go +++ b/shopping/merchant/accounts/apiv1beta/user_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/user_client_example_go123_test.go b/shopping/merchant/accounts/apiv1beta/user_client_example_go123_test.go index 5fae5d29f40e..9092d9b4a356 100644 --- a/shopping/merchant/accounts/apiv1beta/user_client_example_go123_test.go +++ b/shopping/merchant/accounts/apiv1beta/user_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/accounts/apiv1beta/user_client_example_test.go b/shopping/merchant/accounts/apiv1beta/user_client_example_test.go index 74e779bccc44..1ef04ef1c8d2 100644 --- a/shopping/merchant/accounts/apiv1beta/user_client_example_test.go +++ b/shopping/merchant/accounts/apiv1beta/user_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/conversions/apiv1beta/auxiliary.go b/shopping/merchant/conversions/apiv1beta/auxiliary.go index 6da33dabc4f1..3960f4ff952b 100755 --- a/shopping/merchant/conversions/apiv1beta/auxiliary.go +++ b/shopping/merchant/conversions/apiv1beta/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/conversions/apiv1beta/auxiliary_go123.go b/shopping/merchant/conversions/apiv1beta/auxiliary_go123.go index 1b8595780c94..393481bfac63 100755 --- a/shopping/merchant/conversions/apiv1beta/auxiliary_go123.go +++ b/shopping/merchant/conversions/apiv1beta/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/conversions/apiv1beta/conversion_sources_client.go b/shopping/merchant/conversions/apiv1beta/conversion_sources_client.go index a6e379d33d88..544c36ea2a1c 100755 --- a/shopping/merchant/conversions/apiv1beta/conversion_sources_client.go +++ b/shopping/merchant/conversions/apiv1beta/conversion_sources_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/conversions/apiv1beta/conversion_sources_client_example_go123_test.go b/shopping/merchant/conversions/apiv1beta/conversion_sources_client_example_go123_test.go index 0f5638d47278..be35a72a88e1 100644 --- a/shopping/merchant/conversions/apiv1beta/conversion_sources_client_example_go123_test.go +++ b/shopping/merchant/conversions/apiv1beta/conversion_sources_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/conversions/apiv1beta/conversion_sources_client_example_test.go b/shopping/merchant/conversions/apiv1beta/conversion_sources_client_example_test.go index b8e13add2e16..4ee82828c6cc 100644 --- a/shopping/merchant/conversions/apiv1beta/conversion_sources_client_example_test.go +++ b/shopping/merchant/conversions/apiv1beta/conversion_sources_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/conversions/apiv1beta/doc.go b/shopping/merchant/conversions/apiv1beta/doc.go index 5f425c1371ac..b934e925037f 100755 --- a/shopping/merchant/conversions/apiv1beta/doc.go +++ b/shopping/merchant/conversions/apiv1beta/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/conversions/apiv1beta/helpers.go b/shopping/merchant/conversions/apiv1beta/helpers.go index 1b9cb66bacfe..5ec8d9df85f6 100755 --- a/shopping/merchant/conversions/apiv1beta/helpers.go +++ b/shopping/merchant/conversions/apiv1beta/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/datasources/apiv1beta/auxiliary.go b/shopping/merchant/datasources/apiv1beta/auxiliary.go index 828470314aab..45c38c1eccf8 100755 --- a/shopping/merchant/datasources/apiv1beta/auxiliary.go +++ b/shopping/merchant/datasources/apiv1beta/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/datasources/apiv1beta/auxiliary_go123.go b/shopping/merchant/datasources/apiv1beta/auxiliary_go123.go index 27bfe8523711..f6a7a271d71c 100755 --- a/shopping/merchant/datasources/apiv1beta/auxiliary_go123.go +++ b/shopping/merchant/datasources/apiv1beta/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/datasources/apiv1beta/data_sources_client.go b/shopping/merchant/datasources/apiv1beta/data_sources_client.go index 63a1ccc1c5e0..0ddceedc80fe 100755 --- a/shopping/merchant/datasources/apiv1beta/data_sources_client.go +++ b/shopping/merchant/datasources/apiv1beta/data_sources_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/datasources/apiv1beta/data_sources_client_example_go123_test.go b/shopping/merchant/datasources/apiv1beta/data_sources_client_example_go123_test.go index f5036869ca91..77d82a4e99b6 100644 --- a/shopping/merchant/datasources/apiv1beta/data_sources_client_example_go123_test.go +++ b/shopping/merchant/datasources/apiv1beta/data_sources_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/datasources/apiv1beta/data_sources_client_example_test.go b/shopping/merchant/datasources/apiv1beta/data_sources_client_example_test.go index 6a15fb7346eb..4448b1001fd3 100644 --- a/shopping/merchant/datasources/apiv1beta/data_sources_client_example_test.go +++ b/shopping/merchant/datasources/apiv1beta/data_sources_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/datasources/apiv1beta/doc.go b/shopping/merchant/datasources/apiv1beta/doc.go index a50b26c3aeac..11bdf004a3f5 100755 --- a/shopping/merchant/datasources/apiv1beta/doc.go +++ b/shopping/merchant/datasources/apiv1beta/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/datasources/apiv1beta/file_uploads_client.go b/shopping/merchant/datasources/apiv1beta/file_uploads_client.go index 2817b5d4e622..de4bbcd20136 100755 --- a/shopping/merchant/datasources/apiv1beta/file_uploads_client.go +++ b/shopping/merchant/datasources/apiv1beta/file_uploads_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/datasources/apiv1beta/file_uploads_client_example_go123_test.go b/shopping/merchant/datasources/apiv1beta/file_uploads_client_example_go123_test.go index a28cd3461946..f1507061bc92 100644 --- a/shopping/merchant/datasources/apiv1beta/file_uploads_client_example_go123_test.go +++ b/shopping/merchant/datasources/apiv1beta/file_uploads_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/datasources/apiv1beta/file_uploads_client_example_test.go b/shopping/merchant/datasources/apiv1beta/file_uploads_client_example_test.go index fbde2461b991..44fe20f6048a 100644 --- a/shopping/merchant/datasources/apiv1beta/file_uploads_client_example_test.go +++ b/shopping/merchant/datasources/apiv1beta/file_uploads_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/datasources/apiv1beta/helpers.go b/shopping/merchant/datasources/apiv1beta/helpers.go index 37b287753fda..1d5ed7010b26 100755 --- a/shopping/merchant/datasources/apiv1beta/helpers.go +++ b/shopping/merchant/datasources/apiv1beta/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/inventories/apiv1beta/auxiliary.go b/shopping/merchant/inventories/apiv1beta/auxiliary.go index 2ed825e338d2..a9d0baefef6d 100755 --- a/shopping/merchant/inventories/apiv1beta/auxiliary.go +++ b/shopping/merchant/inventories/apiv1beta/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/inventories/apiv1beta/auxiliary_go123.go b/shopping/merchant/inventories/apiv1beta/auxiliary_go123.go index 0b072409e421..777aa830e3e2 100755 --- a/shopping/merchant/inventories/apiv1beta/auxiliary_go123.go +++ b/shopping/merchant/inventories/apiv1beta/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/inventories/apiv1beta/doc.go b/shopping/merchant/inventories/apiv1beta/doc.go index 3721b0595f64..4f6db1b639db 100755 --- a/shopping/merchant/inventories/apiv1beta/doc.go +++ b/shopping/merchant/inventories/apiv1beta/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/inventories/apiv1beta/helpers.go b/shopping/merchant/inventories/apiv1beta/helpers.go index c93a1c103bf9..cc47bbd5bb7b 100755 --- a/shopping/merchant/inventories/apiv1beta/helpers.go +++ b/shopping/merchant/inventories/apiv1beta/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/inventories/apiv1beta/local_inventory_client.go b/shopping/merchant/inventories/apiv1beta/local_inventory_client.go index eab28f0529e0..cceed2a1352a 100755 --- a/shopping/merchant/inventories/apiv1beta/local_inventory_client.go +++ b/shopping/merchant/inventories/apiv1beta/local_inventory_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/inventories/apiv1beta/local_inventory_client_example_go123_test.go b/shopping/merchant/inventories/apiv1beta/local_inventory_client_example_go123_test.go index cf6312f1c147..e65f0f9e42d3 100644 --- a/shopping/merchant/inventories/apiv1beta/local_inventory_client_example_go123_test.go +++ b/shopping/merchant/inventories/apiv1beta/local_inventory_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/inventories/apiv1beta/local_inventory_client_example_test.go b/shopping/merchant/inventories/apiv1beta/local_inventory_client_example_test.go index 74e1a7c11fc4..9e195e485188 100644 --- a/shopping/merchant/inventories/apiv1beta/local_inventory_client_example_test.go +++ b/shopping/merchant/inventories/apiv1beta/local_inventory_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/inventories/apiv1beta/regional_inventory_client.go b/shopping/merchant/inventories/apiv1beta/regional_inventory_client.go index ae8b6c5d40e0..c8942df6deaa 100755 --- a/shopping/merchant/inventories/apiv1beta/regional_inventory_client.go +++ b/shopping/merchant/inventories/apiv1beta/regional_inventory_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/inventories/apiv1beta/regional_inventory_client_example_go123_test.go b/shopping/merchant/inventories/apiv1beta/regional_inventory_client_example_go123_test.go index 84db41f6430a..ba640dcbbeed 100644 --- a/shopping/merchant/inventories/apiv1beta/regional_inventory_client_example_go123_test.go +++ b/shopping/merchant/inventories/apiv1beta/regional_inventory_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/inventories/apiv1beta/regional_inventory_client_example_test.go b/shopping/merchant/inventories/apiv1beta/regional_inventory_client_example_test.go index 12c436361902..b143090f0e43 100644 --- a/shopping/merchant/inventories/apiv1beta/regional_inventory_client_example_test.go +++ b/shopping/merchant/inventories/apiv1beta/regional_inventory_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/lfp/apiv1beta/auxiliary.go b/shopping/merchant/lfp/apiv1beta/auxiliary.go index 6e20d68ca864..bb1334bc2d7e 100755 --- a/shopping/merchant/lfp/apiv1beta/auxiliary.go +++ b/shopping/merchant/lfp/apiv1beta/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/lfp/apiv1beta/auxiliary_go123.go b/shopping/merchant/lfp/apiv1beta/auxiliary_go123.go index ee3a47f5cd0a..4d1eeb3c76a6 100755 --- a/shopping/merchant/lfp/apiv1beta/auxiliary_go123.go +++ b/shopping/merchant/lfp/apiv1beta/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/lfp/apiv1beta/doc.go b/shopping/merchant/lfp/apiv1beta/doc.go index fa146b77c837..704b4b5077bd 100755 --- a/shopping/merchant/lfp/apiv1beta/doc.go +++ b/shopping/merchant/lfp/apiv1beta/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/lfp/apiv1beta/helpers.go b/shopping/merchant/lfp/apiv1beta/helpers.go index 458f53bf5329..86e0e625c229 100755 --- a/shopping/merchant/lfp/apiv1beta/helpers.go +++ b/shopping/merchant/lfp/apiv1beta/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/lfp/apiv1beta/lfp_inventory_client.go b/shopping/merchant/lfp/apiv1beta/lfp_inventory_client.go index 9c9dd50b82dd..9edf24311738 100755 --- a/shopping/merchant/lfp/apiv1beta/lfp_inventory_client.go +++ b/shopping/merchant/lfp/apiv1beta/lfp_inventory_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/lfp/apiv1beta/lfp_inventory_client_example_go123_test.go b/shopping/merchant/lfp/apiv1beta/lfp_inventory_client_example_go123_test.go index 1e426e433903..1421e7c53a0c 100644 --- a/shopping/merchant/lfp/apiv1beta/lfp_inventory_client_example_go123_test.go +++ b/shopping/merchant/lfp/apiv1beta/lfp_inventory_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/lfp/apiv1beta/lfp_inventory_client_example_test.go b/shopping/merchant/lfp/apiv1beta/lfp_inventory_client_example_test.go index 77b760ae4913..0f907719d5d0 100644 --- a/shopping/merchant/lfp/apiv1beta/lfp_inventory_client_example_test.go +++ b/shopping/merchant/lfp/apiv1beta/lfp_inventory_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/lfp/apiv1beta/lfp_sale_client.go b/shopping/merchant/lfp/apiv1beta/lfp_sale_client.go index 665d90dd5ab0..f8d741e44413 100755 --- a/shopping/merchant/lfp/apiv1beta/lfp_sale_client.go +++ b/shopping/merchant/lfp/apiv1beta/lfp_sale_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/lfp/apiv1beta/lfp_sale_client_example_go123_test.go b/shopping/merchant/lfp/apiv1beta/lfp_sale_client_example_go123_test.go index 1e426e433903..1421e7c53a0c 100644 --- a/shopping/merchant/lfp/apiv1beta/lfp_sale_client_example_go123_test.go +++ b/shopping/merchant/lfp/apiv1beta/lfp_sale_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/lfp/apiv1beta/lfp_sale_client_example_test.go b/shopping/merchant/lfp/apiv1beta/lfp_sale_client_example_test.go index 1fc4e1083f8b..4d2d53906e46 100644 --- a/shopping/merchant/lfp/apiv1beta/lfp_sale_client_example_test.go +++ b/shopping/merchant/lfp/apiv1beta/lfp_sale_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/lfp/apiv1beta/lfp_store_client.go b/shopping/merchant/lfp/apiv1beta/lfp_store_client.go index c854231104dc..3e205dc60631 100755 --- a/shopping/merchant/lfp/apiv1beta/lfp_store_client.go +++ b/shopping/merchant/lfp/apiv1beta/lfp_store_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/lfp/apiv1beta/lfp_store_client_example_go123_test.go b/shopping/merchant/lfp/apiv1beta/lfp_store_client_example_go123_test.go index 3855bc0fdac0..dd5920cef5e8 100644 --- a/shopping/merchant/lfp/apiv1beta/lfp_store_client_example_go123_test.go +++ b/shopping/merchant/lfp/apiv1beta/lfp_store_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/lfp/apiv1beta/lfp_store_client_example_test.go b/shopping/merchant/lfp/apiv1beta/lfp_store_client_example_test.go index 3b4bd7c77336..fc2aa4f0a931 100644 --- a/shopping/merchant/lfp/apiv1beta/lfp_store_client_example_test.go +++ b/shopping/merchant/lfp/apiv1beta/lfp_store_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/notifications/apiv1beta/auxiliary.go b/shopping/merchant/notifications/apiv1beta/auxiliary.go index 41b1fb6905dd..d08637bfb07a 100755 --- a/shopping/merchant/notifications/apiv1beta/auxiliary.go +++ b/shopping/merchant/notifications/apiv1beta/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/notifications/apiv1beta/auxiliary_go123.go b/shopping/merchant/notifications/apiv1beta/auxiliary_go123.go index a5db75e9cf99..1e4b34b49c21 100755 --- a/shopping/merchant/notifications/apiv1beta/auxiliary_go123.go +++ b/shopping/merchant/notifications/apiv1beta/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/notifications/apiv1beta/doc.go b/shopping/merchant/notifications/apiv1beta/doc.go index b7b05f591586..41a050842ad9 100755 --- a/shopping/merchant/notifications/apiv1beta/doc.go +++ b/shopping/merchant/notifications/apiv1beta/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/notifications/apiv1beta/helpers.go b/shopping/merchant/notifications/apiv1beta/helpers.go index fbb039491bd0..9bdba3193c74 100755 --- a/shopping/merchant/notifications/apiv1beta/helpers.go +++ b/shopping/merchant/notifications/apiv1beta/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/notifications/apiv1beta/notifications_api_client.go b/shopping/merchant/notifications/apiv1beta/notifications_api_client.go index e6e9cd2bf093..70cb2aff636b 100755 --- a/shopping/merchant/notifications/apiv1beta/notifications_api_client.go +++ b/shopping/merchant/notifications/apiv1beta/notifications_api_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/notifications/apiv1beta/notifications_api_client_example_go123_test.go b/shopping/merchant/notifications/apiv1beta/notifications_api_client_example_go123_test.go index f65aba72b6be..657066a92e0c 100644 --- a/shopping/merchant/notifications/apiv1beta/notifications_api_client_example_go123_test.go +++ b/shopping/merchant/notifications/apiv1beta/notifications_api_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/notifications/apiv1beta/notifications_api_client_example_test.go b/shopping/merchant/notifications/apiv1beta/notifications_api_client_example_test.go index 9399210b9f9d..4a0b0ef05f80 100644 --- a/shopping/merchant/notifications/apiv1beta/notifications_api_client_example_test.go +++ b/shopping/merchant/notifications/apiv1beta/notifications_api_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/products/apiv1beta/auxiliary.go b/shopping/merchant/products/apiv1beta/auxiliary.go index 88fe38416ba8..d5d209e20135 100755 --- a/shopping/merchant/products/apiv1beta/auxiliary.go +++ b/shopping/merchant/products/apiv1beta/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/products/apiv1beta/auxiliary_go123.go b/shopping/merchant/products/apiv1beta/auxiliary_go123.go index c9ce6cd04e85..b7e062254de6 100755 --- a/shopping/merchant/products/apiv1beta/auxiliary_go123.go +++ b/shopping/merchant/products/apiv1beta/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/products/apiv1beta/doc.go b/shopping/merchant/products/apiv1beta/doc.go index fe0a96e25449..00b6a8c48b6e 100755 --- a/shopping/merchant/products/apiv1beta/doc.go +++ b/shopping/merchant/products/apiv1beta/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/products/apiv1beta/helpers.go b/shopping/merchant/products/apiv1beta/helpers.go index d604ed620cdf..6099e6d87e52 100755 --- a/shopping/merchant/products/apiv1beta/helpers.go +++ b/shopping/merchant/products/apiv1beta/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/products/apiv1beta/product_inputs_client.go b/shopping/merchant/products/apiv1beta/product_inputs_client.go index 4f6d077f5abf..cea62c1fb90f 100755 --- a/shopping/merchant/products/apiv1beta/product_inputs_client.go +++ b/shopping/merchant/products/apiv1beta/product_inputs_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/products/apiv1beta/product_inputs_client_example_go123_test.go b/shopping/merchant/products/apiv1beta/product_inputs_client_example_go123_test.go index fff5464b4fd5..79f16882aa2c 100644 --- a/shopping/merchant/products/apiv1beta/product_inputs_client_example_go123_test.go +++ b/shopping/merchant/products/apiv1beta/product_inputs_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/products/apiv1beta/product_inputs_client_example_test.go b/shopping/merchant/products/apiv1beta/product_inputs_client_example_test.go index d3597d6b7fdb..601df63f56eb 100644 --- a/shopping/merchant/products/apiv1beta/product_inputs_client_example_test.go +++ b/shopping/merchant/products/apiv1beta/product_inputs_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/products/apiv1beta/products_client.go b/shopping/merchant/products/apiv1beta/products_client.go index d364088013f2..98794557097c 100755 --- a/shopping/merchant/products/apiv1beta/products_client.go +++ b/shopping/merchant/products/apiv1beta/products_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/products/apiv1beta/products_client_example_go123_test.go b/shopping/merchant/products/apiv1beta/products_client_example_go123_test.go index 844594e8f834..2279ed7b1362 100644 --- a/shopping/merchant/products/apiv1beta/products_client_example_go123_test.go +++ b/shopping/merchant/products/apiv1beta/products_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/products/apiv1beta/products_client_example_test.go b/shopping/merchant/products/apiv1beta/products_client_example_test.go index a17d2eeca949..e1cbadaca1c5 100644 --- a/shopping/merchant/products/apiv1beta/products_client_example_test.go +++ b/shopping/merchant/products/apiv1beta/products_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/promotions/apiv1beta/auxiliary.go b/shopping/merchant/promotions/apiv1beta/auxiliary.go index c893b63c6633..16e5b8615318 100755 --- a/shopping/merchant/promotions/apiv1beta/auxiliary.go +++ b/shopping/merchant/promotions/apiv1beta/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/promotions/apiv1beta/auxiliary_go123.go b/shopping/merchant/promotions/apiv1beta/auxiliary_go123.go index 29181f602663..1a085c84dc45 100755 --- a/shopping/merchant/promotions/apiv1beta/auxiliary_go123.go +++ b/shopping/merchant/promotions/apiv1beta/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/promotions/apiv1beta/doc.go b/shopping/merchant/promotions/apiv1beta/doc.go index 8c432f77b319..138965851cf8 100755 --- a/shopping/merchant/promotions/apiv1beta/doc.go +++ b/shopping/merchant/promotions/apiv1beta/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/promotions/apiv1beta/helpers.go b/shopping/merchant/promotions/apiv1beta/helpers.go index c642c420cc39..a0df5593ca07 100755 --- a/shopping/merchant/promotions/apiv1beta/helpers.go +++ b/shopping/merchant/promotions/apiv1beta/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/promotions/apiv1beta/promotions_client.go b/shopping/merchant/promotions/apiv1beta/promotions_client.go index f78a8286dc4d..d7fbf6db2f1a 100755 --- a/shopping/merchant/promotions/apiv1beta/promotions_client.go +++ b/shopping/merchant/promotions/apiv1beta/promotions_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/promotions/apiv1beta/promotions_client_example_go123_test.go b/shopping/merchant/promotions/apiv1beta/promotions_client_example_go123_test.go index 960b80aff3dc..6b9e64362366 100644 --- a/shopping/merchant/promotions/apiv1beta/promotions_client_example_go123_test.go +++ b/shopping/merchant/promotions/apiv1beta/promotions_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/promotions/apiv1beta/promotions_client_example_test.go b/shopping/merchant/promotions/apiv1beta/promotions_client_example_test.go index 56e8090255a3..28191ba9fe67 100644 --- a/shopping/merchant/promotions/apiv1beta/promotions_client_example_test.go +++ b/shopping/merchant/promotions/apiv1beta/promotions_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/quota/apiv1beta/auxiliary.go b/shopping/merchant/quota/apiv1beta/auxiliary.go index 72577368aac5..a4ac89e54266 100755 --- a/shopping/merchant/quota/apiv1beta/auxiliary.go +++ b/shopping/merchant/quota/apiv1beta/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/quota/apiv1beta/auxiliary_go123.go b/shopping/merchant/quota/apiv1beta/auxiliary_go123.go index 35df8bef38b9..ec3037300ca4 100755 --- a/shopping/merchant/quota/apiv1beta/auxiliary_go123.go +++ b/shopping/merchant/quota/apiv1beta/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/quota/apiv1beta/doc.go b/shopping/merchant/quota/apiv1beta/doc.go index 9906b35cb58a..cd4ecb2bfb3c 100755 --- a/shopping/merchant/quota/apiv1beta/doc.go +++ b/shopping/merchant/quota/apiv1beta/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/quota/apiv1beta/helpers.go b/shopping/merchant/quota/apiv1beta/helpers.go index d9b5531a6900..9f18a911b5b7 100755 --- a/shopping/merchant/quota/apiv1beta/helpers.go +++ b/shopping/merchant/quota/apiv1beta/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/quota/apiv1beta/quota_client.go b/shopping/merchant/quota/apiv1beta/quota_client.go index 2cc341c7f684..1a7fbdc24615 100755 --- a/shopping/merchant/quota/apiv1beta/quota_client.go +++ b/shopping/merchant/quota/apiv1beta/quota_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/quota/apiv1beta/quota_client_example_go123_test.go b/shopping/merchant/quota/apiv1beta/quota_client_example_go123_test.go index a322b5e6ac97..2f3e690e89ac 100644 --- a/shopping/merchant/quota/apiv1beta/quota_client_example_go123_test.go +++ b/shopping/merchant/quota/apiv1beta/quota_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/quota/apiv1beta/quota_client_example_test.go b/shopping/merchant/quota/apiv1beta/quota_client_example_test.go index 77eb25601084..3eaf3cc24850 100644 --- a/shopping/merchant/quota/apiv1beta/quota_client_example_test.go +++ b/shopping/merchant/quota/apiv1beta/quota_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/reports/apiv1beta/auxiliary.go b/shopping/merchant/reports/apiv1beta/auxiliary.go index edd397e91c19..5584581d3c05 100755 --- a/shopping/merchant/reports/apiv1beta/auxiliary.go +++ b/shopping/merchant/reports/apiv1beta/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/reports/apiv1beta/auxiliary_go123.go b/shopping/merchant/reports/apiv1beta/auxiliary_go123.go index 353d94b6a300..990f10197da3 100755 --- a/shopping/merchant/reports/apiv1beta/auxiliary_go123.go +++ b/shopping/merchant/reports/apiv1beta/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/reports/apiv1beta/doc.go b/shopping/merchant/reports/apiv1beta/doc.go index a390e85eab5d..afed3296d658 100755 --- a/shopping/merchant/reports/apiv1beta/doc.go +++ b/shopping/merchant/reports/apiv1beta/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/reports/apiv1beta/helpers.go b/shopping/merchant/reports/apiv1beta/helpers.go index 4b1fe4a756e2..a748deeca150 100755 --- a/shopping/merchant/reports/apiv1beta/helpers.go +++ b/shopping/merchant/reports/apiv1beta/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/reports/apiv1beta/report_client.go b/shopping/merchant/reports/apiv1beta/report_client.go index 55cccd076205..43b863dfa95e 100755 --- a/shopping/merchant/reports/apiv1beta/report_client.go +++ b/shopping/merchant/reports/apiv1beta/report_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/reports/apiv1beta/report_client_example_go123_test.go b/shopping/merchant/reports/apiv1beta/report_client_example_go123_test.go index 66c2afecc056..42c906e1e2c0 100644 --- a/shopping/merchant/reports/apiv1beta/report_client_example_go123_test.go +++ b/shopping/merchant/reports/apiv1beta/report_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/reports/apiv1beta/report_client_example_test.go b/shopping/merchant/reports/apiv1beta/report_client_example_test.go index a3f001156b8e..fd47e694c77d 100644 --- a/shopping/merchant/reports/apiv1beta/report_client_example_test.go +++ b/shopping/merchant/reports/apiv1beta/report_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/reviews/apiv1beta/auxiliary.go b/shopping/merchant/reviews/apiv1beta/auxiliary.go index f5f9bab187cc..8dbccd121fc6 100755 --- a/shopping/merchant/reviews/apiv1beta/auxiliary.go +++ b/shopping/merchant/reviews/apiv1beta/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/reviews/apiv1beta/auxiliary_go123.go b/shopping/merchant/reviews/apiv1beta/auxiliary_go123.go index 62d84ddc9bdc..b22dd9ce71de 100755 --- a/shopping/merchant/reviews/apiv1beta/auxiliary_go123.go +++ b/shopping/merchant/reviews/apiv1beta/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/reviews/apiv1beta/doc.go b/shopping/merchant/reviews/apiv1beta/doc.go index 43cfa61b9f02..e774bc494b0c 100755 --- a/shopping/merchant/reviews/apiv1beta/doc.go +++ b/shopping/merchant/reviews/apiv1beta/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/reviews/apiv1beta/helpers.go b/shopping/merchant/reviews/apiv1beta/helpers.go index d28f9ebce034..9ce7ba2af308 100755 --- a/shopping/merchant/reviews/apiv1beta/helpers.go +++ b/shopping/merchant/reviews/apiv1beta/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/reviews/apiv1beta/merchant_reviews_client.go b/shopping/merchant/reviews/apiv1beta/merchant_reviews_client.go index ed1f782a3842..d5a24071b8c7 100755 --- a/shopping/merchant/reviews/apiv1beta/merchant_reviews_client.go +++ b/shopping/merchant/reviews/apiv1beta/merchant_reviews_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/reviews/apiv1beta/merchant_reviews_client_example_go123_test.go b/shopping/merchant/reviews/apiv1beta/merchant_reviews_client_example_go123_test.go index b94f8cfbe4aa..066fe0401c1a 100644 --- a/shopping/merchant/reviews/apiv1beta/merchant_reviews_client_example_go123_test.go +++ b/shopping/merchant/reviews/apiv1beta/merchant_reviews_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/reviews/apiv1beta/merchant_reviews_client_example_test.go b/shopping/merchant/reviews/apiv1beta/merchant_reviews_client_example_test.go index 9ebb20a7d005..229e0e41de92 100644 --- a/shopping/merchant/reviews/apiv1beta/merchant_reviews_client_example_test.go +++ b/shopping/merchant/reviews/apiv1beta/merchant_reviews_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/reviews/apiv1beta/product_reviews_client.go b/shopping/merchant/reviews/apiv1beta/product_reviews_client.go index 298ac1cdfd45..480cb6bd75e2 100755 --- a/shopping/merchant/reviews/apiv1beta/product_reviews_client.go +++ b/shopping/merchant/reviews/apiv1beta/product_reviews_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/reviews/apiv1beta/product_reviews_client_example_go123_test.go b/shopping/merchant/reviews/apiv1beta/product_reviews_client_example_go123_test.go index b712aa210986..6db0f6f99b09 100644 --- a/shopping/merchant/reviews/apiv1beta/product_reviews_client_example_go123_test.go +++ b/shopping/merchant/reviews/apiv1beta/product_reviews_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/shopping/merchant/reviews/apiv1beta/product_reviews_client_example_test.go b/shopping/merchant/reviews/apiv1beta/product_reviews_client_example_test.go index 6de9d6eb0638..b81ce97fa87a 100644 --- a/shopping/merchant/reviews/apiv1beta/product_reviews_client_example_test.go +++ b/shopping/merchant/reviews/apiv1beta/product_reviews_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/spanner/admin/database/apiv1/auxiliary.go b/spanner/admin/database/apiv1/auxiliary.go index 70a0f0702d91..9f2bf4cc3a1c 100755 --- a/spanner/admin/database/apiv1/auxiliary.go +++ b/spanner/admin/database/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/spanner/admin/database/apiv1/auxiliary_go123.go b/spanner/admin/database/apiv1/auxiliary_go123.go index 10ba3c49c510..b6c2f328dea4 100755 --- a/spanner/admin/database/apiv1/auxiliary_go123.go +++ b/spanner/admin/database/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/spanner/admin/database/apiv1/database_admin_client.go b/spanner/admin/database/apiv1/database_admin_client.go index 70c38d6b4f3d..21e75e7bc66a 100755 --- a/spanner/admin/database/apiv1/database_admin_client.go +++ b/spanner/admin/database/apiv1/database_admin_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/spanner/admin/database/apiv1/database_admin_client_example_go123_test.go b/spanner/admin/database/apiv1/database_admin_client_example_go123_test.go index ae5f531c6f00..ccc05d3232b1 100644 --- a/spanner/admin/database/apiv1/database_admin_client_example_go123_test.go +++ b/spanner/admin/database/apiv1/database_admin_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/spanner/admin/database/apiv1/database_admin_client_example_test.go b/spanner/admin/database/apiv1/database_admin_client_example_test.go index c6ec49595a3b..10782fe9714b 100644 --- a/spanner/admin/database/apiv1/database_admin_client_example_test.go +++ b/spanner/admin/database/apiv1/database_admin_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/spanner/admin/database/apiv1/doc.go b/spanner/admin/database/apiv1/doc.go index 959a6e43ef07..70f108bde1ab 100755 --- a/spanner/admin/database/apiv1/doc.go +++ b/spanner/admin/database/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/spanner/admin/database/apiv1/helpers.go b/spanner/admin/database/apiv1/helpers.go index 0c537dcfbfee..bfdc70d8cb0d 100755 --- a/spanner/admin/database/apiv1/helpers.go +++ b/spanner/admin/database/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/spanner/admin/instance/apiv1/auxiliary.go b/spanner/admin/instance/apiv1/auxiliary.go index d156075e428b..c90ed9096675 100755 --- a/spanner/admin/instance/apiv1/auxiliary.go +++ b/spanner/admin/instance/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/spanner/admin/instance/apiv1/auxiliary_go123.go b/spanner/admin/instance/apiv1/auxiliary_go123.go index 94569aaf1990..977ca841477e 100755 --- a/spanner/admin/instance/apiv1/auxiliary_go123.go +++ b/spanner/admin/instance/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/spanner/admin/instance/apiv1/doc.go b/spanner/admin/instance/apiv1/doc.go index bc7a43e817f3..eee60f468ab5 100755 --- a/spanner/admin/instance/apiv1/doc.go +++ b/spanner/admin/instance/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/spanner/admin/instance/apiv1/helpers.go b/spanner/admin/instance/apiv1/helpers.go index e6456bf4ba5f..86fe39d71087 100755 --- a/spanner/admin/instance/apiv1/helpers.go +++ b/spanner/admin/instance/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/spanner/admin/instance/apiv1/instance_admin_client.go b/spanner/admin/instance/apiv1/instance_admin_client.go index edb38ff9dbbc..aaf8b490517f 100755 --- a/spanner/admin/instance/apiv1/instance_admin_client.go +++ b/spanner/admin/instance/apiv1/instance_admin_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/spanner/admin/instance/apiv1/instance_admin_client_example_go123_test.go b/spanner/admin/instance/apiv1/instance_admin_client_example_go123_test.go index 5944a8cc144d..1816ed5fa464 100644 --- a/spanner/admin/instance/apiv1/instance_admin_client_example_go123_test.go +++ b/spanner/admin/instance/apiv1/instance_admin_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/spanner/admin/instance/apiv1/instance_admin_client_example_test.go b/spanner/admin/instance/apiv1/instance_admin_client_example_test.go index b33634a13c97..ef027d50bd60 100644 --- a/spanner/admin/instance/apiv1/instance_admin_client_example_test.go +++ b/spanner/admin/instance/apiv1/instance_admin_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/spanner/apiv1/auxiliary.go b/spanner/apiv1/auxiliary.go index 189b157175f1..9f20fac7b57d 100755 --- a/spanner/apiv1/auxiliary.go +++ b/spanner/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/spanner/apiv1/auxiliary_go123.go b/spanner/apiv1/auxiliary_go123.go index 5ef7db55695b..759ecdb005b7 100755 --- a/spanner/apiv1/auxiliary_go123.go +++ b/spanner/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/spanner/apiv1/doc.go b/spanner/apiv1/doc.go index b89cb5b4c950..b513cb605381 100755 --- a/spanner/apiv1/doc.go +++ b/spanner/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/spanner/apiv1/helpers.go b/spanner/apiv1/helpers.go index 8bdbaa4058a4..1eb67e1cf5c5 100755 --- a/spanner/apiv1/helpers.go +++ b/spanner/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/spanner/apiv1/spanner_client.go b/spanner/apiv1/spanner_client.go index 56d4a0137d68..3f549002034a 100755 --- a/spanner/apiv1/spanner_client.go +++ b/spanner/apiv1/spanner_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/spanner/apiv1/spanner_client_example_go123_test.go b/spanner/apiv1/spanner_client_example_go123_test.go index fcbe54a57ccf..a236c1903c07 100644 --- a/spanner/apiv1/spanner_client_example_go123_test.go +++ b/spanner/apiv1/spanner_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/spanner/apiv1/spanner_client_example_test.go b/spanner/apiv1/spanner_client_example_test.go index 419b10505ea6..68eeb009ee51 100644 --- a/spanner/apiv1/spanner_client_example_test.go +++ b/spanner/apiv1/spanner_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/spanner/executor/apiv1/auxiliary.go b/spanner/executor/apiv1/auxiliary.go index eeadeec990dd..00cb761913c8 100755 --- a/spanner/executor/apiv1/auxiliary.go +++ b/spanner/executor/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/spanner/executor/apiv1/auxiliary_go123.go b/spanner/executor/apiv1/auxiliary_go123.go index dc9e0ab096e6..2690cf06cd2a 100755 --- a/spanner/executor/apiv1/auxiliary_go123.go +++ b/spanner/executor/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/spanner/executor/apiv1/doc.go b/spanner/executor/apiv1/doc.go index d1c232d5b607..ced5946fdfa3 100755 --- a/spanner/executor/apiv1/doc.go +++ b/spanner/executor/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/spanner/executor/apiv1/helpers.go b/spanner/executor/apiv1/helpers.go index 8f4387d23285..00c6f29daf98 100755 --- a/spanner/executor/apiv1/helpers.go +++ b/spanner/executor/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/spanner/executor/apiv1/spanner_executor_proxy_client.go b/spanner/executor/apiv1/spanner_executor_proxy_client.go index 5de6bc0294f8..0659b2adc119 100755 --- a/spanner/executor/apiv1/spanner_executor_proxy_client.go +++ b/spanner/executor/apiv1/spanner_executor_proxy_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/spanner/executor/apiv1/spanner_executor_proxy_client_example_go123_test.go b/spanner/executor/apiv1/spanner_executor_proxy_client_example_go123_test.go index 1157050ce115..f4455346ca68 100644 --- a/spanner/executor/apiv1/spanner_executor_proxy_client_example_go123_test.go +++ b/spanner/executor/apiv1/spanner_executor_proxy_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/spanner/executor/apiv1/spanner_executor_proxy_client_example_test.go b/spanner/executor/apiv1/spanner_executor_proxy_client_example_test.go index 39190476136e..27e66316f32a 100644 --- a/spanner/executor/apiv1/spanner_executor_proxy_client_example_test.go +++ b/spanner/executor/apiv1/spanner_executor_proxy_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/speech/apiv1/adaptation_client.go b/speech/apiv1/adaptation_client.go index 928efbc9a7fd..825717001ba5 100755 --- a/speech/apiv1/adaptation_client.go +++ b/speech/apiv1/adaptation_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/speech/apiv1/adaptation_client_example_go123_test.go b/speech/apiv1/adaptation_client_example_go123_test.go index c73ca7c4d51f..e2abc386f1e3 100644 --- a/speech/apiv1/adaptation_client_example_go123_test.go +++ b/speech/apiv1/adaptation_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/speech/apiv1/adaptation_client_example_test.go b/speech/apiv1/adaptation_client_example_test.go index d1908e6c2e18..685dc6f28513 100644 --- a/speech/apiv1/adaptation_client_example_test.go +++ b/speech/apiv1/adaptation_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/speech/apiv1/auxiliary.go b/speech/apiv1/auxiliary.go index d2c18685ff87..3b066ee69694 100755 --- a/speech/apiv1/auxiliary.go +++ b/speech/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/speech/apiv1/auxiliary_go123.go b/speech/apiv1/auxiliary_go123.go index f66003b61a46..23bdcbde5fd3 100755 --- a/speech/apiv1/auxiliary_go123.go +++ b/speech/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/speech/apiv1/doc.go b/speech/apiv1/doc.go index 5d605800c285..1bc9198f8e92 100755 --- a/speech/apiv1/doc.go +++ b/speech/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/speech/apiv1/helpers.go b/speech/apiv1/helpers.go index ab3d4368f0e0..4d8487c5466e 100755 --- a/speech/apiv1/helpers.go +++ b/speech/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/speech/apiv1/speech_client.go b/speech/apiv1/speech_client.go index 5dba07c26c1b..a664a8dbb8fb 100755 --- a/speech/apiv1/speech_client.go +++ b/speech/apiv1/speech_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/speech/apiv1/speech_client_example_go123_test.go b/speech/apiv1/speech_client_example_go123_test.go index 55fa5a7c9bad..4e47293f77a5 100644 --- a/speech/apiv1/speech_client_example_go123_test.go +++ b/speech/apiv1/speech_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/speech/apiv1/speech_client_example_test.go b/speech/apiv1/speech_client_example_test.go index 9e30c718c028..8fbb3a02d1db 100644 --- a/speech/apiv1/speech_client_example_test.go +++ b/speech/apiv1/speech_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/speech/apiv1p1beta1/adaptation_client.go b/speech/apiv1p1beta1/adaptation_client.go index 319a7a07113a..ee3f47715c80 100755 --- a/speech/apiv1p1beta1/adaptation_client.go +++ b/speech/apiv1p1beta1/adaptation_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/speech/apiv1p1beta1/adaptation_client_example_go123_test.go b/speech/apiv1p1beta1/adaptation_client_example_go123_test.go index 2458df1bc879..68b33cd8fefe 100644 --- a/speech/apiv1p1beta1/adaptation_client_example_go123_test.go +++ b/speech/apiv1p1beta1/adaptation_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/speech/apiv1p1beta1/adaptation_client_example_test.go b/speech/apiv1p1beta1/adaptation_client_example_test.go index 6dba1a7d9096..d65e98abe41f 100644 --- a/speech/apiv1p1beta1/adaptation_client_example_test.go +++ b/speech/apiv1p1beta1/adaptation_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/speech/apiv1p1beta1/auxiliary.go b/speech/apiv1p1beta1/auxiliary.go index 6ba5118da475..bd203b63bc3f 100755 --- a/speech/apiv1p1beta1/auxiliary.go +++ b/speech/apiv1p1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/speech/apiv1p1beta1/auxiliary_go123.go b/speech/apiv1p1beta1/auxiliary_go123.go index d1c3b736d343..5db1ed7eeb7d 100755 --- a/speech/apiv1p1beta1/auxiliary_go123.go +++ b/speech/apiv1p1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/speech/apiv1p1beta1/doc.go b/speech/apiv1p1beta1/doc.go index fce44ddc6ab1..b98b9bd36df9 100755 --- a/speech/apiv1p1beta1/doc.go +++ b/speech/apiv1p1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/speech/apiv1p1beta1/helpers.go b/speech/apiv1p1beta1/helpers.go index ab3d4368f0e0..4d8487c5466e 100755 --- a/speech/apiv1p1beta1/helpers.go +++ b/speech/apiv1p1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/speech/apiv1p1beta1/speech_client.go b/speech/apiv1p1beta1/speech_client.go index 6e1d4a902a68..628450e0df80 100755 --- a/speech/apiv1p1beta1/speech_client.go +++ b/speech/apiv1p1beta1/speech_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/speech/apiv1p1beta1/speech_client_example_go123_test.go b/speech/apiv1p1beta1/speech_client_example_go123_test.go index 39ad47e4f245..5cb4e6f3c6f7 100644 --- a/speech/apiv1p1beta1/speech_client_example_go123_test.go +++ b/speech/apiv1p1beta1/speech_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/speech/apiv1p1beta1/speech_client_example_test.go b/speech/apiv1p1beta1/speech_client_example_test.go index e3b1edf7919e..fce973550e7a 100644 --- a/speech/apiv1p1beta1/speech_client_example_test.go +++ b/speech/apiv1p1beta1/speech_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/speech/apiv2/auxiliary.go b/speech/apiv2/auxiliary.go index 030c324d7025..c1e369a862a9 100755 --- a/speech/apiv2/auxiliary.go +++ b/speech/apiv2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/speech/apiv2/auxiliary_go123.go b/speech/apiv2/auxiliary_go123.go index 5d5f3be6781f..c73ac7b67cab 100755 --- a/speech/apiv2/auxiliary_go123.go +++ b/speech/apiv2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/speech/apiv2/doc.go b/speech/apiv2/doc.go index ce1ad1e9b763..6c42a38889a7 100755 --- a/speech/apiv2/doc.go +++ b/speech/apiv2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/speech/apiv2/helpers.go b/speech/apiv2/helpers.go index ab3d4368f0e0..4d8487c5466e 100755 --- a/speech/apiv2/helpers.go +++ b/speech/apiv2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/speech/apiv2/speech_client.go b/speech/apiv2/speech_client.go index 3197c6699dda..9d4ac2f09858 100755 --- a/speech/apiv2/speech_client.go +++ b/speech/apiv2/speech_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/speech/apiv2/speech_client_example_go123_test.go b/speech/apiv2/speech_client_example_go123_test.go index 826a8a25c939..4c502b12f6cd 100644 --- a/speech/apiv2/speech_client_example_go123_test.go +++ b/speech/apiv2/speech_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/speech/apiv2/speech_client_example_test.go b/speech/apiv2/speech_client_example_test.go index 5992e5956997..c2e13294958a 100644 --- a/speech/apiv2/speech_client_example_test.go +++ b/speech/apiv2/speech_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/storage/control/apiv2/auxiliary.go b/storage/control/apiv2/auxiliary.go index 6f7080f33c7f..85101a4599ea 100755 --- a/storage/control/apiv2/auxiliary.go +++ b/storage/control/apiv2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/storage/control/apiv2/auxiliary_go123.go b/storage/control/apiv2/auxiliary_go123.go index fb0c391b4008..ba5e6b19129b 100755 --- a/storage/control/apiv2/auxiliary_go123.go +++ b/storage/control/apiv2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/storage/control/apiv2/doc.go b/storage/control/apiv2/doc.go index 61ac70567c66..50b4a7bea2ca 100755 --- a/storage/control/apiv2/doc.go +++ b/storage/control/apiv2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/storage/control/apiv2/helpers.go b/storage/control/apiv2/helpers.go index d3736512ecde..d1c9bdddc978 100755 --- a/storage/control/apiv2/helpers.go +++ b/storage/control/apiv2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/storage/control/apiv2/storage_control_client.go b/storage/control/apiv2/storage_control_client.go index 582e42d166b8..77c8998925a8 100755 --- a/storage/control/apiv2/storage_control_client.go +++ b/storage/control/apiv2/storage_control_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/storage/control/apiv2/storage_control_client_example_go123_test.go b/storage/control/apiv2/storage_control_client_example_go123_test.go index 0132787b5b83..7192c51f4781 100644 --- a/storage/control/apiv2/storage_control_client_example_go123_test.go +++ b/storage/control/apiv2/storage_control_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/storage/control/apiv2/storage_control_client_example_test.go b/storage/control/apiv2/storage_control_client_example_test.go index 685e7b14e330..1539354439f7 100644 --- a/storage/control/apiv2/storage_control_client_example_test.go +++ b/storage/control/apiv2/storage_control_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/storage/internal/apiv2/auxiliary.go b/storage/internal/apiv2/auxiliary.go index f6af3452d312..03c3f8c170d2 100755 --- a/storage/internal/apiv2/auxiliary.go +++ b/storage/internal/apiv2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/storage/internal/apiv2/auxiliary_go123.go b/storage/internal/apiv2/auxiliary_go123.go index e6cb160d0319..a51532f60f2c 100755 --- a/storage/internal/apiv2/auxiliary_go123.go +++ b/storage/internal/apiv2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/storage/internal/apiv2/doc.go b/storage/internal/apiv2/doc.go index 4640d5bdfd2a..c1a186b76db1 100755 --- a/storage/internal/apiv2/doc.go +++ b/storage/internal/apiv2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/storage/internal/apiv2/helpers.go b/storage/internal/apiv2/helpers.go index 601d5fa2a646..0de9b31f6418 100755 --- a/storage/internal/apiv2/helpers.go +++ b/storage/internal/apiv2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/storage/internal/apiv2/storage_client.go b/storage/internal/apiv2/storage_client.go index 55c940be39e0..fbaa5d392229 100755 --- a/storage/internal/apiv2/storage_client.go +++ b/storage/internal/apiv2/storage_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/storage/internal/apiv2/storage_client_example_go123_test.go b/storage/internal/apiv2/storage_client_example_go123_test.go index a5ce2c0bee21..93ed40eff0ef 100644 --- a/storage/internal/apiv2/storage_client_example_go123_test.go +++ b/storage/internal/apiv2/storage_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/storage/internal/apiv2/storage_client_example_test.go b/storage/internal/apiv2/storage_client_example_test.go index dd688dd699eb..a9c2b10b9508 100644 --- a/storage/internal/apiv2/storage_client_example_test.go +++ b/storage/internal/apiv2/storage_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/storageinsights/apiv1/auxiliary.go b/storageinsights/apiv1/auxiliary.go index d7f3c844c05d..8c494dfc3f31 100755 --- a/storageinsights/apiv1/auxiliary.go +++ b/storageinsights/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/storageinsights/apiv1/auxiliary_go123.go b/storageinsights/apiv1/auxiliary_go123.go index b22d4c8689b7..ccb250482582 100755 --- a/storageinsights/apiv1/auxiliary_go123.go +++ b/storageinsights/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/storageinsights/apiv1/doc.go b/storageinsights/apiv1/doc.go index be61a1cd859a..6a1f99df0a81 100755 --- a/storageinsights/apiv1/doc.go +++ b/storageinsights/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/storageinsights/apiv1/helpers.go b/storageinsights/apiv1/helpers.go index 3193eaa8151e..63bd51ca3503 100755 --- a/storageinsights/apiv1/helpers.go +++ b/storageinsights/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/storageinsights/apiv1/storage_insights_client.go b/storageinsights/apiv1/storage_insights_client.go index 64c07af58190..2ab4941e0997 100755 --- a/storageinsights/apiv1/storage_insights_client.go +++ b/storageinsights/apiv1/storage_insights_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/storageinsights/apiv1/storage_insights_client_example_go123_test.go b/storageinsights/apiv1/storage_insights_client_example_go123_test.go index df837d330319..aa3d602ce3a4 100644 --- a/storageinsights/apiv1/storage_insights_client_example_go123_test.go +++ b/storageinsights/apiv1/storage_insights_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/storageinsights/apiv1/storage_insights_client_example_test.go b/storageinsights/apiv1/storage_insights_client_example_test.go index 1df5a3016dbb..a4450217c0e2 100644 --- a/storageinsights/apiv1/storage_insights_client_example_test.go +++ b/storageinsights/apiv1/storage_insights_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/storagetransfer/apiv1/auxiliary.go b/storagetransfer/apiv1/auxiliary.go index 9087ff4064d5..26be7c1e98df 100755 --- a/storagetransfer/apiv1/auxiliary.go +++ b/storagetransfer/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/storagetransfer/apiv1/auxiliary_go123.go b/storagetransfer/apiv1/auxiliary_go123.go index 15fc493e2538..38cc12eb78cb 100755 --- a/storagetransfer/apiv1/auxiliary_go123.go +++ b/storagetransfer/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/storagetransfer/apiv1/doc.go b/storagetransfer/apiv1/doc.go index e0b21f0f5543..55ae3cd49163 100755 --- a/storagetransfer/apiv1/doc.go +++ b/storagetransfer/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/storagetransfer/apiv1/helpers.go b/storagetransfer/apiv1/helpers.go index 668d41f0ffe4..140278d48266 100755 --- a/storagetransfer/apiv1/helpers.go +++ b/storagetransfer/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/storagetransfer/apiv1/storage_transfer_client.go b/storagetransfer/apiv1/storage_transfer_client.go index bd215a2fd10e..3823599e9863 100755 --- a/storagetransfer/apiv1/storage_transfer_client.go +++ b/storagetransfer/apiv1/storage_transfer_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/storagetransfer/apiv1/storage_transfer_client_example_go123_test.go b/storagetransfer/apiv1/storage_transfer_client_example_go123_test.go index 18ed10e7c683..bd079a2f5142 100644 --- a/storagetransfer/apiv1/storage_transfer_client_example_go123_test.go +++ b/storagetransfer/apiv1/storage_transfer_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/storagetransfer/apiv1/storage_transfer_client_example_test.go b/storagetransfer/apiv1/storage_transfer_client_example_test.go index 2c33fe7fef7a..a9b75d3b5a0b 100644 --- a/storagetransfer/apiv1/storage_transfer_client_example_test.go +++ b/storagetransfer/apiv1/storage_transfer_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/streetview/publish/apiv1/auxiliary.go b/streetview/publish/apiv1/auxiliary.go index 75fb24f67459..f274271ed276 100755 --- a/streetview/publish/apiv1/auxiliary.go +++ b/streetview/publish/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/streetview/publish/apiv1/auxiliary_go123.go b/streetview/publish/apiv1/auxiliary_go123.go index 3094efba7004..8f6252506b3f 100755 --- a/streetview/publish/apiv1/auxiliary_go123.go +++ b/streetview/publish/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/streetview/publish/apiv1/doc.go b/streetview/publish/apiv1/doc.go index 12c98d4c9981..c7823ae95582 100755 --- a/streetview/publish/apiv1/doc.go +++ b/streetview/publish/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/streetview/publish/apiv1/helpers.go b/streetview/publish/apiv1/helpers.go index 4d02f53cef9c..45b7e6b68bcf 100755 --- a/streetview/publish/apiv1/helpers.go +++ b/streetview/publish/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/streetview/publish/apiv1/street_view_publish_client.go b/streetview/publish/apiv1/street_view_publish_client.go index 604eda55de4f..7af73bda7b41 100755 --- a/streetview/publish/apiv1/street_view_publish_client.go +++ b/streetview/publish/apiv1/street_view_publish_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/streetview/publish/apiv1/street_view_publish_client_example_go123_test.go b/streetview/publish/apiv1/street_view_publish_client_example_go123_test.go index 90a12c91ad79..111d4a9ba149 100644 --- a/streetview/publish/apiv1/street_view_publish_client_example_go123_test.go +++ b/streetview/publish/apiv1/street_view_publish_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/streetview/publish/apiv1/street_view_publish_client_example_test.go b/streetview/publish/apiv1/street_view_publish_client_example_test.go index 58231083df9a..97dc3e9c5c29 100644 --- a/streetview/publish/apiv1/street_view_publish_client_example_test.go +++ b/streetview/publish/apiv1/street_view_publish_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/support/apiv2/auxiliary.go b/support/apiv2/auxiliary.go index ee7794d3aa57..ae487eebf9c8 100755 --- a/support/apiv2/auxiliary.go +++ b/support/apiv2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/support/apiv2/auxiliary_go123.go b/support/apiv2/auxiliary_go123.go index 10014e1be3e8..1c0d9367d601 100755 --- a/support/apiv2/auxiliary_go123.go +++ b/support/apiv2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/support/apiv2/case_attachment_client.go b/support/apiv2/case_attachment_client.go index 27531d7d1323..563dde72a73a 100755 --- a/support/apiv2/case_attachment_client.go +++ b/support/apiv2/case_attachment_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/support/apiv2/case_attachment_client_example_go123_test.go b/support/apiv2/case_attachment_client_example_go123_test.go index 81114ab9875d..07267c4b876c 100644 --- a/support/apiv2/case_attachment_client_example_go123_test.go +++ b/support/apiv2/case_attachment_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/support/apiv2/case_attachment_client_example_test.go b/support/apiv2/case_attachment_client_example_test.go index af44be8e88f0..22c8e36c5bd7 100644 --- a/support/apiv2/case_attachment_client_example_test.go +++ b/support/apiv2/case_attachment_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/support/apiv2/case_client.go b/support/apiv2/case_client.go index c42d4fe382de..22a45ae7c660 100755 --- a/support/apiv2/case_client.go +++ b/support/apiv2/case_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/support/apiv2/case_client_example_go123_test.go b/support/apiv2/case_client_example_go123_test.go index 81a9af77dbe8..8f25ca347589 100644 --- a/support/apiv2/case_client_example_go123_test.go +++ b/support/apiv2/case_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/support/apiv2/case_client_example_test.go b/support/apiv2/case_client_example_test.go index 2fe4d5332134..02574629a3b0 100644 --- a/support/apiv2/case_client_example_test.go +++ b/support/apiv2/case_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/support/apiv2/comment_client.go b/support/apiv2/comment_client.go index dd9e41e84780..3d843db38d29 100755 --- a/support/apiv2/comment_client.go +++ b/support/apiv2/comment_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/support/apiv2/comment_client_example_go123_test.go b/support/apiv2/comment_client_example_go123_test.go index d12a0014a3e4..a78938cc8936 100644 --- a/support/apiv2/comment_client_example_go123_test.go +++ b/support/apiv2/comment_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/support/apiv2/comment_client_example_test.go b/support/apiv2/comment_client_example_test.go index b10336542c58..d260d0fcd628 100644 --- a/support/apiv2/comment_client_example_test.go +++ b/support/apiv2/comment_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/support/apiv2/doc.go b/support/apiv2/doc.go index e27b8f580ea8..a07f05ac0a06 100755 --- a/support/apiv2/doc.go +++ b/support/apiv2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/support/apiv2/helpers.go b/support/apiv2/helpers.go index 535610391ace..30e30ae371a2 100755 --- a/support/apiv2/helpers.go +++ b/support/apiv2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4/auxiliary.go b/talent/apiv4/auxiliary.go index b58cf431e0c7..74b8edd48209 100755 --- a/talent/apiv4/auxiliary.go +++ b/talent/apiv4/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4/auxiliary_go123.go b/talent/apiv4/auxiliary_go123.go index ffd2743fd245..f669760a961a 100755 --- a/talent/apiv4/auxiliary_go123.go +++ b/talent/apiv4/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4/company_client.go b/talent/apiv4/company_client.go index b3c67951ffba..1a4a849031a4 100755 --- a/talent/apiv4/company_client.go +++ b/talent/apiv4/company_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4/company_client_example_go123_test.go b/talent/apiv4/company_client_example_go123_test.go index e9b0e44601c0..5f7bea9ffd3b 100644 --- a/talent/apiv4/company_client_example_go123_test.go +++ b/talent/apiv4/company_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4/company_client_example_test.go b/talent/apiv4/company_client_example_test.go index e74666ceea79..c6018d2bcf09 100644 --- a/talent/apiv4/company_client_example_test.go +++ b/talent/apiv4/company_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4/completion_client.go b/talent/apiv4/completion_client.go index 94ca772328fd..f53d72ba5736 100755 --- a/talent/apiv4/completion_client.go +++ b/talent/apiv4/completion_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4/completion_client_example_go123_test.go b/talent/apiv4/completion_client_example_go123_test.go index 7807f95d0b8f..44f8819662c2 100644 --- a/talent/apiv4/completion_client_example_go123_test.go +++ b/talent/apiv4/completion_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4/completion_client_example_test.go b/talent/apiv4/completion_client_example_test.go index b0552914d403..8ee3cb4179d3 100644 --- a/talent/apiv4/completion_client_example_test.go +++ b/talent/apiv4/completion_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4/doc.go b/talent/apiv4/doc.go index d02ed2f3419f..2a7ef98360a3 100755 --- a/talent/apiv4/doc.go +++ b/talent/apiv4/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4/event_client.go b/talent/apiv4/event_client.go index 999b061a33d2..c9dbde9587d6 100755 --- a/talent/apiv4/event_client.go +++ b/talent/apiv4/event_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4/event_client_example_go123_test.go b/talent/apiv4/event_client_example_go123_test.go index 7807f95d0b8f..44f8819662c2 100644 --- a/talent/apiv4/event_client_example_go123_test.go +++ b/talent/apiv4/event_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4/event_client_example_test.go b/talent/apiv4/event_client_example_test.go index f643438dd2ed..c2e30ae7a6a8 100644 --- a/talent/apiv4/event_client_example_test.go +++ b/talent/apiv4/event_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4/helpers.go b/talent/apiv4/helpers.go index 8d1e4398c348..72c1defed736 100755 --- a/talent/apiv4/helpers.go +++ b/talent/apiv4/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4/job_client.go b/talent/apiv4/job_client.go index 91e9fbab5304..d7e8b197868f 100755 --- a/talent/apiv4/job_client.go +++ b/talent/apiv4/job_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4/job_client_example_go123_test.go b/talent/apiv4/job_client_example_go123_test.go index 72e0e81fae15..969f0831e4a7 100644 --- a/talent/apiv4/job_client_example_go123_test.go +++ b/talent/apiv4/job_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4/job_client_example_test.go b/talent/apiv4/job_client_example_test.go index 72a70c58b10d..a53c46984954 100644 --- a/talent/apiv4/job_client_example_test.go +++ b/talent/apiv4/job_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4/tenant_client.go b/talent/apiv4/tenant_client.go index fdb64a454139..f1190843316d 100755 --- a/talent/apiv4/tenant_client.go +++ b/talent/apiv4/tenant_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4/tenant_client_example_go123_test.go b/talent/apiv4/tenant_client_example_go123_test.go index 5efe59e90cd8..5d94c65b3124 100644 --- a/talent/apiv4/tenant_client_example_go123_test.go +++ b/talent/apiv4/tenant_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4/tenant_client_example_test.go b/talent/apiv4/tenant_client_example_test.go index c904078c8d5b..c635aedb89cf 100644 --- a/talent/apiv4/tenant_client_example_test.go +++ b/talent/apiv4/tenant_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4beta1/auxiliary.go b/talent/apiv4beta1/auxiliary.go index 1d5d872d122b..b97ff97b9d00 100755 --- a/talent/apiv4beta1/auxiliary.go +++ b/talent/apiv4beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4beta1/auxiliary_go123.go b/talent/apiv4beta1/auxiliary_go123.go index edc61e868949..ae8f5c8e5083 100755 --- a/talent/apiv4beta1/auxiliary_go123.go +++ b/talent/apiv4beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4beta1/company_client.go b/talent/apiv4beta1/company_client.go index aedad14f19d2..6cf68c3ee407 100755 --- a/talent/apiv4beta1/company_client.go +++ b/talent/apiv4beta1/company_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4beta1/company_client_example_go123_test.go b/talent/apiv4beta1/company_client_example_go123_test.go index c2b2370ec9e3..0c4f66b70479 100644 --- a/talent/apiv4beta1/company_client_example_go123_test.go +++ b/talent/apiv4beta1/company_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4beta1/company_client_example_test.go b/talent/apiv4beta1/company_client_example_test.go index 02ce2883467b..c90b6335c86f 100644 --- a/talent/apiv4beta1/company_client_example_test.go +++ b/talent/apiv4beta1/company_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4beta1/completion_client.go b/talent/apiv4beta1/completion_client.go index cc3148466635..75d9f52a7d6b 100755 --- a/talent/apiv4beta1/completion_client.go +++ b/talent/apiv4beta1/completion_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4beta1/completion_client_example_go123_test.go b/talent/apiv4beta1/completion_client_example_go123_test.go index 7807f95d0b8f..44f8819662c2 100644 --- a/talent/apiv4beta1/completion_client_example_go123_test.go +++ b/talent/apiv4beta1/completion_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4beta1/completion_client_example_test.go b/talent/apiv4beta1/completion_client_example_test.go index 55ba67a64330..60c66ea023bb 100644 --- a/talent/apiv4beta1/completion_client_example_test.go +++ b/talent/apiv4beta1/completion_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4beta1/doc.go b/talent/apiv4beta1/doc.go index 9cbde5b83ed1..5ed20dbd330f 100755 --- a/talent/apiv4beta1/doc.go +++ b/talent/apiv4beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4beta1/event_client.go b/talent/apiv4beta1/event_client.go index 4e986d104978..057f6edcfb65 100755 --- a/talent/apiv4beta1/event_client.go +++ b/talent/apiv4beta1/event_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4beta1/event_client_example_go123_test.go b/talent/apiv4beta1/event_client_example_go123_test.go index 7807f95d0b8f..44f8819662c2 100644 --- a/talent/apiv4beta1/event_client_example_go123_test.go +++ b/talent/apiv4beta1/event_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4beta1/event_client_example_test.go b/talent/apiv4beta1/event_client_example_test.go index 24b8da15ce2c..a30f7cd463bc 100644 --- a/talent/apiv4beta1/event_client_example_test.go +++ b/talent/apiv4beta1/event_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4beta1/helpers.go b/talent/apiv4beta1/helpers.go index 8d1e4398c348..72c1defed736 100755 --- a/talent/apiv4beta1/helpers.go +++ b/talent/apiv4beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4beta1/job_client.go b/talent/apiv4beta1/job_client.go index bf825bd1366b..85ea21ac9312 100755 --- a/talent/apiv4beta1/job_client.go +++ b/talent/apiv4beta1/job_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4beta1/job_client_example_go123_test.go b/talent/apiv4beta1/job_client_example_go123_test.go index 9b0fd60de187..fe19827d390a 100644 --- a/talent/apiv4beta1/job_client_example_go123_test.go +++ b/talent/apiv4beta1/job_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4beta1/job_client_example_test.go b/talent/apiv4beta1/job_client_example_test.go index 9df1388e587c..838f5283f2d0 100644 --- a/talent/apiv4beta1/job_client_example_test.go +++ b/talent/apiv4beta1/job_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4beta1/talentpb/job_service.pb.go b/talent/apiv4beta1/talentpb/job_service.pb.go index 64a43bb39437..5ebe7b52ab93 100755 --- a/talent/apiv4beta1/talentpb/job_service.pb.go +++ b/talent/apiv4beta1/talentpb/job_service.pb.go @@ -335,6 +335,70 @@ func (SearchJobsRequest_KeywordMatchMode) EnumDescriptor() ([]byte, []int) { return file_google_cloud_talent_v4beta1_job_service_proto_rawDescGZIP(), []int{7, 2} } +// The relevance threshold of the search results. The higher relevance +// threshold is, the higher relevant results are shown and the less number of +// results are returned. +type SearchJobsRequest_RelevanceThreshold int32 + +const ( + // Default value. In this case, server behavior defaults to Google defined + // threshold. + SearchJobsRequest_RELEVANCE_THRESHOLD_UNSPECIFIED SearchJobsRequest_RelevanceThreshold = 0 + // Lowest relevance threshold. + SearchJobsRequest_LOWEST SearchJobsRequest_RelevanceThreshold = 1 + // Low relevance threshold. + SearchJobsRequest_LOW SearchJobsRequest_RelevanceThreshold = 2 + // Medium relevance threshold. + SearchJobsRequest_MEDIUM SearchJobsRequest_RelevanceThreshold = 3 + // High relevance threshold. + SearchJobsRequest_HIGH SearchJobsRequest_RelevanceThreshold = 4 +) + +// Enum value maps for SearchJobsRequest_RelevanceThreshold. +var ( + SearchJobsRequest_RelevanceThreshold_name = map[int32]string{ + 0: "RELEVANCE_THRESHOLD_UNSPECIFIED", + 1: "LOWEST", + 2: "LOW", + 3: "MEDIUM", + 4: "HIGH", + } + SearchJobsRequest_RelevanceThreshold_value = map[string]int32{ + "RELEVANCE_THRESHOLD_UNSPECIFIED": 0, + "LOWEST": 1, + "LOW": 2, + "MEDIUM": 3, + "HIGH": 4, + } +) + +func (x SearchJobsRequest_RelevanceThreshold) Enum() *SearchJobsRequest_RelevanceThreshold { + p := new(SearchJobsRequest_RelevanceThreshold) + *p = x + return p +} + +func (x SearchJobsRequest_RelevanceThreshold) String() string { + return protoimpl.X.EnumStringOf(x.Descriptor(), protoreflect.EnumNumber(x)) +} + +func (SearchJobsRequest_RelevanceThreshold) Descriptor() protoreflect.EnumDescriptor { + return file_google_cloud_talent_v4beta1_job_service_proto_enumTypes[4].Descriptor() +} + +func (SearchJobsRequest_RelevanceThreshold) Type() protoreflect.EnumType { + return &file_google_cloud_talent_v4beta1_job_service_proto_enumTypes[4] +} + +func (x SearchJobsRequest_RelevanceThreshold) Number() protoreflect.EnumNumber { + return protoreflect.EnumNumber(x) +} + +// Deprecated: Use SearchJobsRequest_RelevanceThreshold.Descriptor instead. +func (SearchJobsRequest_RelevanceThreshold) EnumDescriptor() ([]byte, []int) { + return file_google_cloud_talent_v4beta1_job_service_proto_rawDescGZIP(), []int{7, 3} +} + // The importance level for // [CustomRankingInfo.ranking_expression][google.cloud.talent.v4beta1.SearchJobsRequest.CustomRankingInfo.ranking_expression]. type SearchJobsRequest_CustomRankingInfo_ImportanceLevel int32 @@ -401,11 +465,11 @@ func (x SearchJobsRequest_CustomRankingInfo_ImportanceLevel) String() string { } func (SearchJobsRequest_CustomRankingInfo_ImportanceLevel) Descriptor() protoreflect.EnumDescriptor { - return file_google_cloud_talent_v4beta1_job_service_proto_enumTypes[4].Descriptor() + return file_google_cloud_talent_v4beta1_job_service_proto_enumTypes[5].Descriptor() } func (SearchJobsRequest_CustomRankingInfo_ImportanceLevel) Type() protoreflect.EnumType { - return &file_google_cloud_talent_v4beta1_job_service_proto_enumTypes[4] + return &file_google_cloud_talent_v4beta1_job_service_proto_enumTypes[5] } func (x SearchJobsRequest_CustomRankingInfo_ImportanceLevel) Number() protoreflect.EnumNumber { @@ -1220,6 +1284,12 @@ type SearchJobsRequest struct { // [KeywordMatchMode.KEYWORD_MATCH_ALL][google.cloud.talent.v4beta1.SearchJobsRequest.KeywordMatchMode.KEYWORD_MATCH_ALL] // if no value is specified. KeywordMatchMode SearchJobsRequest_KeywordMatchMode `protobuf:"varint,18,opt,name=keyword_match_mode,json=keywordMatchMode,proto3,enum=google.cloud.talent.v4beta1.SearchJobsRequest_KeywordMatchMode" json:"keyword_match_mode,omitempty"` + // Optional. The relevance threshold of the search results. + // + // Default to Google defined threshold, leveraging a balance of + // precision and recall to deliver both highly accurate results and + // comprehensive coverage of relevant information. + RelevanceThreshold SearchJobsRequest_RelevanceThreshold `protobuf:"varint,19,opt,name=relevance_threshold,json=relevanceThreshold,proto3,enum=google.cloud.talent.v4beta1.SearchJobsRequest_RelevanceThreshold" json:"relevance_threshold,omitempty"` } func (x *SearchJobsRequest) Reset() { @@ -1365,6 +1435,13 @@ func (x *SearchJobsRequest) GetKeywordMatchMode() SearchJobsRequest_KeywordMatch return SearchJobsRequest_KEYWORD_MATCH_MODE_UNSPECIFIED } +func (x *SearchJobsRequest) GetRelevanceThreshold() SearchJobsRequest_RelevanceThreshold { + if x != nil { + return x.RelevanceThreshold + } + return SearchJobsRequest_RELEVANCE_THRESHOLD_UNSPECIFIED +} + // Response for SearchJob method. type SearchJobsResponse struct { state protoimpl.MessageState @@ -2100,7 +2177,7 @@ var file_google_cloud_talent_v4beta1_job_service_proto_rawDesc = []byte{ 0x28, 0x0b, 0x32, 0x2d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, - 0x61, 0x52, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x22, 0xcc, 0x0d, 0x0a, 0x11, + 0x61, 0x52, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x22, 0xab, 0x0f, 0x0a, 0x11, 0x53, 0x65, 0x61, 0x72, 0x63, 0x68, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x37, 0x0a, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x1f, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x19, 0x12, 0x17, 0x6a, 0x6f, 0x62, 0x73, 0x2e, @@ -2170,125 +2247,130 @@ var file_google_cloud_talent_v4beta1_job_service_proto_rawDesc = []byte{ 0x72, 0x63, 0x68, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x2e, 0x4b, 0x65, 0x79, 0x77, 0x6f, 0x72, 0x64, 0x4d, 0x61, 0x74, 0x63, 0x68, 0x4d, 0x6f, 0x64, 0x65, 0x52, 0x10, 0x6b, 0x65, 0x79, 0x77, 0x6f, 0x72, 0x64, 0x4d, 0x61, 0x74, 0x63, 0x68, 0x4d, 0x6f, 0x64, - 0x65, 0x1a, 0xbf, 0x02, 0x0a, 0x11, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x52, 0x61, 0x6e, 0x6b, - 0x69, 0x6e, 0x67, 0x49, 0x6e, 0x66, 0x6f, 0x12, 0x80, 0x01, 0x0a, 0x10, 0x69, 0x6d, 0x70, 0x6f, - 0x72, 0x74, 0x61, 0x6e, 0x63, 0x65, 0x5f, 0x6c, 0x65, 0x76, 0x65, 0x6c, 0x18, 0x01, 0x20, 0x01, - 0x28, 0x0e, 0x32, 0x50, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, - 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, - 0x2e, 0x53, 0x65, 0x61, 0x72, 0x63, 0x68, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, - 0x73, 0x74, 0x2e, 0x43, 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x52, 0x61, 0x6e, 0x6b, 0x69, 0x6e, 0x67, - 0x49, 0x6e, 0x66, 0x6f, 0x2e, 0x49, 0x6d, 0x70, 0x6f, 0x72, 0x74, 0x61, 0x6e, 0x63, 0x65, 0x4c, - 0x65, 0x76, 0x65, 0x6c, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x0f, 0x69, 0x6d, 0x70, 0x6f, 0x72, - 0x74, 0x61, 0x6e, 0x63, 0x65, 0x4c, 0x65, 0x76, 0x65, 0x6c, 0x12, 0x32, 0x0a, 0x12, 0x72, 0x61, - 0x6e, 0x6b, 0x69, 0x6e, 0x67, 0x5f, 0x65, 0x78, 0x70, 0x72, 0x65, 0x73, 0x73, 0x69, 0x6f, 0x6e, - 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x11, 0x72, 0x61, 0x6e, - 0x6b, 0x69, 0x6e, 0x67, 0x45, 0x78, 0x70, 0x72, 0x65, 0x73, 0x73, 0x69, 0x6f, 0x6e, 0x22, 0x73, - 0x0a, 0x0f, 0x49, 0x6d, 0x70, 0x6f, 0x72, 0x74, 0x61, 0x6e, 0x63, 0x65, 0x4c, 0x65, 0x76, 0x65, - 0x6c, 0x12, 0x20, 0x0a, 0x1c, 0x49, 0x4d, 0x50, 0x4f, 0x52, 0x54, 0x41, 0x4e, 0x43, 0x45, 0x5f, - 0x4c, 0x45, 0x56, 0x45, 0x4c, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, - 0x44, 0x10, 0x00, 0x12, 0x08, 0x0a, 0x04, 0x4e, 0x4f, 0x4e, 0x45, 0x10, 0x01, 0x12, 0x07, 0x0a, - 0x03, 0x4c, 0x4f, 0x57, 0x10, 0x02, 0x12, 0x08, 0x0a, 0x04, 0x4d, 0x49, 0x4c, 0x44, 0x10, 0x03, - 0x12, 0x0a, 0x0a, 0x06, 0x4d, 0x45, 0x44, 0x49, 0x55, 0x4d, 0x10, 0x04, 0x12, 0x08, 0x0a, 0x04, - 0x48, 0x49, 0x47, 0x48, 0x10, 0x05, 0x12, 0x0b, 0x0a, 0x07, 0x45, 0x58, 0x54, 0x52, 0x45, 0x4d, - 0x45, 0x10, 0x06, 0x22, 0x52, 0x0a, 0x0a, 0x53, 0x65, 0x61, 0x72, 0x63, 0x68, 0x4d, 0x6f, 0x64, - 0x65, 0x12, 0x1b, 0x0a, 0x17, 0x53, 0x45, 0x41, 0x52, 0x43, 0x48, 0x5f, 0x4d, 0x4f, 0x44, 0x45, - 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x0e, - 0x0a, 0x0a, 0x4a, 0x4f, 0x42, 0x5f, 0x53, 0x45, 0x41, 0x52, 0x43, 0x48, 0x10, 0x01, 0x12, 0x17, - 0x0a, 0x13, 0x46, 0x45, 0x41, 0x54, 0x55, 0x52, 0x45, 0x44, 0x5f, 0x4a, 0x4f, 0x42, 0x5f, 0x53, - 0x45, 0x41, 0x52, 0x43, 0x48, 0x10, 0x02, 0x22, 0x57, 0x0a, 0x14, 0x44, 0x69, 0x76, 0x65, 0x72, - 0x73, 0x69, 0x66, 0x69, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4c, 0x65, 0x76, 0x65, 0x6c, 0x12, - 0x25, 0x0a, 0x21, 0x44, 0x49, 0x56, 0x45, 0x52, 0x53, 0x49, 0x46, 0x49, 0x43, 0x41, 0x54, 0x49, - 0x4f, 0x4e, 0x5f, 0x4c, 0x45, 0x56, 0x45, 0x4c, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, - 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x0c, 0x0a, 0x08, 0x44, 0x49, 0x53, 0x41, 0x42, 0x4c, - 0x45, 0x44, 0x10, 0x01, 0x12, 0x0a, 0x0a, 0x06, 0x53, 0x49, 0x4d, 0x50, 0x4c, 0x45, 0x10, 0x02, - 0x22, 0x87, 0x01, 0x0a, 0x10, 0x4b, 0x65, 0x79, 0x77, 0x6f, 0x72, 0x64, 0x4d, 0x61, 0x74, 0x63, - 0x68, 0x4d, 0x6f, 0x64, 0x65, 0x12, 0x22, 0x0a, 0x1e, 0x4b, 0x45, 0x59, 0x57, 0x4f, 0x52, 0x44, - 0x5f, 0x4d, 0x41, 0x54, 0x43, 0x48, 0x5f, 0x4d, 0x4f, 0x44, 0x45, 0x5f, 0x55, 0x4e, 0x53, 0x50, - 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x1a, 0x0a, 0x16, 0x4b, 0x45, 0x59, - 0x57, 0x4f, 0x52, 0x44, 0x5f, 0x4d, 0x41, 0x54, 0x43, 0x48, 0x5f, 0x44, 0x49, 0x53, 0x41, 0x42, - 0x4c, 0x45, 0x44, 0x10, 0x01, 0x12, 0x15, 0x0a, 0x11, 0x4b, 0x45, 0x59, 0x57, 0x4f, 0x52, 0x44, - 0x5f, 0x4d, 0x41, 0x54, 0x43, 0x48, 0x5f, 0x41, 0x4c, 0x4c, 0x10, 0x02, 0x12, 0x1c, 0x0a, 0x18, - 0x4b, 0x45, 0x59, 0x57, 0x4f, 0x52, 0x44, 0x5f, 0x4d, 0x41, 0x54, 0x43, 0x48, 0x5f, 0x54, 0x49, - 0x54, 0x4c, 0x45, 0x5f, 0x4f, 0x4e, 0x4c, 0x59, 0x10, 0x03, 0x22, 0xcf, 0x08, 0x0a, 0x12, 0x53, - 0x65, 0x61, 0x72, 0x63, 0x68, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, - 0x65, 0x12, 0x60, 0x0a, 0x0d, 0x6d, 0x61, 0x74, 0x63, 0x68, 0x69, 0x6e, 0x67, 0x5f, 0x6a, 0x6f, - 0x62, 0x73, 0x18, 0x01, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x3b, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, - 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, - 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x53, 0x65, 0x61, 0x72, 0x63, 0x68, 0x4a, 0x6f, 0x62, - 0x73, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x2e, 0x4d, 0x61, 0x74, 0x63, 0x68, 0x69, - 0x6e, 0x67, 0x4a, 0x6f, 0x62, 0x52, 0x0c, 0x6d, 0x61, 0x74, 0x63, 0x68, 0x69, 0x6e, 0x67, 0x4a, - 0x6f, 0x62, 0x73, 0x12, 0x69, 0x0a, 0x17, 0x68, 0x69, 0x73, 0x74, 0x6f, 0x67, 0x72, 0x61, 0x6d, - 0x5f, 0x71, 0x75, 0x65, 0x72, 0x79, 0x5f, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x73, 0x18, 0x02, - 0x20, 0x03, 0x28, 0x0b, 0x32, 0x31, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, - 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, - 0x61, 0x31, 0x2e, 0x48, 0x69, 0x73, 0x74, 0x6f, 0x67, 0x72, 0x61, 0x6d, 0x51, 0x75, 0x65, 0x72, - 0x79, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x52, 0x15, 0x68, 0x69, 0x73, 0x74, 0x6f, 0x67, 0x72, - 0x61, 0x6d, 0x51, 0x75, 0x65, 0x72, 0x79, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x73, 0x12, 0x26, - 0x0a, 0x0f, 0x6e, 0x65, 0x78, 0x74, 0x5f, 0x70, 0x61, 0x67, 0x65, 0x5f, 0x74, 0x6f, 0x6b, 0x65, - 0x6e, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0d, 0x6e, 0x65, 0x78, 0x74, 0x50, 0x61, 0x67, - 0x65, 0x54, 0x6f, 0x6b, 0x65, 0x6e, 0x12, 0x50, 0x0a, 0x10, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, - 0x6f, 0x6e, 0x5f, 0x66, 0x69, 0x6c, 0x74, 0x65, 0x72, 0x73, 0x18, 0x04, 0x20, 0x03, 0x28, 0x0b, - 0x32, 0x25, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, - 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x4c, - 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x0f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, - 0x6e, 0x46, 0x69, 0x6c, 0x74, 0x65, 0x72, 0x73, 0x12, 0x30, 0x0a, 0x14, 0x65, 0x73, 0x74, 0x69, - 0x6d, 0x61, 0x74, 0x65, 0x64, 0x5f, 0x74, 0x6f, 0x74, 0x61, 0x6c, 0x5f, 0x73, 0x69, 0x7a, 0x65, - 0x18, 0x05, 0x20, 0x01, 0x28, 0x05, 0x52, 0x12, 0x65, 0x73, 0x74, 0x69, 0x6d, 0x61, 0x74, 0x65, - 0x64, 0x54, 0x6f, 0x74, 0x61, 0x6c, 0x53, 0x69, 0x7a, 0x65, 0x12, 0x1d, 0x0a, 0x0a, 0x74, 0x6f, - 0x74, 0x61, 0x6c, 0x5f, 0x73, 0x69, 0x7a, 0x65, 0x18, 0x06, 0x20, 0x01, 0x28, 0x05, 0x52, 0x09, - 0x74, 0x6f, 0x74, 0x61, 0x6c, 0x53, 0x69, 0x7a, 0x65, 0x12, 0x49, 0x0a, 0x08, 0x6d, 0x65, 0x74, - 0x61, 0x64, 0x61, 0x74, 0x61, 0x18, 0x07, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x2d, 0x2e, 0x67, 0x6f, - 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, - 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, - 0x73, 0x65, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x52, 0x08, 0x6d, 0x65, 0x74, 0x61, - 0x64, 0x61, 0x74, 0x61, 0x12, 0x3b, 0x0a, 0x1a, 0x62, 0x72, 0x6f, 0x61, 0x64, 0x65, 0x6e, 0x65, - 0x64, 0x5f, 0x71, 0x75, 0x65, 0x72, 0x79, 0x5f, 0x6a, 0x6f, 0x62, 0x73, 0x5f, 0x63, 0x6f, 0x75, - 0x6e, 0x74, 0x18, 0x08, 0x20, 0x01, 0x28, 0x05, 0x52, 0x17, 0x62, 0x72, 0x6f, 0x61, 0x64, 0x65, - 0x6e, 0x65, 0x64, 0x51, 0x75, 0x65, 0x72, 0x79, 0x4a, 0x6f, 0x62, 0x73, 0x43, 0x6f, 0x75, 0x6e, - 0x74, 0x12, 0x5a, 0x0a, 0x10, 0x73, 0x70, 0x65, 0x6c, 0x6c, 0x5f, 0x63, 0x6f, 0x72, 0x72, 0x65, - 0x63, 0x74, 0x69, 0x6f, 0x6e, 0x18, 0x09, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x2f, 0x2e, 0x67, 0x6f, + 0x65, 0x12, 0x77, 0x0a, 0x13, 0x72, 0x65, 0x6c, 0x65, 0x76, 0x61, 0x6e, 0x63, 0x65, 0x5f, 0x74, + 0x68, 0x72, 0x65, 0x73, 0x68, 0x6f, 0x6c, 0x64, 0x18, 0x13, 0x20, 0x01, 0x28, 0x0e, 0x32, 0x41, + 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, + 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x53, 0x65, 0x61, + 0x72, 0x63, 0x68, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x2e, 0x52, + 0x65, 0x6c, 0x65, 0x76, 0x61, 0x6e, 0x63, 0x65, 0x54, 0x68, 0x72, 0x65, 0x73, 0x68, 0x6f, 0x6c, + 0x64, 0x42, 0x03, 0xe0, 0x41, 0x01, 0x52, 0x12, 0x72, 0x65, 0x6c, 0x65, 0x76, 0x61, 0x6e, 0x63, + 0x65, 0x54, 0x68, 0x72, 0x65, 0x73, 0x68, 0x6f, 0x6c, 0x64, 0x1a, 0xbf, 0x02, 0x0a, 0x11, 0x43, + 0x75, 0x73, 0x74, 0x6f, 0x6d, 0x52, 0x61, 0x6e, 0x6b, 0x69, 0x6e, 0x67, 0x49, 0x6e, 0x66, 0x6f, + 0x12, 0x80, 0x01, 0x0a, 0x10, 0x69, 0x6d, 0x70, 0x6f, 0x72, 0x74, 0x61, 0x6e, 0x63, 0x65, 0x5f, + 0x6c, 0x65, 0x76, 0x65, 0x6c, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0e, 0x32, 0x50, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, - 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x53, 0x70, 0x65, 0x6c, 0x6c, 0x69, - 0x6e, 0x67, 0x43, 0x6f, 0x72, 0x72, 0x65, 0x63, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x0f, 0x73, 0x70, - 0x65, 0x6c, 0x6c, 0x43, 0x6f, 0x72, 0x72, 0x65, 0x63, 0x74, 0x69, 0x6f, 0x6e, 0x1a, 0x9e, 0x02, - 0x0a, 0x0b, 0x4d, 0x61, 0x74, 0x63, 0x68, 0x69, 0x6e, 0x67, 0x4a, 0x6f, 0x62, 0x12, 0x32, 0x0a, - 0x03, 0x6a, 0x6f, 0x62, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x20, 0x2e, 0x67, 0x6f, 0x6f, + 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x53, 0x65, 0x61, 0x72, 0x63, 0x68, + 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x2e, 0x43, 0x75, 0x73, 0x74, + 0x6f, 0x6d, 0x52, 0x61, 0x6e, 0x6b, 0x69, 0x6e, 0x67, 0x49, 0x6e, 0x66, 0x6f, 0x2e, 0x49, 0x6d, + 0x70, 0x6f, 0x72, 0x74, 0x61, 0x6e, 0x63, 0x65, 0x4c, 0x65, 0x76, 0x65, 0x6c, 0x42, 0x03, 0xe0, + 0x41, 0x02, 0x52, 0x0f, 0x69, 0x6d, 0x70, 0x6f, 0x72, 0x74, 0x61, 0x6e, 0x63, 0x65, 0x4c, 0x65, + 0x76, 0x65, 0x6c, 0x12, 0x32, 0x0a, 0x12, 0x72, 0x61, 0x6e, 0x6b, 0x69, 0x6e, 0x67, 0x5f, 0x65, + 0x78, 0x70, 0x72, 0x65, 0x73, 0x73, 0x69, 0x6f, 0x6e, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x42, + 0x03, 0xe0, 0x41, 0x02, 0x52, 0x11, 0x72, 0x61, 0x6e, 0x6b, 0x69, 0x6e, 0x67, 0x45, 0x78, 0x70, + 0x72, 0x65, 0x73, 0x73, 0x69, 0x6f, 0x6e, 0x22, 0x73, 0x0a, 0x0f, 0x49, 0x6d, 0x70, 0x6f, 0x72, + 0x74, 0x61, 0x6e, 0x63, 0x65, 0x4c, 0x65, 0x76, 0x65, 0x6c, 0x12, 0x20, 0x0a, 0x1c, 0x49, 0x4d, + 0x50, 0x4f, 0x52, 0x54, 0x41, 0x4e, 0x43, 0x45, 0x5f, 0x4c, 0x45, 0x56, 0x45, 0x4c, 0x5f, 0x55, + 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x08, 0x0a, 0x04, + 0x4e, 0x4f, 0x4e, 0x45, 0x10, 0x01, 0x12, 0x07, 0x0a, 0x03, 0x4c, 0x4f, 0x57, 0x10, 0x02, 0x12, + 0x08, 0x0a, 0x04, 0x4d, 0x49, 0x4c, 0x44, 0x10, 0x03, 0x12, 0x0a, 0x0a, 0x06, 0x4d, 0x45, 0x44, + 0x49, 0x55, 0x4d, 0x10, 0x04, 0x12, 0x08, 0x0a, 0x04, 0x48, 0x49, 0x47, 0x48, 0x10, 0x05, 0x12, + 0x0b, 0x0a, 0x07, 0x45, 0x58, 0x54, 0x52, 0x45, 0x4d, 0x45, 0x10, 0x06, 0x22, 0x52, 0x0a, 0x0a, + 0x53, 0x65, 0x61, 0x72, 0x63, 0x68, 0x4d, 0x6f, 0x64, 0x65, 0x12, 0x1b, 0x0a, 0x17, 0x53, 0x45, + 0x41, 0x52, 0x43, 0x48, 0x5f, 0x4d, 0x4f, 0x44, 0x45, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, + 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x0e, 0x0a, 0x0a, 0x4a, 0x4f, 0x42, 0x5f, 0x53, + 0x45, 0x41, 0x52, 0x43, 0x48, 0x10, 0x01, 0x12, 0x17, 0x0a, 0x13, 0x46, 0x45, 0x41, 0x54, 0x55, + 0x52, 0x45, 0x44, 0x5f, 0x4a, 0x4f, 0x42, 0x5f, 0x53, 0x45, 0x41, 0x52, 0x43, 0x48, 0x10, 0x02, + 0x22, 0x57, 0x0a, 0x14, 0x44, 0x69, 0x76, 0x65, 0x72, 0x73, 0x69, 0x66, 0x69, 0x63, 0x61, 0x74, + 0x69, 0x6f, 0x6e, 0x4c, 0x65, 0x76, 0x65, 0x6c, 0x12, 0x25, 0x0a, 0x21, 0x44, 0x49, 0x56, 0x45, + 0x52, 0x53, 0x49, 0x46, 0x49, 0x43, 0x41, 0x54, 0x49, 0x4f, 0x4e, 0x5f, 0x4c, 0x45, 0x56, 0x45, + 0x4c, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, + 0x0c, 0x0a, 0x08, 0x44, 0x49, 0x53, 0x41, 0x42, 0x4c, 0x45, 0x44, 0x10, 0x01, 0x12, 0x0a, 0x0a, + 0x06, 0x53, 0x49, 0x4d, 0x50, 0x4c, 0x45, 0x10, 0x02, 0x22, 0x87, 0x01, 0x0a, 0x10, 0x4b, 0x65, + 0x79, 0x77, 0x6f, 0x72, 0x64, 0x4d, 0x61, 0x74, 0x63, 0x68, 0x4d, 0x6f, 0x64, 0x65, 0x12, 0x22, + 0x0a, 0x1e, 0x4b, 0x45, 0x59, 0x57, 0x4f, 0x52, 0x44, 0x5f, 0x4d, 0x41, 0x54, 0x43, 0x48, 0x5f, + 0x4d, 0x4f, 0x44, 0x45, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, + 0x10, 0x00, 0x12, 0x1a, 0x0a, 0x16, 0x4b, 0x45, 0x59, 0x57, 0x4f, 0x52, 0x44, 0x5f, 0x4d, 0x41, + 0x54, 0x43, 0x48, 0x5f, 0x44, 0x49, 0x53, 0x41, 0x42, 0x4c, 0x45, 0x44, 0x10, 0x01, 0x12, 0x15, + 0x0a, 0x11, 0x4b, 0x45, 0x59, 0x57, 0x4f, 0x52, 0x44, 0x5f, 0x4d, 0x41, 0x54, 0x43, 0x48, 0x5f, + 0x41, 0x4c, 0x4c, 0x10, 0x02, 0x12, 0x1c, 0x0a, 0x18, 0x4b, 0x45, 0x59, 0x57, 0x4f, 0x52, 0x44, + 0x5f, 0x4d, 0x41, 0x54, 0x43, 0x48, 0x5f, 0x54, 0x49, 0x54, 0x4c, 0x45, 0x5f, 0x4f, 0x4e, 0x4c, + 0x59, 0x10, 0x03, 0x22, 0x64, 0x0a, 0x12, 0x52, 0x65, 0x6c, 0x65, 0x76, 0x61, 0x6e, 0x63, 0x65, + 0x54, 0x68, 0x72, 0x65, 0x73, 0x68, 0x6f, 0x6c, 0x64, 0x12, 0x23, 0x0a, 0x1f, 0x52, 0x45, 0x4c, + 0x45, 0x56, 0x41, 0x4e, 0x43, 0x45, 0x5f, 0x54, 0x48, 0x52, 0x45, 0x53, 0x48, 0x4f, 0x4c, 0x44, + 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x0a, + 0x0a, 0x06, 0x4c, 0x4f, 0x57, 0x45, 0x53, 0x54, 0x10, 0x01, 0x12, 0x07, 0x0a, 0x03, 0x4c, 0x4f, + 0x57, 0x10, 0x02, 0x12, 0x0a, 0x0a, 0x06, 0x4d, 0x45, 0x44, 0x49, 0x55, 0x4d, 0x10, 0x03, 0x12, + 0x08, 0x0a, 0x04, 0x48, 0x49, 0x47, 0x48, 0x10, 0x04, 0x22, 0xcf, 0x08, 0x0a, 0x12, 0x53, 0x65, + 0x61, 0x72, 0x63, 0x68, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, + 0x12, 0x60, 0x0a, 0x0d, 0x6d, 0x61, 0x74, 0x63, 0x68, 0x69, 0x6e, 0x67, 0x5f, 0x6a, 0x6f, 0x62, + 0x73, 0x18, 0x01, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x3b, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, + 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, + 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x53, 0x65, 0x61, 0x72, 0x63, 0x68, 0x4a, 0x6f, 0x62, 0x73, + 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x2e, 0x4d, 0x61, 0x74, 0x63, 0x68, 0x69, 0x6e, + 0x67, 0x4a, 0x6f, 0x62, 0x52, 0x0c, 0x6d, 0x61, 0x74, 0x63, 0x68, 0x69, 0x6e, 0x67, 0x4a, 0x6f, + 0x62, 0x73, 0x12, 0x69, 0x0a, 0x17, 0x68, 0x69, 0x73, 0x74, 0x6f, 0x67, 0x72, 0x61, 0x6d, 0x5f, + 0x71, 0x75, 0x65, 0x72, 0x79, 0x5f, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x73, 0x18, 0x02, 0x20, + 0x03, 0x28, 0x0b, 0x32, 0x31, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, + 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, + 0x31, 0x2e, 0x48, 0x69, 0x73, 0x74, 0x6f, 0x67, 0x72, 0x61, 0x6d, 0x51, 0x75, 0x65, 0x72, 0x79, + 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x52, 0x15, 0x68, 0x69, 0x73, 0x74, 0x6f, 0x67, 0x72, 0x61, + 0x6d, 0x51, 0x75, 0x65, 0x72, 0x79, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x73, 0x12, 0x26, 0x0a, + 0x0f, 0x6e, 0x65, 0x78, 0x74, 0x5f, 0x70, 0x61, 0x67, 0x65, 0x5f, 0x74, 0x6f, 0x6b, 0x65, 0x6e, + 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0d, 0x6e, 0x65, 0x78, 0x74, 0x50, 0x61, 0x67, 0x65, + 0x54, 0x6f, 0x6b, 0x65, 0x6e, 0x12, 0x50, 0x0a, 0x10, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, + 0x6e, 0x5f, 0x66, 0x69, 0x6c, 0x74, 0x65, 0x72, 0x73, 0x18, 0x04, 0x20, 0x03, 0x28, 0x0b, 0x32, + 0x25, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, + 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x4c, 0x6f, + 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x0f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, + 0x46, 0x69, 0x6c, 0x74, 0x65, 0x72, 0x73, 0x12, 0x30, 0x0a, 0x14, 0x65, 0x73, 0x74, 0x69, 0x6d, + 0x61, 0x74, 0x65, 0x64, 0x5f, 0x74, 0x6f, 0x74, 0x61, 0x6c, 0x5f, 0x73, 0x69, 0x7a, 0x65, 0x18, + 0x05, 0x20, 0x01, 0x28, 0x05, 0x52, 0x12, 0x65, 0x73, 0x74, 0x69, 0x6d, 0x61, 0x74, 0x65, 0x64, + 0x54, 0x6f, 0x74, 0x61, 0x6c, 0x53, 0x69, 0x7a, 0x65, 0x12, 0x1d, 0x0a, 0x0a, 0x74, 0x6f, 0x74, + 0x61, 0x6c, 0x5f, 0x73, 0x69, 0x7a, 0x65, 0x18, 0x06, 0x20, 0x01, 0x28, 0x05, 0x52, 0x09, 0x74, + 0x6f, 0x74, 0x61, 0x6c, 0x53, 0x69, 0x7a, 0x65, 0x12, 0x49, 0x0a, 0x08, 0x6d, 0x65, 0x74, 0x61, + 0x64, 0x61, 0x74, 0x61, 0x18, 0x07, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x2d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, - 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x4a, 0x6f, 0x62, 0x52, 0x03, 0x6a, 0x6f, - 0x62, 0x12, 0x1f, 0x0a, 0x0b, 0x6a, 0x6f, 0x62, 0x5f, 0x73, 0x75, 0x6d, 0x6d, 0x61, 0x72, 0x79, - 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0a, 0x6a, 0x6f, 0x62, 0x53, 0x75, 0x6d, 0x6d, 0x61, - 0x72, 0x79, 0x12, 0x2a, 0x0a, 0x11, 0x6a, 0x6f, 0x62, 0x5f, 0x74, 0x69, 0x74, 0x6c, 0x65, 0x5f, - 0x73, 0x6e, 0x69, 0x70, 0x70, 0x65, 0x74, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0f, 0x6a, - 0x6f, 0x62, 0x54, 0x69, 0x74, 0x6c, 0x65, 0x53, 0x6e, 0x69, 0x70, 0x70, 0x65, 0x74, 0x12, 0x2e, - 0x0a, 0x13, 0x73, 0x65, 0x61, 0x72, 0x63, 0x68, 0x5f, 0x74, 0x65, 0x78, 0x74, 0x5f, 0x73, 0x6e, - 0x69, 0x70, 0x70, 0x65, 0x74, 0x18, 0x04, 0x20, 0x01, 0x28, 0x09, 0x52, 0x11, 0x73, 0x65, 0x61, - 0x72, 0x63, 0x68, 0x54, 0x65, 0x78, 0x74, 0x53, 0x6e, 0x69, 0x70, 0x70, 0x65, 0x74, 0x12, 0x5e, - 0x0a, 0x0c, 0x63, 0x6f, 0x6d, 0x6d, 0x75, 0x74, 0x65, 0x5f, 0x69, 0x6e, 0x66, 0x6f, 0x18, 0x05, - 0x20, 0x01, 0x28, 0x0b, 0x32, 0x3b, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, - 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, - 0x61, 0x31, 0x2e, 0x53, 0x65, 0x61, 0x72, 0x63, 0x68, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x73, - 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x2e, 0x43, 0x6f, 0x6d, 0x6d, 0x75, 0x74, 0x65, 0x49, 0x6e, 0x66, - 0x6f, 0x52, 0x0b, 0x63, 0x6f, 0x6d, 0x6d, 0x75, 0x74, 0x65, 0x49, 0x6e, 0x66, 0x6f, 0x1a, 0x9b, - 0x01, 0x0a, 0x0b, 0x43, 0x6f, 0x6d, 0x6d, 0x75, 0x74, 0x65, 0x49, 0x6e, 0x66, 0x6f, 0x12, 0x48, - 0x0a, 0x0c, 0x6a, 0x6f, 0x62, 0x5f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x18, 0x01, - 0x20, 0x01, 0x28, 0x0b, 0x32, 0x25, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, - 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, - 0x61, 0x31, 0x2e, 0x4c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x0b, 0x6a, 0x6f, 0x62, - 0x4c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x12, 0x42, 0x0a, 0x0f, 0x74, 0x72, 0x61, 0x76, - 0x65, 0x6c, 0x5f, 0x64, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x18, 0x02, 0x20, 0x01, 0x28, - 0x0b, 0x32, 0x19, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, - 0x62, 0x75, 0x66, 0x2e, 0x44, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x0e, 0x74, 0x72, - 0x61, 0x76, 0x65, 0x6c, 0x44, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x22, 0x8c, 0x01, 0x0a, - 0x16, 0x42, 0x61, 0x74, 0x63, 0x68, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x4a, 0x6f, 0x62, 0x73, - 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x37, 0x0a, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, - 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x1f, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x19, 0x12, - 0x17, 0x6a, 0x6f, 0x62, 0x73, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, - 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x4a, 0x6f, 0x62, 0x52, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, - 0x12, 0x39, 0x0a, 0x04, 0x6a, 0x6f, 0x62, 0x73, 0x18, 0x02, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x20, - 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, - 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x4a, 0x6f, 0x62, - 0x42, 0x03, 0xe0, 0x41, 0x02, 0x52, 0x04, 0x6a, 0x6f, 0x62, 0x73, 0x22, 0xc9, 0x01, 0x0a, 0x16, - 0x42, 0x61, 0x74, 0x63, 0x68, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x4a, 0x6f, 0x62, 0x73, 0x52, + 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, + 0x65, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x52, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, + 0x61, 0x74, 0x61, 0x12, 0x3b, 0x0a, 0x1a, 0x62, 0x72, 0x6f, 0x61, 0x64, 0x65, 0x6e, 0x65, 0x64, + 0x5f, 0x71, 0x75, 0x65, 0x72, 0x79, 0x5f, 0x6a, 0x6f, 0x62, 0x73, 0x5f, 0x63, 0x6f, 0x75, 0x6e, + 0x74, 0x18, 0x08, 0x20, 0x01, 0x28, 0x05, 0x52, 0x17, 0x62, 0x72, 0x6f, 0x61, 0x64, 0x65, 0x6e, + 0x65, 0x64, 0x51, 0x75, 0x65, 0x72, 0x79, 0x4a, 0x6f, 0x62, 0x73, 0x43, 0x6f, 0x75, 0x6e, 0x74, + 0x12, 0x5a, 0x0a, 0x10, 0x73, 0x70, 0x65, 0x6c, 0x6c, 0x5f, 0x63, 0x6f, 0x72, 0x72, 0x65, 0x63, + 0x74, 0x69, 0x6f, 0x6e, 0x18, 0x09, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x2f, 0x2e, 0x67, 0x6f, 0x6f, + 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, + 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x53, 0x70, 0x65, 0x6c, 0x6c, 0x69, 0x6e, + 0x67, 0x43, 0x6f, 0x72, 0x72, 0x65, 0x63, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x0f, 0x73, 0x70, 0x65, + 0x6c, 0x6c, 0x43, 0x6f, 0x72, 0x72, 0x65, 0x63, 0x74, 0x69, 0x6f, 0x6e, 0x1a, 0x9e, 0x02, 0x0a, + 0x0b, 0x4d, 0x61, 0x74, 0x63, 0x68, 0x69, 0x6e, 0x67, 0x4a, 0x6f, 0x62, 0x12, 0x32, 0x0a, 0x03, + 0x6a, 0x6f, 0x62, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x20, 0x2e, 0x67, 0x6f, 0x6f, 0x67, + 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, + 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x4a, 0x6f, 0x62, 0x52, 0x03, 0x6a, 0x6f, 0x62, + 0x12, 0x1f, 0x0a, 0x0b, 0x6a, 0x6f, 0x62, 0x5f, 0x73, 0x75, 0x6d, 0x6d, 0x61, 0x72, 0x79, 0x18, + 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0a, 0x6a, 0x6f, 0x62, 0x53, 0x75, 0x6d, 0x6d, 0x61, 0x72, + 0x79, 0x12, 0x2a, 0x0a, 0x11, 0x6a, 0x6f, 0x62, 0x5f, 0x74, 0x69, 0x74, 0x6c, 0x65, 0x5f, 0x73, + 0x6e, 0x69, 0x70, 0x70, 0x65, 0x74, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0f, 0x6a, 0x6f, + 0x62, 0x54, 0x69, 0x74, 0x6c, 0x65, 0x53, 0x6e, 0x69, 0x70, 0x70, 0x65, 0x74, 0x12, 0x2e, 0x0a, + 0x13, 0x73, 0x65, 0x61, 0x72, 0x63, 0x68, 0x5f, 0x74, 0x65, 0x78, 0x74, 0x5f, 0x73, 0x6e, 0x69, + 0x70, 0x70, 0x65, 0x74, 0x18, 0x04, 0x20, 0x01, 0x28, 0x09, 0x52, 0x11, 0x73, 0x65, 0x61, 0x72, + 0x63, 0x68, 0x54, 0x65, 0x78, 0x74, 0x53, 0x6e, 0x69, 0x70, 0x70, 0x65, 0x74, 0x12, 0x5e, 0x0a, + 0x0c, 0x63, 0x6f, 0x6d, 0x6d, 0x75, 0x74, 0x65, 0x5f, 0x69, 0x6e, 0x66, 0x6f, 0x18, 0x05, 0x20, + 0x01, 0x28, 0x0b, 0x32, 0x3b, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, + 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, + 0x31, 0x2e, 0x53, 0x65, 0x61, 0x72, 0x63, 0x68, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x73, 0x70, + 0x6f, 0x6e, 0x73, 0x65, 0x2e, 0x43, 0x6f, 0x6d, 0x6d, 0x75, 0x74, 0x65, 0x49, 0x6e, 0x66, 0x6f, + 0x52, 0x0b, 0x63, 0x6f, 0x6d, 0x6d, 0x75, 0x74, 0x65, 0x49, 0x6e, 0x66, 0x6f, 0x1a, 0x9b, 0x01, + 0x0a, 0x0b, 0x43, 0x6f, 0x6d, 0x6d, 0x75, 0x74, 0x65, 0x49, 0x6e, 0x66, 0x6f, 0x12, 0x48, 0x0a, + 0x0c, 0x6a, 0x6f, 0x62, 0x5f, 0x6c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x18, 0x01, 0x20, + 0x01, 0x28, 0x0b, 0x32, 0x25, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, + 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, + 0x31, 0x2e, 0x4c, 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x0b, 0x6a, 0x6f, 0x62, 0x4c, + 0x6f, 0x63, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x12, 0x42, 0x0a, 0x0f, 0x74, 0x72, 0x61, 0x76, 0x65, + 0x6c, 0x5f, 0x64, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, + 0x32, 0x19, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, + 0x75, 0x66, 0x2e, 0x44, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x0e, 0x74, 0x72, 0x61, + 0x76, 0x65, 0x6c, 0x44, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x22, 0x8c, 0x01, 0x0a, 0x16, + 0x42, 0x61, 0x74, 0x63, 0x68, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x37, 0x0a, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x1f, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x19, 0x12, 0x17, 0x6a, 0x6f, 0x62, 0x73, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, @@ -2296,189 +2378,198 @@ var file_google_cloud_talent_v4beta1_job_service_proto_rawDesc = []byte{ 0x39, 0x0a, 0x04, 0x6a, 0x6f, 0x62, 0x73, 0x18, 0x02, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x20, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x4a, 0x6f, 0x62, 0x42, - 0x03, 0xe0, 0x41, 0x02, 0x52, 0x04, 0x6a, 0x6f, 0x62, 0x73, 0x12, 0x3b, 0x0a, 0x0b, 0x75, 0x70, - 0x64, 0x61, 0x74, 0x65, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x18, 0x03, 0x20, 0x01, 0x28, 0x0b, 0x32, - 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, - 0x66, 0x2e, 0x46, 0x69, 0x65, 0x6c, 0x64, 0x4d, 0x61, 0x73, 0x6b, 0x52, 0x0a, 0x75, 0x70, 0x64, - 0x61, 0x74, 0x65, 0x4d, 0x61, 0x73, 0x6b, 0x22, 0xdd, 0x01, 0x0a, 0x12, 0x4a, 0x6f, 0x62, 0x4f, - 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x12, 0x5a, - 0x0a, 0x0b, 0x6a, 0x6f, 0x62, 0x5f, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x73, 0x18, 0x01, 0x20, - 0x03, 0x28, 0x0b, 0x32, 0x39, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, - 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, - 0x31, 0x2e, 0x4a, 0x6f, 0x62, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, - 0x73, 0x75, 0x6c, 0x74, 0x2e, 0x4a, 0x6f, 0x62, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x52, 0x0a, - 0x6a, 0x6f, 0x62, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x73, 0x1a, 0x6b, 0x0a, 0x09, 0x4a, 0x6f, - 0x62, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x12, 0x32, 0x0a, 0x03, 0x6a, 0x6f, 0x62, 0x18, 0x01, - 0x20, 0x01, 0x28, 0x0b, 0x32, 0x20, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, - 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, - 0x61, 0x31, 0x2e, 0x4a, 0x6f, 0x62, 0x52, 0x03, 0x6a, 0x6f, 0x62, 0x12, 0x2a, 0x0a, 0x06, 0x73, - 0x74, 0x61, 0x74, 0x75, 0x73, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x12, 0x2e, 0x67, 0x6f, - 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x72, 0x70, 0x63, 0x2e, 0x53, 0x74, 0x61, 0x74, 0x75, 0x73, 0x52, - 0x06, 0x73, 0x74, 0x61, 0x74, 0x75, 0x73, 0x2a, 0x76, 0x0a, 0x07, 0x4a, 0x6f, 0x62, 0x56, 0x69, - 0x65, 0x77, 0x12, 0x18, 0x0a, 0x14, 0x4a, 0x4f, 0x42, 0x5f, 0x56, 0x49, 0x45, 0x57, 0x5f, 0x55, - 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x14, 0x0a, 0x10, - 0x4a, 0x4f, 0x42, 0x5f, 0x56, 0x49, 0x45, 0x57, 0x5f, 0x49, 0x44, 0x5f, 0x4f, 0x4e, 0x4c, 0x59, - 0x10, 0x01, 0x12, 0x14, 0x0a, 0x10, 0x4a, 0x4f, 0x42, 0x5f, 0x56, 0x49, 0x45, 0x57, 0x5f, 0x4d, - 0x49, 0x4e, 0x49, 0x4d, 0x41, 0x4c, 0x10, 0x02, 0x12, 0x12, 0x0a, 0x0e, 0x4a, 0x4f, 0x42, 0x5f, - 0x56, 0x49, 0x45, 0x57, 0x5f, 0x53, 0x4d, 0x41, 0x4c, 0x4c, 0x10, 0x03, 0x12, 0x11, 0x0a, 0x0d, - 0x4a, 0x4f, 0x42, 0x5f, 0x56, 0x49, 0x45, 0x57, 0x5f, 0x46, 0x55, 0x4c, 0x4c, 0x10, 0x04, 0x32, - 0xce, 0x12, 0x0a, 0x0a, 0x4a, 0x6f, 0x62, 0x53, 0x65, 0x72, 0x76, 0x69, 0x63, 0x65, 0x12, 0xc9, - 0x01, 0x0a, 0x09, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x4a, 0x6f, 0x62, 0x12, 0x2d, 0x2e, 0x67, + 0x03, 0xe0, 0x41, 0x02, 0x52, 0x04, 0x6a, 0x6f, 0x62, 0x73, 0x22, 0xc9, 0x01, 0x0a, 0x16, 0x42, + 0x61, 0x74, 0x63, 0x68, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, + 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x37, 0x0a, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x18, + 0x01, 0x20, 0x01, 0x28, 0x09, 0x42, 0x1f, 0xe0, 0x41, 0x02, 0xfa, 0x41, 0x19, 0x12, 0x17, 0x6a, + 0x6f, 0x62, 0x73, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, + 0x6f, 0x6d, 0x2f, 0x4a, 0x6f, 0x62, 0x52, 0x06, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x12, 0x39, + 0x0a, 0x04, 0x6a, 0x6f, 0x62, 0x73, 0x18, 0x02, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x20, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, - 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x43, 0x72, 0x65, 0x61, 0x74, - 0x65, 0x4a, 0x6f, 0x62, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x20, 0x2e, 0x67, 0x6f, + 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x4a, 0x6f, 0x62, 0x42, 0x03, + 0xe0, 0x41, 0x02, 0x52, 0x04, 0x6a, 0x6f, 0x62, 0x73, 0x12, 0x3b, 0x0a, 0x0b, 0x75, 0x70, 0x64, + 0x61, 0x74, 0x65, 0x5f, 0x6d, 0x61, 0x73, 0x6b, 0x18, 0x03, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, + 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, + 0x2e, 0x46, 0x69, 0x65, 0x6c, 0x64, 0x4d, 0x61, 0x73, 0x6b, 0x52, 0x0a, 0x75, 0x70, 0x64, 0x61, + 0x74, 0x65, 0x4d, 0x61, 0x73, 0x6b, 0x22, 0xdd, 0x01, 0x0a, 0x12, 0x4a, 0x6f, 0x62, 0x4f, 0x70, + 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x12, 0x5a, 0x0a, + 0x0b, 0x6a, 0x6f, 0x62, 0x5f, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x73, 0x18, 0x01, 0x20, 0x03, + 0x28, 0x0b, 0x32, 0x39, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, + 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, + 0x2e, 0x4a, 0x6f, 0x62, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x73, + 0x75, 0x6c, 0x74, 0x2e, 0x4a, 0x6f, 0x62, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x52, 0x0a, 0x6a, + 0x6f, 0x62, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x73, 0x1a, 0x6b, 0x0a, 0x09, 0x4a, 0x6f, 0x62, + 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x12, 0x32, 0x0a, 0x03, 0x6a, 0x6f, 0x62, 0x18, 0x01, 0x20, + 0x01, 0x28, 0x0b, 0x32, 0x20, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, + 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, + 0x31, 0x2e, 0x4a, 0x6f, 0x62, 0x52, 0x03, 0x6a, 0x6f, 0x62, 0x12, 0x2a, 0x0a, 0x06, 0x73, 0x74, + 0x61, 0x74, 0x75, 0x73, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x12, 0x2e, 0x67, 0x6f, 0x6f, + 0x67, 0x6c, 0x65, 0x2e, 0x72, 0x70, 0x63, 0x2e, 0x53, 0x74, 0x61, 0x74, 0x75, 0x73, 0x52, 0x06, + 0x73, 0x74, 0x61, 0x74, 0x75, 0x73, 0x2a, 0x76, 0x0a, 0x07, 0x4a, 0x6f, 0x62, 0x56, 0x69, 0x65, + 0x77, 0x12, 0x18, 0x0a, 0x14, 0x4a, 0x4f, 0x42, 0x5f, 0x56, 0x49, 0x45, 0x57, 0x5f, 0x55, 0x4e, + 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x14, 0x0a, 0x10, 0x4a, + 0x4f, 0x42, 0x5f, 0x56, 0x49, 0x45, 0x57, 0x5f, 0x49, 0x44, 0x5f, 0x4f, 0x4e, 0x4c, 0x59, 0x10, + 0x01, 0x12, 0x14, 0x0a, 0x10, 0x4a, 0x4f, 0x42, 0x5f, 0x56, 0x49, 0x45, 0x57, 0x5f, 0x4d, 0x49, + 0x4e, 0x49, 0x4d, 0x41, 0x4c, 0x10, 0x02, 0x12, 0x12, 0x0a, 0x0e, 0x4a, 0x4f, 0x42, 0x5f, 0x56, + 0x49, 0x45, 0x57, 0x5f, 0x53, 0x4d, 0x41, 0x4c, 0x4c, 0x10, 0x03, 0x12, 0x11, 0x0a, 0x0d, 0x4a, + 0x4f, 0x42, 0x5f, 0x56, 0x49, 0x45, 0x57, 0x5f, 0x46, 0x55, 0x4c, 0x4c, 0x10, 0x04, 0x32, 0xce, + 0x12, 0x0a, 0x0a, 0x4a, 0x6f, 0x62, 0x53, 0x65, 0x72, 0x76, 0x69, 0x63, 0x65, 0x12, 0xc9, 0x01, + 0x0a, 0x09, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x4a, 0x6f, 0x62, 0x12, 0x2d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, - 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x4a, 0x6f, 0x62, 0x22, 0x6b, 0xda, - 0x41, 0x0a, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x2c, 0x6a, 0x6f, 0x62, 0x82, 0xd3, 0xe4, 0x93, - 0x02, 0x58, 0x3a, 0x01, 0x2a, 0x5a, 0x26, 0x3a, 0x01, 0x2a, 0x22, 0x21, 0x2f, 0x76, 0x34, 0x62, - 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, - 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x22, 0x2b, 0x2f, - 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, - 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x74, 0x65, 0x6e, 0x61, 0x6e, - 0x74, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x12, 0x9b, 0x02, 0x0a, 0x0f, 0x42, - 0x61, 0x74, 0x63, 0x68, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x4a, 0x6f, 0x62, 0x73, 0x12, 0x33, + 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, + 0x4a, 0x6f, 0x62, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x20, 0x2e, 0x67, 0x6f, 0x6f, + 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, + 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x4a, 0x6f, 0x62, 0x22, 0x6b, 0xda, 0x41, + 0x0a, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x2c, 0x6a, 0x6f, 0x62, 0x82, 0xd3, 0xe4, 0x93, 0x02, + 0x58, 0x3a, 0x01, 0x2a, 0x5a, 0x26, 0x3a, 0x01, 0x2a, 0x22, 0x21, 0x2f, 0x76, 0x34, 0x62, 0x65, + 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, + 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x22, 0x2b, 0x2f, 0x76, + 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x70, + 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x74, 0x65, 0x6e, 0x61, 0x6e, 0x74, + 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x12, 0x9b, 0x02, 0x0a, 0x0f, 0x42, 0x61, + 0x74, 0x63, 0x68, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x4a, 0x6f, 0x62, 0x73, 0x12, 0x33, 0x2e, + 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, + 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x42, 0x61, 0x74, 0x63, + 0x68, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, + 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x6c, 0x6f, 0x6e, 0x67, + 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, 0x67, 0x2e, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, + 0x6e, 0x22, 0xb3, 0x01, 0xca, 0x41, 0x2c, 0x0a, 0x12, 0x4a, 0x6f, 0x62, 0x4f, 0x70, 0x65, 0x72, + 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x12, 0x16, 0x42, 0x61, 0x74, + 0x63, 0x68, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, + 0x61, 0x74, 0x61, 0xda, 0x41, 0x0b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x2c, 0x6a, 0x6f, 0x62, + 0x73, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x70, 0x3a, 0x01, 0x2a, 0x5a, 0x32, 0x3a, 0x01, 0x2a, 0x22, + 0x2d, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, + 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x6a, 0x6f, + 0x62, 0x73, 0x3a, 0x62, 0x61, 0x74, 0x63, 0x68, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x22, 0x37, + 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, + 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x74, 0x65, 0x6e, 0x61, + 0x6e, 0x74, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x3a, 0x62, 0x61, 0x74, 0x63, + 0x68, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x12, 0xb7, 0x01, 0x0a, 0x06, 0x47, 0x65, 0x74, 0x4a, + 0x6f, 0x62, 0x12, 0x2a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, + 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, + 0x2e, 0x47, 0x65, 0x74, 0x4a, 0x6f, 0x62, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x20, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, - 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x42, 0x61, 0x74, - 0x63, 0x68, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x71, 0x75, - 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x6c, 0x6f, 0x6e, - 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, 0x67, 0x2e, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, - 0x6f, 0x6e, 0x22, 0xb3, 0x01, 0xca, 0x41, 0x2c, 0x0a, 0x12, 0x4a, 0x6f, 0x62, 0x4f, 0x70, 0x65, - 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x12, 0x16, 0x42, 0x61, - 0x74, 0x63, 0x68, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x4d, 0x65, 0x74, 0x61, - 0x64, 0x61, 0x74, 0x61, 0xda, 0x41, 0x0b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x2c, 0x6a, 0x6f, - 0x62, 0x73, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x70, 0x3a, 0x01, 0x2a, 0x5a, 0x32, 0x3a, 0x01, 0x2a, - 0x22, 0x2d, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, - 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x6a, - 0x6f, 0x62, 0x73, 0x3a, 0x62, 0x61, 0x74, 0x63, 0x68, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x22, - 0x37, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, - 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x74, 0x65, 0x6e, - 0x61, 0x6e, 0x74, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x3a, 0x62, 0x61, 0x74, - 0x63, 0x68, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x12, 0xb7, 0x01, 0x0a, 0x06, 0x47, 0x65, 0x74, - 0x4a, 0x6f, 0x62, 0x12, 0x2a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, - 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, - 0x31, 0x2e, 0x47, 0x65, 0x74, 0x4a, 0x6f, 0x62, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, - 0x20, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, - 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x4a, 0x6f, - 0x62, 0x22, 0x5f, 0xda, 0x41, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x52, - 0x5a, 0x23, 0x12, 0x21, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x6e, 0x61, + 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x4a, 0x6f, 0x62, + 0x22, 0x5f, 0xda, 0x41, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x52, 0x5a, + 0x23, 0x12, 0x21, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x6e, 0x61, 0x6d, + 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6a, 0x6f, 0x62, + 0x73, 0x2f, 0x2a, 0x7d, 0x12, 0x2b, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, + 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, + 0x74, 0x65, 0x6e, 0x61, 0x6e, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x2f, 0x2a, + 0x7d, 0x12, 0xca, 0x01, 0x0a, 0x09, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x4a, 0x6f, 0x62, 0x12, + 0x2d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, + 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x55, 0x70, + 0x64, 0x61, 0x74, 0x65, 0x4a, 0x6f, 0x62, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x20, + 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, + 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x4a, 0x6f, 0x62, + 0x22, 0x6c, 0xda, 0x41, 0x03, 0x6a, 0x6f, 0x62, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x60, 0x3a, 0x01, + 0x2a, 0x5a, 0x2a, 0x3a, 0x01, 0x2a, 0x32, 0x25, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, + 0x2f, 0x7b, 0x6a, 0x6f, 0x62, 0x2e, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, + 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x2f, 0x2a, 0x7d, 0x32, 0x2f, 0x2f, + 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x6a, 0x6f, 0x62, 0x2e, 0x6e, 0x61, 0x6d, + 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x74, 0x65, 0x6e, + 0x61, 0x6e, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x2f, 0x2a, 0x7d, 0x12, 0x9b, + 0x02, 0x0a, 0x0f, 0x42, 0x61, 0x74, 0x63, 0x68, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x4a, 0x6f, + 0x62, 0x73, 0x12, 0x33, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, + 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, + 0x2e, 0x42, 0x61, 0x74, 0x63, 0x68, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x4a, 0x6f, 0x62, 0x73, + 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, + 0x2e, 0x6c, 0x6f, 0x6e, 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, 0x67, 0x2e, 0x4f, 0x70, 0x65, + 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x22, 0xb3, 0x01, 0xca, 0x41, 0x2c, 0x0a, 0x12, 0x4a, 0x6f, + 0x62, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x73, 0x75, 0x6c, 0x74, + 0x12, 0x16, 0x42, 0x61, 0x74, 0x63, 0x68, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, + 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0xda, 0x41, 0x0b, 0x70, 0x61, 0x72, 0x65, 0x6e, + 0x74, 0x2c, 0x6a, 0x6f, 0x62, 0x73, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x70, 0x3a, 0x01, 0x2a, 0x5a, + 0x32, 0x3a, 0x01, 0x2a, 0x22, 0x2d, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, + 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, + 0x2a, 0x7d, 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x3a, 0x62, 0x61, 0x74, 0x63, 0x68, 0x55, 0x70, 0x64, + 0x61, 0x74, 0x65, 0x22, 0x37, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x70, + 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, + 0x2f, 0x74, 0x65, 0x6e, 0x61, 0x6e, 0x74, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x6a, 0x6f, 0x62, 0x73, + 0x3a, 0x62, 0x61, 0x74, 0x63, 0x68, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x12, 0xb3, 0x01, 0x0a, + 0x09, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x4a, 0x6f, 0x62, 0x12, 0x2d, 0x2e, 0x67, 0x6f, 0x6f, + 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, + 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x4a, + 0x6f, 0x62, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x16, 0x2e, 0x67, 0x6f, 0x6f, 0x67, + 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x45, 0x6d, 0x70, 0x74, + 0x79, 0x22, 0x5f, 0xda, 0x41, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x52, + 0x5a, 0x23, 0x2a, 0x21, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6a, 0x6f, - 0x62, 0x73, 0x2f, 0x2a, 0x7d, 0x12, 0x2b, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, + 0x62, 0x73, 0x2f, 0x2a, 0x7d, 0x2a, 0x2b, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x74, 0x65, 0x6e, 0x61, 0x6e, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x2f, - 0x2a, 0x7d, 0x12, 0xca, 0x01, 0x0a, 0x09, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x4a, 0x6f, 0x62, - 0x12, 0x2d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, - 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x55, - 0x70, 0x64, 0x61, 0x74, 0x65, 0x4a, 0x6f, 0x62, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, - 0x20, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, - 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x4a, 0x6f, - 0x62, 0x22, 0x6c, 0xda, 0x41, 0x03, 0x6a, 0x6f, 0x62, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x60, 0x3a, - 0x01, 0x2a, 0x5a, 0x2a, 0x3a, 0x01, 0x2a, 0x32, 0x25, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, - 0x31, 0x2f, 0x7b, 0x6a, 0x6f, 0x62, 0x2e, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, - 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x2f, 0x2a, 0x7d, 0x32, 0x2f, - 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x6a, 0x6f, 0x62, 0x2e, 0x6e, 0x61, - 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x74, 0x65, - 0x6e, 0x61, 0x6e, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x2f, 0x2a, 0x7d, 0x12, - 0x9b, 0x02, 0x0a, 0x0f, 0x42, 0x61, 0x74, 0x63, 0x68, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x4a, - 0x6f, 0x62, 0x73, 0x12, 0x33, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, - 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, - 0x31, 0x2e, 0x42, 0x61, 0x74, 0x63, 0x68, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x4a, 0x6f, 0x62, - 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, - 0x65, 0x2e, 0x6c, 0x6f, 0x6e, 0x67, 0x72, 0x75, 0x6e, 0x6e, 0x69, 0x6e, 0x67, 0x2e, 0x4f, 0x70, - 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x22, 0xb3, 0x01, 0xca, 0x41, 0x2c, 0x0a, 0x12, 0x4a, - 0x6f, 0x62, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x73, 0x75, 0x6c, - 0x74, 0x12, 0x16, 0x42, 0x61, 0x74, 0x63, 0x68, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, - 0x6e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0xda, 0x41, 0x0b, 0x70, 0x61, 0x72, 0x65, - 0x6e, 0x74, 0x2c, 0x6a, 0x6f, 0x62, 0x73, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x70, 0x3a, 0x01, 0x2a, - 0x5a, 0x32, 0x3a, 0x01, 0x2a, 0x22, 0x2d, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, + 0x2a, 0x7d, 0x12, 0xe4, 0x01, 0x0a, 0x0f, 0x42, 0x61, 0x74, 0x63, 0x68, 0x44, 0x65, 0x6c, 0x65, + 0x74, 0x65, 0x4a, 0x6f, 0x62, 0x73, 0x12, 0x33, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, + 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, + 0x65, 0x74, 0x61, 0x31, 0x2e, 0x42, 0x61, 0x74, 0x63, 0x68, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, + 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x16, 0x2e, 0x67, 0x6f, + 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x45, 0x6d, + 0x70, 0x74, 0x79, 0x22, 0x83, 0x01, 0xda, 0x41, 0x0d, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x2c, + 0x66, 0x69, 0x6c, 0x74, 0x65, 0x72, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x6d, 0x3a, 0x01, 0x2a, 0x5a, + 0x2f, 0x22, 0x2d, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x70, 0x61, 0x72, + 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, + 0x6a, 0x6f, 0x62, 0x73, 0x3a, 0x62, 0x61, 0x74, 0x63, 0x68, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, + 0x22, 0x37, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, + 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x74, 0x65, + 0x6e, 0x61, 0x6e, 0x74, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x3a, 0x62, 0x61, + 0x74, 0x63, 0x68, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x12, 0xd1, 0x01, 0x0a, 0x08, 0x4c, 0x69, + 0x73, 0x74, 0x4a, 0x6f, 0x62, 0x73, 0x12, 0x2c, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, + 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, + 0x65, 0x74, 0x61, 0x31, 0x2e, 0x4c, 0x69, 0x73, 0x74, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x71, + 0x75, 0x65, 0x73, 0x74, 0x1a, 0x2d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, + 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, + 0x61, 0x31, 0x2e, 0x4c, 0x69, 0x73, 0x74, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x73, 0x70, 0x6f, + 0x6e, 0x73, 0x65, 0x22, 0x68, 0xda, 0x41, 0x0d, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x2c, 0x66, + 0x69, 0x6c, 0x74, 0x65, 0x72, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x52, 0x5a, 0x23, 0x12, 0x21, 0x2f, + 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, + 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x6a, 0x6f, 0x62, 0x73, + 0x12, 0x2b, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, + 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x74, 0x65, + 0x6e, 0x61, 0x6e, 0x74, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x12, 0xdb, 0x01, + 0x0a, 0x0a, 0x53, 0x65, 0x61, 0x72, 0x63, 0x68, 0x4a, 0x6f, 0x62, 0x73, 0x12, 0x2e, 0x2e, 0x67, + 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, + 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x53, 0x65, 0x61, 0x72, 0x63, + 0x68, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x2f, 0x2e, 0x67, + 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, + 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x53, 0x65, 0x61, 0x72, 0x63, + 0x68, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x6c, 0x82, + 0xd3, 0xe4, 0x93, 0x02, 0x66, 0x3a, 0x01, 0x2a, 0x5a, 0x2d, 0x3a, 0x01, 0x2a, 0x22, 0x28, 0x2f, + 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, + 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x6a, 0x6f, 0x62, 0x73, + 0x3a, 0x73, 0x65, 0x61, 0x72, 0x63, 0x68, 0x22, 0x32, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, + 0x31, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, + 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x74, 0x65, 0x6e, 0x61, 0x6e, 0x74, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, + 0x6a, 0x6f, 0x62, 0x73, 0x3a, 0x73, 0x65, 0x61, 0x72, 0x63, 0x68, 0x12, 0xf3, 0x01, 0x0a, 0x12, + 0x53, 0x65, 0x61, 0x72, 0x63, 0x68, 0x4a, 0x6f, 0x62, 0x73, 0x46, 0x6f, 0x72, 0x41, 0x6c, 0x65, + 0x72, 0x74, 0x12, 0x2e, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, + 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, + 0x2e, 0x53, 0x65, 0x61, 0x72, 0x63, 0x68, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, + 0x73, 0x74, 0x1a, 0x2f, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, + 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, + 0x2e, 0x53, 0x65, 0x61, 0x72, 0x63, 0x68, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x73, 0x70, 0x6f, + 0x6e, 0x73, 0x65, 0x22, 0x7c, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x76, 0x3a, 0x01, 0x2a, 0x5a, 0x35, + 0x3a, 0x01, 0x2a, 0x22, 0x30, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x70, + 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, + 0x7d, 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x3a, 0x73, 0x65, 0x61, 0x72, 0x63, 0x68, 0x46, 0x6f, 0x72, + 0x41, 0x6c, 0x65, 0x72, 0x74, 0x22, 0x3a, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, - 0x2f, 0x2a, 0x7d, 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x3a, 0x62, 0x61, 0x74, 0x63, 0x68, 0x55, 0x70, - 0x64, 0x61, 0x74, 0x65, 0x22, 0x37, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, - 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, - 0x2a, 0x2f, 0x74, 0x65, 0x6e, 0x61, 0x6e, 0x74, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x6a, 0x6f, 0x62, - 0x73, 0x3a, 0x62, 0x61, 0x74, 0x63, 0x68, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x12, 0xb3, 0x01, - 0x0a, 0x09, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x4a, 0x6f, 0x62, 0x12, 0x2d, 0x2e, 0x67, 0x6f, - 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, - 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, - 0x4a, 0x6f, 0x62, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x16, 0x2e, 0x67, 0x6f, 0x6f, - 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x45, 0x6d, 0x70, - 0x74, 0x79, 0x22, 0x5f, 0xda, 0x41, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x82, 0xd3, 0xe4, 0x93, 0x02, - 0x52, 0x5a, 0x23, 0x2a, 0x21, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x6e, - 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6a, - 0x6f, 0x62, 0x73, 0x2f, 0x2a, 0x7d, 0x2a, 0x2b, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, - 0x2f, 0x7b, 0x6e, 0x61, 0x6d, 0x65, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, - 0x2a, 0x2f, 0x74, 0x65, 0x6e, 0x61, 0x6e, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x6a, 0x6f, 0x62, 0x73, - 0x2f, 0x2a, 0x7d, 0x12, 0xe4, 0x01, 0x0a, 0x0f, 0x42, 0x61, 0x74, 0x63, 0x68, 0x44, 0x65, 0x6c, - 0x65, 0x74, 0x65, 0x4a, 0x6f, 0x62, 0x73, 0x12, 0x33, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, - 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, - 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x42, 0x61, 0x74, 0x63, 0x68, 0x44, 0x65, 0x6c, 0x65, 0x74, - 0x65, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x16, 0x2e, 0x67, - 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x45, - 0x6d, 0x70, 0x74, 0x79, 0x22, 0x83, 0x01, 0xda, 0x41, 0x0d, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, - 0x2c, 0x66, 0x69, 0x6c, 0x74, 0x65, 0x72, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x6d, 0x3a, 0x01, 0x2a, - 0x5a, 0x2f, 0x22, 0x2d, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x70, 0x61, - 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x7d, - 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x3a, 0x62, 0x61, 0x74, 0x63, 0x68, 0x44, 0x65, 0x6c, 0x65, 0x74, - 0x65, 0x22, 0x37, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x70, 0x61, 0x72, - 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x74, - 0x65, 0x6e, 0x61, 0x6e, 0x74, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x3a, 0x62, - 0x61, 0x74, 0x63, 0x68, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x12, 0xd1, 0x01, 0x0a, 0x08, 0x4c, - 0x69, 0x73, 0x74, 0x4a, 0x6f, 0x62, 0x73, 0x12, 0x2c, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, - 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, - 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x4c, 0x69, 0x73, 0x74, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, - 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x2d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, - 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, - 0x74, 0x61, 0x31, 0x2e, 0x4c, 0x69, 0x73, 0x74, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x73, 0x70, - 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x68, 0xda, 0x41, 0x0d, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x2c, - 0x66, 0x69, 0x6c, 0x74, 0x65, 0x72, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x52, 0x5a, 0x23, 0x12, 0x21, - 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, - 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x6a, 0x6f, 0x62, - 0x73, 0x12, 0x2b, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x70, 0x61, 0x72, - 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x74, - 0x65, 0x6e, 0x61, 0x6e, 0x74, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x12, 0xdb, - 0x01, 0x0a, 0x0a, 0x53, 0x65, 0x61, 0x72, 0x63, 0x68, 0x4a, 0x6f, 0x62, 0x73, 0x12, 0x2e, 0x2e, - 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, - 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x53, 0x65, 0x61, 0x72, - 0x63, 0x68, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x2f, 0x2e, - 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, - 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2e, 0x53, 0x65, 0x61, 0x72, - 0x63, 0x68, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x6c, - 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x66, 0x3a, 0x01, 0x2a, 0x5a, 0x2d, 0x3a, 0x01, 0x2a, 0x22, 0x28, - 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, - 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x6a, 0x6f, 0x62, - 0x73, 0x3a, 0x73, 0x65, 0x61, 0x72, 0x63, 0x68, 0x22, 0x32, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, - 0x61, 0x31, 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, - 0x63, 0x74, 0x73, 0x2f, 0x2a, 0x2f, 0x74, 0x65, 0x6e, 0x61, 0x6e, 0x74, 0x73, 0x2f, 0x2a, 0x7d, - 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x3a, 0x73, 0x65, 0x61, 0x72, 0x63, 0x68, 0x12, 0xf3, 0x01, 0x0a, - 0x12, 0x53, 0x65, 0x61, 0x72, 0x63, 0x68, 0x4a, 0x6f, 0x62, 0x73, 0x46, 0x6f, 0x72, 0x41, 0x6c, - 0x65, 0x72, 0x74, 0x12, 0x2e, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, - 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, - 0x31, 0x2e, 0x53, 0x65, 0x61, 0x72, 0x63, 0x68, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x71, 0x75, - 0x65, 0x73, 0x74, 0x1a, 0x2f, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, 0x6f, - 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, - 0x31, 0x2e, 0x53, 0x65, 0x61, 0x72, 0x63, 0x68, 0x4a, 0x6f, 0x62, 0x73, 0x52, 0x65, 0x73, 0x70, - 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x7c, 0x82, 0xd3, 0xe4, 0x93, 0x02, 0x76, 0x3a, 0x01, 0x2a, 0x5a, - 0x35, 0x3a, 0x01, 0x2a, 0x22, 0x30, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x7b, - 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, 0x73, 0x2f, - 0x2a, 0x7d, 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x3a, 0x73, 0x65, 0x61, 0x72, 0x63, 0x68, 0x46, 0x6f, - 0x72, 0x41, 0x6c, 0x65, 0x72, 0x74, 0x22, 0x3a, 0x2f, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, - 0x2f, 0x7b, 0x70, 0x61, 0x72, 0x65, 0x6e, 0x74, 0x3d, 0x70, 0x72, 0x6f, 0x6a, 0x65, 0x63, 0x74, - 0x73, 0x2f, 0x2a, 0x2f, 0x74, 0x65, 0x6e, 0x61, 0x6e, 0x74, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x6a, - 0x6f, 0x62, 0x73, 0x3a, 0x73, 0x65, 0x61, 0x72, 0x63, 0x68, 0x46, 0x6f, 0x72, 0x41, 0x6c, 0x65, - 0x72, 0x74, 0x1a, 0x6c, 0xca, 0x41, 0x13, 0x6a, 0x6f, 0x62, 0x73, 0x2e, 0x67, 0x6f, 0x6f, 0x67, - 0x6c, 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0xd2, 0x41, 0x53, 0x68, 0x74, 0x74, - 0x70, 0x73, 0x3a, 0x2f, 0x2f, 0x77, 0x77, 0x77, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, - 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x61, 0x75, 0x74, 0x68, 0x2f, 0x63, 0x6c, 0x6f, - 0x75, 0x64, 0x2d, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2c, 0x68, 0x74, 0x74, 0x70, + 0x2f, 0x2a, 0x2f, 0x74, 0x65, 0x6e, 0x61, 0x6e, 0x74, 0x73, 0x2f, 0x2a, 0x7d, 0x2f, 0x6a, 0x6f, + 0x62, 0x73, 0x3a, 0x73, 0x65, 0x61, 0x72, 0x63, 0x68, 0x46, 0x6f, 0x72, 0x41, 0x6c, 0x65, 0x72, + 0x74, 0x1a, 0x6c, 0xca, 0x41, 0x13, 0x6a, 0x6f, 0x62, 0x73, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, + 0x65, 0x61, 0x70, 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0xd2, 0x41, 0x53, 0x68, 0x74, 0x74, 0x70, 0x73, 0x3a, 0x2f, 0x2f, 0x77, 0x77, 0x77, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, - 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x61, 0x75, 0x74, 0x68, 0x2f, 0x6a, 0x6f, 0x62, 0x73, - 0x42, 0x73, 0x0a, 0x1f, 0x63, 0x6f, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, - 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, - 0x74, 0x61, 0x31, 0x42, 0x0f, 0x4a, 0x6f, 0x62, 0x53, 0x65, 0x72, 0x76, 0x69, 0x63, 0x65, 0x50, - 0x72, 0x6f, 0x74, 0x6f, 0x50, 0x01, 0x5a, 0x37, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x67, 0x6f, - 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x67, 0x6f, 0x2f, 0x74, 0x61, 0x6c, 0x65, - 0x6e, 0x74, 0x2f, 0x61, 0x70, 0x69, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x74, 0x61, - 0x6c, 0x65, 0x6e, 0x74, 0x70, 0x62, 0x3b, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x70, 0x62, 0xa2, - 0x02, 0x03, 0x43, 0x54, 0x53, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, + 0x69, 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x61, 0x75, 0x74, 0x68, 0x2f, 0x63, 0x6c, 0x6f, 0x75, + 0x64, 0x2d, 0x70, 0x6c, 0x61, 0x74, 0x66, 0x6f, 0x72, 0x6d, 0x2c, 0x68, 0x74, 0x74, 0x70, 0x73, + 0x3a, 0x2f, 0x2f, 0x77, 0x77, 0x77, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x61, 0x70, 0x69, + 0x73, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x61, 0x75, 0x74, 0x68, 0x2f, 0x6a, 0x6f, 0x62, 0x73, 0x42, + 0x73, 0x0a, 0x1f, 0x63, 0x6f, 0x6d, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6c, + 0x6f, 0x75, 0x64, 0x2e, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x2e, 0x76, 0x34, 0x62, 0x65, 0x74, + 0x61, 0x31, 0x42, 0x0f, 0x4a, 0x6f, 0x62, 0x53, 0x65, 0x72, 0x76, 0x69, 0x63, 0x65, 0x50, 0x72, + 0x6f, 0x74, 0x6f, 0x50, 0x01, 0x5a, 0x37, 0x63, 0x6c, 0x6f, 0x75, 0x64, 0x2e, 0x67, 0x6f, 0x6f, + 0x67, 0x6c, 0x65, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x67, 0x6f, 0x2f, 0x74, 0x61, 0x6c, 0x65, 0x6e, + 0x74, 0x2f, 0x61, 0x70, 0x69, 0x76, 0x34, 0x62, 0x65, 0x74, 0x61, 0x31, 0x2f, 0x74, 0x61, 0x6c, + 0x65, 0x6e, 0x74, 0x70, 0x62, 0x3b, 0x74, 0x61, 0x6c, 0x65, 0x6e, 0x74, 0x70, 0x62, 0xa2, 0x02, + 0x03, 0x43, 0x54, 0x53, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, } var ( @@ -2493,100 +2584,102 @@ func file_google_cloud_talent_v4beta1_job_service_proto_rawDescGZIP() []byte { return file_google_cloud_talent_v4beta1_job_service_proto_rawDescData } -var file_google_cloud_talent_v4beta1_job_service_proto_enumTypes = make([]protoimpl.EnumInfo, 5) +var file_google_cloud_talent_v4beta1_job_service_proto_enumTypes = make([]protoimpl.EnumInfo, 6) var file_google_cloud_talent_v4beta1_job_service_proto_msgTypes = make([]protoimpl.MessageInfo, 16) var file_google_cloud_talent_v4beta1_job_service_proto_goTypes = []any{ (JobView)(0), // 0: google.cloud.talent.v4beta1.JobView (SearchJobsRequest_SearchMode)(0), // 1: google.cloud.talent.v4beta1.SearchJobsRequest.SearchMode (SearchJobsRequest_DiversificationLevel)(0), // 2: google.cloud.talent.v4beta1.SearchJobsRequest.DiversificationLevel (SearchJobsRequest_KeywordMatchMode)(0), // 3: google.cloud.talent.v4beta1.SearchJobsRequest.KeywordMatchMode - (SearchJobsRequest_CustomRankingInfo_ImportanceLevel)(0), // 4: google.cloud.talent.v4beta1.SearchJobsRequest.CustomRankingInfo.ImportanceLevel - (*CreateJobRequest)(nil), // 5: google.cloud.talent.v4beta1.CreateJobRequest - (*GetJobRequest)(nil), // 6: google.cloud.talent.v4beta1.GetJobRequest - (*UpdateJobRequest)(nil), // 7: google.cloud.talent.v4beta1.UpdateJobRequest - (*DeleteJobRequest)(nil), // 8: google.cloud.talent.v4beta1.DeleteJobRequest - (*BatchDeleteJobsRequest)(nil), // 9: google.cloud.talent.v4beta1.BatchDeleteJobsRequest - (*ListJobsRequest)(nil), // 10: google.cloud.talent.v4beta1.ListJobsRequest - (*ListJobsResponse)(nil), // 11: google.cloud.talent.v4beta1.ListJobsResponse - (*SearchJobsRequest)(nil), // 12: google.cloud.talent.v4beta1.SearchJobsRequest - (*SearchJobsResponse)(nil), // 13: google.cloud.talent.v4beta1.SearchJobsResponse - (*BatchCreateJobsRequest)(nil), // 14: google.cloud.talent.v4beta1.BatchCreateJobsRequest - (*BatchUpdateJobsRequest)(nil), // 15: google.cloud.talent.v4beta1.BatchUpdateJobsRequest - (*JobOperationResult)(nil), // 16: google.cloud.talent.v4beta1.JobOperationResult - (*SearchJobsRequest_CustomRankingInfo)(nil), // 17: google.cloud.talent.v4beta1.SearchJobsRequest.CustomRankingInfo - (*SearchJobsResponse_MatchingJob)(nil), // 18: google.cloud.talent.v4beta1.SearchJobsResponse.MatchingJob - (*SearchJobsResponse_CommuteInfo)(nil), // 19: google.cloud.talent.v4beta1.SearchJobsResponse.CommuteInfo - (*JobOperationResult_JobResult)(nil), // 20: google.cloud.talent.v4beta1.JobOperationResult.JobResult - (*Job)(nil), // 21: google.cloud.talent.v4beta1.Job - (*fieldmaskpb.FieldMask)(nil), // 22: google.protobuf.FieldMask - (*ResponseMetadata)(nil), // 23: google.cloud.talent.v4beta1.ResponseMetadata - (*RequestMetadata)(nil), // 24: google.cloud.talent.v4beta1.RequestMetadata - (*JobQuery)(nil), // 25: google.cloud.talent.v4beta1.JobQuery - (*HistogramQuery)(nil), // 26: google.cloud.talent.v4beta1.HistogramQuery - (*HistogramQueryResult)(nil), // 27: google.cloud.talent.v4beta1.HistogramQueryResult - (*Location)(nil), // 28: google.cloud.talent.v4beta1.Location - (*SpellingCorrection)(nil), // 29: google.cloud.talent.v4beta1.SpellingCorrection - (*durationpb.Duration)(nil), // 30: google.protobuf.Duration - (*status.Status)(nil), // 31: google.rpc.Status - (*longrunningpb.Operation)(nil), // 32: google.longrunning.Operation - (*emptypb.Empty)(nil), // 33: google.protobuf.Empty + (SearchJobsRequest_RelevanceThreshold)(0), // 4: google.cloud.talent.v4beta1.SearchJobsRequest.RelevanceThreshold + (SearchJobsRequest_CustomRankingInfo_ImportanceLevel)(0), // 5: google.cloud.talent.v4beta1.SearchJobsRequest.CustomRankingInfo.ImportanceLevel + (*CreateJobRequest)(nil), // 6: google.cloud.talent.v4beta1.CreateJobRequest + (*GetJobRequest)(nil), // 7: google.cloud.talent.v4beta1.GetJobRequest + (*UpdateJobRequest)(nil), // 8: google.cloud.talent.v4beta1.UpdateJobRequest + (*DeleteJobRequest)(nil), // 9: google.cloud.talent.v4beta1.DeleteJobRequest + (*BatchDeleteJobsRequest)(nil), // 10: google.cloud.talent.v4beta1.BatchDeleteJobsRequest + (*ListJobsRequest)(nil), // 11: google.cloud.talent.v4beta1.ListJobsRequest + (*ListJobsResponse)(nil), // 12: google.cloud.talent.v4beta1.ListJobsResponse + (*SearchJobsRequest)(nil), // 13: google.cloud.talent.v4beta1.SearchJobsRequest + (*SearchJobsResponse)(nil), // 14: google.cloud.talent.v4beta1.SearchJobsResponse + (*BatchCreateJobsRequest)(nil), // 15: google.cloud.talent.v4beta1.BatchCreateJobsRequest + (*BatchUpdateJobsRequest)(nil), // 16: google.cloud.talent.v4beta1.BatchUpdateJobsRequest + (*JobOperationResult)(nil), // 17: google.cloud.talent.v4beta1.JobOperationResult + (*SearchJobsRequest_CustomRankingInfo)(nil), // 18: google.cloud.talent.v4beta1.SearchJobsRequest.CustomRankingInfo + (*SearchJobsResponse_MatchingJob)(nil), // 19: google.cloud.talent.v4beta1.SearchJobsResponse.MatchingJob + (*SearchJobsResponse_CommuteInfo)(nil), // 20: google.cloud.talent.v4beta1.SearchJobsResponse.CommuteInfo + (*JobOperationResult_JobResult)(nil), // 21: google.cloud.talent.v4beta1.JobOperationResult.JobResult + (*Job)(nil), // 22: google.cloud.talent.v4beta1.Job + (*fieldmaskpb.FieldMask)(nil), // 23: google.protobuf.FieldMask + (*ResponseMetadata)(nil), // 24: google.cloud.talent.v4beta1.ResponseMetadata + (*RequestMetadata)(nil), // 25: google.cloud.talent.v4beta1.RequestMetadata + (*JobQuery)(nil), // 26: google.cloud.talent.v4beta1.JobQuery + (*HistogramQuery)(nil), // 27: google.cloud.talent.v4beta1.HistogramQuery + (*HistogramQueryResult)(nil), // 28: google.cloud.talent.v4beta1.HistogramQueryResult + (*Location)(nil), // 29: google.cloud.talent.v4beta1.Location + (*SpellingCorrection)(nil), // 30: google.cloud.talent.v4beta1.SpellingCorrection + (*durationpb.Duration)(nil), // 31: google.protobuf.Duration + (*status.Status)(nil), // 32: google.rpc.Status + (*longrunningpb.Operation)(nil), // 33: google.longrunning.Operation + (*emptypb.Empty)(nil), // 34: google.protobuf.Empty } var file_google_cloud_talent_v4beta1_job_service_proto_depIdxs = []int32{ - 21, // 0: google.cloud.talent.v4beta1.CreateJobRequest.job:type_name -> google.cloud.talent.v4beta1.Job - 21, // 1: google.cloud.talent.v4beta1.UpdateJobRequest.job:type_name -> google.cloud.talent.v4beta1.Job - 22, // 2: google.cloud.talent.v4beta1.UpdateJobRequest.update_mask:type_name -> google.protobuf.FieldMask + 22, // 0: google.cloud.talent.v4beta1.CreateJobRequest.job:type_name -> google.cloud.talent.v4beta1.Job + 22, // 1: google.cloud.talent.v4beta1.UpdateJobRequest.job:type_name -> google.cloud.talent.v4beta1.Job + 23, // 2: google.cloud.talent.v4beta1.UpdateJobRequest.update_mask:type_name -> google.protobuf.FieldMask 0, // 3: google.cloud.talent.v4beta1.ListJobsRequest.job_view:type_name -> google.cloud.talent.v4beta1.JobView - 21, // 4: google.cloud.talent.v4beta1.ListJobsResponse.jobs:type_name -> google.cloud.talent.v4beta1.Job - 23, // 5: google.cloud.talent.v4beta1.ListJobsResponse.metadata:type_name -> google.cloud.talent.v4beta1.ResponseMetadata + 22, // 4: google.cloud.talent.v4beta1.ListJobsResponse.jobs:type_name -> google.cloud.talent.v4beta1.Job + 24, // 5: google.cloud.talent.v4beta1.ListJobsResponse.metadata:type_name -> google.cloud.talent.v4beta1.ResponseMetadata 1, // 6: google.cloud.talent.v4beta1.SearchJobsRequest.search_mode:type_name -> google.cloud.talent.v4beta1.SearchJobsRequest.SearchMode - 24, // 7: google.cloud.talent.v4beta1.SearchJobsRequest.request_metadata:type_name -> google.cloud.talent.v4beta1.RequestMetadata - 25, // 8: google.cloud.talent.v4beta1.SearchJobsRequest.job_query:type_name -> google.cloud.talent.v4beta1.JobQuery - 26, // 9: google.cloud.talent.v4beta1.SearchJobsRequest.histogram_queries:type_name -> google.cloud.talent.v4beta1.HistogramQuery + 25, // 7: google.cloud.talent.v4beta1.SearchJobsRequest.request_metadata:type_name -> google.cloud.talent.v4beta1.RequestMetadata + 26, // 8: google.cloud.talent.v4beta1.SearchJobsRequest.job_query:type_name -> google.cloud.talent.v4beta1.JobQuery + 27, // 9: google.cloud.talent.v4beta1.SearchJobsRequest.histogram_queries:type_name -> google.cloud.talent.v4beta1.HistogramQuery 0, // 10: google.cloud.talent.v4beta1.SearchJobsRequest.job_view:type_name -> google.cloud.talent.v4beta1.JobView 2, // 11: google.cloud.talent.v4beta1.SearchJobsRequest.diversification_level:type_name -> google.cloud.talent.v4beta1.SearchJobsRequest.DiversificationLevel - 17, // 12: google.cloud.talent.v4beta1.SearchJobsRequest.custom_ranking_info:type_name -> google.cloud.talent.v4beta1.SearchJobsRequest.CustomRankingInfo + 18, // 12: google.cloud.talent.v4beta1.SearchJobsRequest.custom_ranking_info:type_name -> google.cloud.talent.v4beta1.SearchJobsRequest.CustomRankingInfo 3, // 13: google.cloud.talent.v4beta1.SearchJobsRequest.keyword_match_mode:type_name -> google.cloud.talent.v4beta1.SearchJobsRequest.KeywordMatchMode - 18, // 14: google.cloud.talent.v4beta1.SearchJobsResponse.matching_jobs:type_name -> google.cloud.talent.v4beta1.SearchJobsResponse.MatchingJob - 27, // 15: google.cloud.talent.v4beta1.SearchJobsResponse.histogram_query_results:type_name -> google.cloud.talent.v4beta1.HistogramQueryResult - 28, // 16: google.cloud.talent.v4beta1.SearchJobsResponse.location_filters:type_name -> google.cloud.talent.v4beta1.Location - 23, // 17: google.cloud.talent.v4beta1.SearchJobsResponse.metadata:type_name -> google.cloud.talent.v4beta1.ResponseMetadata - 29, // 18: google.cloud.talent.v4beta1.SearchJobsResponse.spell_correction:type_name -> google.cloud.talent.v4beta1.SpellingCorrection - 21, // 19: google.cloud.talent.v4beta1.BatchCreateJobsRequest.jobs:type_name -> google.cloud.talent.v4beta1.Job - 21, // 20: google.cloud.talent.v4beta1.BatchUpdateJobsRequest.jobs:type_name -> google.cloud.talent.v4beta1.Job - 22, // 21: google.cloud.talent.v4beta1.BatchUpdateJobsRequest.update_mask:type_name -> google.protobuf.FieldMask - 20, // 22: google.cloud.talent.v4beta1.JobOperationResult.job_results:type_name -> google.cloud.talent.v4beta1.JobOperationResult.JobResult - 4, // 23: google.cloud.talent.v4beta1.SearchJobsRequest.CustomRankingInfo.importance_level:type_name -> google.cloud.talent.v4beta1.SearchJobsRequest.CustomRankingInfo.ImportanceLevel - 21, // 24: google.cloud.talent.v4beta1.SearchJobsResponse.MatchingJob.job:type_name -> google.cloud.talent.v4beta1.Job - 19, // 25: google.cloud.talent.v4beta1.SearchJobsResponse.MatchingJob.commute_info:type_name -> google.cloud.talent.v4beta1.SearchJobsResponse.CommuteInfo - 28, // 26: google.cloud.talent.v4beta1.SearchJobsResponse.CommuteInfo.job_location:type_name -> google.cloud.talent.v4beta1.Location - 30, // 27: google.cloud.talent.v4beta1.SearchJobsResponse.CommuteInfo.travel_duration:type_name -> google.protobuf.Duration - 21, // 28: google.cloud.talent.v4beta1.JobOperationResult.JobResult.job:type_name -> google.cloud.talent.v4beta1.Job - 31, // 29: google.cloud.talent.v4beta1.JobOperationResult.JobResult.status:type_name -> google.rpc.Status - 5, // 30: google.cloud.talent.v4beta1.JobService.CreateJob:input_type -> google.cloud.talent.v4beta1.CreateJobRequest - 14, // 31: google.cloud.talent.v4beta1.JobService.BatchCreateJobs:input_type -> google.cloud.talent.v4beta1.BatchCreateJobsRequest - 6, // 32: google.cloud.talent.v4beta1.JobService.GetJob:input_type -> google.cloud.talent.v4beta1.GetJobRequest - 7, // 33: google.cloud.talent.v4beta1.JobService.UpdateJob:input_type -> google.cloud.talent.v4beta1.UpdateJobRequest - 15, // 34: google.cloud.talent.v4beta1.JobService.BatchUpdateJobs:input_type -> google.cloud.talent.v4beta1.BatchUpdateJobsRequest - 8, // 35: google.cloud.talent.v4beta1.JobService.DeleteJob:input_type -> google.cloud.talent.v4beta1.DeleteJobRequest - 9, // 36: google.cloud.talent.v4beta1.JobService.BatchDeleteJobs:input_type -> google.cloud.talent.v4beta1.BatchDeleteJobsRequest - 10, // 37: google.cloud.talent.v4beta1.JobService.ListJobs:input_type -> google.cloud.talent.v4beta1.ListJobsRequest - 12, // 38: google.cloud.talent.v4beta1.JobService.SearchJobs:input_type -> google.cloud.talent.v4beta1.SearchJobsRequest - 12, // 39: google.cloud.talent.v4beta1.JobService.SearchJobsForAlert:input_type -> google.cloud.talent.v4beta1.SearchJobsRequest - 21, // 40: google.cloud.talent.v4beta1.JobService.CreateJob:output_type -> google.cloud.talent.v4beta1.Job - 32, // 41: google.cloud.talent.v4beta1.JobService.BatchCreateJobs:output_type -> google.longrunning.Operation - 21, // 42: google.cloud.talent.v4beta1.JobService.GetJob:output_type -> google.cloud.talent.v4beta1.Job - 21, // 43: google.cloud.talent.v4beta1.JobService.UpdateJob:output_type -> google.cloud.talent.v4beta1.Job - 32, // 44: google.cloud.talent.v4beta1.JobService.BatchUpdateJobs:output_type -> google.longrunning.Operation - 33, // 45: google.cloud.talent.v4beta1.JobService.DeleteJob:output_type -> google.protobuf.Empty - 33, // 46: google.cloud.talent.v4beta1.JobService.BatchDeleteJobs:output_type -> google.protobuf.Empty - 11, // 47: google.cloud.talent.v4beta1.JobService.ListJobs:output_type -> google.cloud.talent.v4beta1.ListJobsResponse - 13, // 48: google.cloud.talent.v4beta1.JobService.SearchJobs:output_type -> google.cloud.talent.v4beta1.SearchJobsResponse - 13, // 49: google.cloud.talent.v4beta1.JobService.SearchJobsForAlert:output_type -> google.cloud.talent.v4beta1.SearchJobsResponse - 40, // [40:50] is the sub-list for method output_type - 30, // [30:40] is the sub-list for method input_type - 30, // [30:30] is the sub-list for extension type_name - 30, // [30:30] is the sub-list for extension extendee - 0, // [0:30] is the sub-list for field type_name + 4, // 14: google.cloud.talent.v4beta1.SearchJobsRequest.relevance_threshold:type_name -> google.cloud.talent.v4beta1.SearchJobsRequest.RelevanceThreshold + 19, // 15: google.cloud.talent.v4beta1.SearchJobsResponse.matching_jobs:type_name -> google.cloud.talent.v4beta1.SearchJobsResponse.MatchingJob + 28, // 16: google.cloud.talent.v4beta1.SearchJobsResponse.histogram_query_results:type_name -> google.cloud.talent.v4beta1.HistogramQueryResult + 29, // 17: google.cloud.talent.v4beta1.SearchJobsResponse.location_filters:type_name -> google.cloud.talent.v4beta1.Location + 24, // 18: google.cloud.talent.v4beta1.SearchJobsResponse.metadata:type_name -> google.cloud.talent.v4beta1.ResponseMetadata + 30, // 19: google.cloud.talent.v4beta1.SearchJobsResponse.spell_correction:type_name -> google.cloud.talent.v4beta1.SpellingCorrection + 22, // 20: google.cloud.talent.v4beta1.BatchCreateJobsRequest.jobs:type_name -> google.cloud.talent.v4beta1.Job + 22, // 21: google.cloud.talent.v4beta1.BatchUpdateJobsRequest.jobs:type_name -> google.cloud.talent.v4beta1.Job + 23, // 22: google.cloud.talent.v4beta1.BatchUpdateJobsRequest.update_mask:type_name -> google.protobuf.FieldMask + 21, // 23: google.cloud.talent.v4beta1.JobOperationResult.job_results:type_name -> google.cloud.talent.v4beta1.JobOperationResult.JobResult + 5, // 24: google.cloud.talent.v4beta1.SearchJobsRequest.CustomRankingInfo.importance_level:type_name -> google.cloud.talent.v4beta1.SearchJobsRequest.CustomRankingInfo.ImportanceLevel + 22, // 25: google.cloud.talent.v4beta1.SearchJobsResponse.MatchingJob.job:type_name -> google.cloud.talent.v4beta1.Job + 20, // 26: google.cloud.talent.v4beta1.SearchJobsResponse.MatchingJob.commute_info:type_name -> google.cloud.talent.v4beta1.SearchJobsResponse.CommuteInfo + 29, // 27: google.cloud.talent.v4beta1.SearchJobsResponse.CommuteInfo.job_location:type_name -> google.cloud.talent.v4beta1.Location + 31, // 28: google.cloud.talent.v4beta1.SearchJobsResponse.CommuteInfo.travel_duration:type_name -> google.protobuf.Duration + 22, // 29: google.cloud.talent.v4beta1.JobOperationResult.JobResult.job:type_name -> google.cloud.talent.v4beta1.Job + 32, // 30: google.cloud.talent.v4beta1.JobOperationResult.JobResult.status:type_name -> google.rpc.Status + 6, // 31: google.cloud.talent.v4beta1.JobService.CreateJob:input_type -> google.cloud.talent.v4beta1.CreateJobRequest + 15, // 32: google.cloud.talent.v4beta1.JobService.BatchCreateJobs:input_type -> google.cloud.talent.v4beta1.BatchCreateJobsRequest + 7, // 33: google.cloud.talent.v4beta1.JobService.GetJob:input_type -> google.cloud.talent.v4beta1.GetJobRequest + 8, // 34: google.cloud.talent.v4beta1.JobService.UpdateJob:input_type -> google.cloud.talent.v4beta1.UpdateJobRequest + 16, // 35: google.cloud.talent.v4beta1.JobService.BatchUpdateJobs:input_type -> google.cloud.talent.v4beta1.BatchUpdateJobsRequest + 9, // 36: google.cloud.talent.v4beta1.JobService.DeleteJob:input_type -> google.cloud.talent.v4beta1.DeleteJobRequest + 10, // 37: google.cloud.talent.v4beta1.JobService.BatchDeleteJobs:input_type -> google.cloud.talent.v4beta1.BatchDeleteJobsRequest + 11, // 38: google.cloud.talent.v4beta1.JobService.ListJobs:input_type -> google.cloud.talent.v4beta1.ListJobsRequest + 13, // 39: google.cloud.talent.v4beta1.JobService.SearchJobs:input_type -> google.cloud.talent.v4beta1.SearchJobsRequest + 13, // 40: google.cloud.talent.v4beta1.JobService.SearchJobsForAlert:input_type -> google.cloud.talent.v4beta1.SearchJobsRequest + 22, // 41: google.cloud.talent.v4beta1.JobService.CreateJob:output_type -> google.cloud.talent.v4beta1.Job + 33, // 42: google.cloud.talent.v4beta1.JobService.BatchCreateJobs:output_type -> google.longrunning.Operation + 22, // 43: google.cloud.talent.v4beta1.JobService.GetJob:output_type -> google.cloud.talent.v4beta1.Job + 22, // 44: google.cloud.talent.v4beta1.JobService.UpdateJob:output_type -> google.cloud.talent.v4beta1.Job + 33, // 45: google.cloud.talent.v4beta1.JobService.BatchUpdateJobs:output_type -> google.longrunning.Operation + 34, // 46: google.cloud.talent.v4beta1.JobService.DeleteJob:output_type -> google.protobuf.Empty + 34, // 47: google.cloud.talent.v4beta1.JobService.BatchDeleteJobs:output_type -> google.protobuf.Empty + 12, // 48: google.cloud.talent.v4beta1.JobService.ListJobs:output_type -> google.cloud.talent.v4beta1.ListJobsResponse + 14, // 49: google.cloud.talent.v4beta1.JobService.SearchJobs:output_type -> google.cloud.talent.v4beta1.SearchJobsResponse + 14, // 50: google.cloud.talent.v4beta1.JobService.SearchJobsForAlert:output_type -> google.cloud.talent.v4beta1.SearchJobsResponse + 41, // [41:51] is the sub-list for method output_type + 31, // [31:41] is the sub-list for method input_type + 31, // [31:31] is the sub-list for extension type_name + 31, // [31:31] is the sub-list for extension extendee + 0, // [0:31] is the sub-list for field type_name } func init() { file_google_cloud_talent_v4beta1_job_service_proto_init() } @@ -2603,7 +2696,7 @@ func file_google_cloud_talent_v4beta1_job_service_proto_init() { File: protoimpl.DescBuilder{ GoPackagePath: reflect.TypeOf(x{}).PkgPath(), RawDescriptor: file_google_cloud_talent_v4beta1_job_service_proto_rawDesc, - NumEnums: 5, + NumEnums: 6, NumMessages: 16, NumExtensions: 0, NumServices: 1, diff --git a/talent/apiv4beta1/tenant_client.go b/talent/apiv4beta1/tenant_client.go index 96c80eb618f8..f4edd4fd8a79 100755 --- a/talent/apiv4beta1/tenant_client.go +++ b/talent/apiv4beta1/tenant_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4beta1/tenant_client_example_go123_test.go b/talent/apiv4beta1/tenant_client_example_go123_test.go index 85d0977bc46f..68ee0e5d6f11 100644 --- a/talent/apiv4beta1/tenant_client_example_go123_test.go +++ b/talent/apiv4beta1/tenant_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/talent/apiv4beta1/tenant_client_example_test.go b/talent/apiv4beta1/tenant_client_example_test.go index cd78ea0f0eb2..aa9485b52e48 100644 --- a/talent/apiv4beta1/tenant_client_example_test.go +++ b/talent/apiv4beta1/tenant_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/telcoautomation/apiv1/auxiliary.go b/telcoautomation/apiv1/auxiliary.go index fa2cb4aaf69c..0f5907354dd7 100755 --- a/telcoautomation/apiv1/auxiliary.go +++ b/telcoautomation/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/telcoautomation/apiv1/auxiliary_go123.go b/telcoautomation/apiv1/auxiliary_go123.go index ae8d042d4a99..76ab2f6515e2 100755 --- a/telcoautomation/apiv1/auxiliary_go123.go +++ b/telcoautomation/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/telcoautomation/apiv1/doc.go b/telcoautomation/apiv1/doc.go index efd57878c0d8..10254357a0dc 100755 --- a/telcoautomation/apiv1/doc.go +++ b/telcoautomation/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/telcoautomation/apiv1/helpers.go b/telcoautomation/apiv1/helpers.go index cee5075c1dab..0eaaadcfe247 100755 --- a/telcoautomation/apiv1/helpers.go +++ b/telcoautomation/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/telcoautomation/apiv1/telco_automation_client.go b/telcoautomation/apiv1/telco_automation_client.go index 4b7eee06f7fe..f2e31576b4b5 100755 --- a/telcoautomation/apiv1/telco_automation_client.go +++ b/telcoautomation/apiv1/telco_automation_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/telcoautomation/apiv1/telco_automation_client_example_go123_test.go b/telcoautomation/apiv1/telco_automation_client_example_go123_test.go index 3fe197dc08f9..3a278c3f004f 100644 --- a/telcoautomation/apiv1/telco_automation_client_example_go123_test.go +++ b/telcoautomation/apiv1/telco_automation_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/telcoautomation/apiv1/telco_automation_client_example_test.go b/telcoautomation/apiv1/telco_automation_client_example_test.go index 4d40db5b4742..1be769605ec2 100644 --- a/telcoautomation/apiv1/telco_automation_client_example_test.go +++ b/telcoautomation/apiv1/telco_automation_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/texttospeech/apiv1/auxiliary.go b/texttospeech/apiv1/auxiliary.go index 86d033c92dda..abf3b013074d 100755 --- a/texttospeech/apiv1/auxiliary.go +++ b/texttospeech/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/texttospeech/apiv1/auxiliary_go123.go b/texttospeech/apiv1/auxiliary_go123.go index 9f8f83446e3e..a13c3c8b0dda 100755 --- a/texttospeech/apiv1/auxiliary_go123.go +++ b/texttospeech/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/texttospeech/apiv1/doc.go b/texttospeech/apiv1/doc.go index f451a2513a34..515e6045bbf0 100755 --- a/texttospeech/apiv1/doc.go +++ b/texttospeech/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/texttospeech/apiv1/helpers.go b/texttospeech/apiv1/helpers.go index 0d527e510052..01136e60adfe 100755 --- a/texttospeech/apiv1/helpers.go +++ b/texttospeech/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/texttospeech/apiv1/text_to_speech_client.go b/texttospeech/apiv1/text_to_speech_client.go index 7981ca28614e..a7b8a61754c0 100755 --- a/texttospeech/apiv1/text_to_speech_client.go +++ b/texttospeech/apiv1/text_to_speech_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/texttospeech/apiv1/text_to_speech_client_example_go123_test.go b/texttospeech/apiv1/text_to_speech_client_example_go123_test.go index 27a6523547fa..fc94826e3ce1 100644 --- a/texttospeech/apiv1/text_to_speech_client_example_go123_test.go +++ b/texttospeech/apiv1/text_to_speech_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/texttospeech/apiv1/text_to_speech_client_example_test.go b/texttospeech/apiv1/text_to_speech_client_example_test.go index 51311b4ff650..15185daf4abf 100644 --- a/texttospeech/apiv1/text_to_speech_client_example_test.go +++ b/texttospeech/apiv1/text_to_speech_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/texttospeech/apiv1/text_to_speech_long_audio_synthesize_client.go b/texttospeech/apiv1/text_to_speech_long_audio_synthesize_client.go index 8cd48a517509..ce15726dfb53 100755 --- a/texttospeech/apiv1/text_to_speech_long_audio_synthesize_client.go +++ b/texttospeech/apiv1/text_to_speech_long_audio_synthesize_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/texttospeech/apiv1/text_to_speech_long_audio_synthesize_client_example_go123_test.go b/texttospeech/apiv1/text_to_speech_long_audio_synthesize_client_example_go123_test.go index 1e3858fd4997..36b7dcace065 100644 --- a/texttospeech/apiv1/text_to_speech_long_audio_synthesize_client_example_go123_test.go +++ b/texttospeech/apiv1/text_to_speech_long_audio_synthesize_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/texttospeech/apiv1/text_to_speech_long_audio_synthesize_client_example_test.go b/texttospeech/apiv1/text_to_speech_long_audio_synthesize_client_example_test.go index ee48b80832c1..f77aaa2bc54c 100644 --- a/texttospeech/apiv1/text_to_speech_long_audio_synthesize_client_example_test.go +++ b/texttospeech/apiv1/text_to_speech_long_audio_synthesize_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/tpu/apiv1/auxiliary.go b/tpu/apiv1/auxiliary.go index 4c2948e0dcf4..517be1cce5f5 100755 --- a/tpu/apiv1/auxiliary.go +++ b/tpu/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/tpu/apiv1/auxiliary_go123.go b/tpu/apiv1/auxiliary_go123.go index 5524731b3fe6..25fa8db669ab 100755 --- a/tpu/apiv1/auxiliary_go123.go +++ b/tpu/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/tpu/apiv1/doc.go b/tpu/apiv1/doc.go index c7207fc2cbd4..b4e74cef4fc7 100755 --- a/tpu/apiv1/doc.go +++ b/tpu/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/tpu/apiv1/helpers.go b/tpu/apiv1/helpers.go index 5c77e487ddaa..646a9c1e759b 100755 --- a/tpu/apiv1/helpers.go +++ b/tpu/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/tpu/apiv1/tpu_client.go b/tpu/apiv1/tpu_client.go index 97bb2d91147a..738c9872d436 100755 --- a/tpu/apiv1/tpu_client.go +++ b/tpu/apiv1/tpu_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/tpu/apiv1/tpu_client_example_go123_test.go b/tpu/apiv1/tpu_client_example_go123_test.go index 3f7e1b421acf..7ec027e9b0d4 100644 --- a/tpu/apiv1/tpu_client_example_go123_test.go +++ b/tpu/apiv1/tpu_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/tpu/apiv1/tpu_client_example_test.go b/tpu/apiv1/tpu_client_example_test.go index e559b244bba5..ddea4039d2aa 100644 --- a/tpu/apiv1/tpu_client_example_test.go +++ b/tpu/apiv1/tpu_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/trace/apiv1/auxiliary.go b/trace/apiv1/auxiliary.go index f0c40c47cea3..0edc27fdc349 100755 --- a/trace/apiv1/auxiliary.go +++ b/trace/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/trace/apiv1/auxiliary_go123.go b/trace/apiv1/auxiliary_go123.go index baaab5de35dd..53beb335d18d 100755 --- a/trace/apiv1/auxiliary_go123.go +++ b/trace/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/trace/apiv1/doc.go b/trace/apiv1/doc.go index 2f7e26b740d2..232f402d1bf6 100755 --- a/trace/apiv1/doc.go +++ b/trace/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/trace/apiv1/helpers.go b/trace/apiv1/helpers.go index bb4937625b60..b31bb43f5518 100755 --- a/trace/apiv1/helpers.go +++ b/trace/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/trace/apiv1/trace_client.go b/trace/apiv1/trace_client.go index 1bd94690e65c..f1fbdead7ee4 100755 --- a/trace/apiv1/trace_client.go +++ b/trace/apiv1/trace_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/trace/apiv1/trace_client_example_go123_test.go b/trace/apiv1/trace_client_example_go123_test.go index 2b130b53ec1e..8232714ff3fc 100644 --- a/trace/apiv1/trace_client_example_go123_test.go +++ b/trace/apiv1/trace_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/trace/apiv1/trace_client_example_test.go b/trace/apiv1/trace_client_example_test.go index 11a8c0b7c143..a6b411ed20b3 100644 --- a/trace/apiv1/trace_client_example_test.go +++ b/trace/apiv1/trace_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/trace/apiv2/auxiliary.go b/trace/apiv2/auxiliary.go index 6fd60d03609c..51ec589c482c 100755 --- a/trace/apiv2/auxiliary.go +++ b/trace/apiv2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/trace/apiv2/auxiliary_go123.go b/trace/apiv2/auxiliary_go123.go index dabeb1dc3213..e0f441d653ad 100755 --- a/trace/apiv2/auxiliary_go123.go +++ b/trace/apiv2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/trace/apiv2/doc.go b/trace/apiv2/doc.go index dcb1e1cb7945..7a75dc5084a0 100755 --- a/trace/apiv2/doc.go +++ b/trace/apiv2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/trace/apiv2/helpers.go b/trace/apiv2/helpers.go index 413848b5eaf0..fc2785d2d789 100755 --- a/trace/apiv2/helpers.go +++ b/trace/apiv2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/trace/apiv2/trace_client.go b/trace/apiv2/trace_client.go index c753a8dba08a..54e9c9d2d9ca 100755 --- a/trace/apiv2/trace_client.go +++ b/trace/apiv2/trace_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/trace/apiv2/trace_client_example_go123_test.go b/trace/apiv2/trace_client_example_go123_test.go index 0cb8616d86d4..f1a04a8bf986 100644 --- a/trace/apiv2/trace_client_example_go123_test.go +++ b/trace/apiv2/trace_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/trace/apiv2/trace_client_example_test.go b/trace/apiv2/trace_client_example_test.go index 1a8b0b680d71..4e416ef46fe7 100644 --- a/trace/apiv2/trace_client_example_test.go +++ b/trace/apiv2/trace_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/translate/apiv3/auxiliary.go b/translate/apiv3/auxiliary.go index 659b05a007a8..5a23232e8382 100755 --- a/translate/apiv3/auxiliary.go +++ b/translate/apiv3/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/translate/apiv3/auxiliary_go123.go b/translate/apiv3/auxiliary_go123.go index 3d88d786cb5d..c0a79eb9e6f3 100755 --- a/translate/apiv3/auxiliary_go123.go +++ b/translate/apiv3/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/translate/apiv3/doc.go b/translate/apiv3/doc.go index ba977fea5bf0..11a4287fb093 100755 --- a/translate/apiv3/doc.go +++ b/translate/apiv3/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/translate/apiv3/helpers.go b/translate/apiv3/helpers.go index 6c9a722bd463..84a5465b0c75 100755 --- a/translate/apiv3/helpers.go +++ b/translate/apiv3/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/translate/apiv3/translation_client.go b/translate/apiv3/translation_client.go index eabdf1a741d4..3a5e1f2de01d 100755 --- a/translate/apiv3/translation_client.go +++ b/translate/apiv3/translation_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/translate/apiv3/translation_client_example_go123_test.go b/translate/apiv3/translation_client_example_go123_test.go index 0630b92e7c22..b95427aaae56 100644 --- a/translate/apiv3/translation_client_example_go123_test.go +++ b/translate/apiv3/translation_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/translate/apiv3/translation_client_example_test.go b/translate/apiv3/translation_client_example_test.go index 320c84211622..8e39aa4503f9 100644 --- a/translate/apiv3/translation_client_example_test.go +++ b/translate/apiv3/translation_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/video/livestream/apiv1/auxiliary.go b/video/livestream/apiv1/auxiliary.go index 958b50f52a8e..11880552dc1f 100755 --- a/video/livestream/apiv1/auxiliary.go +++ b/video/livestream/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/video/livestream/apiv1/auxiliary_go123.go b/video/livestream/apiv1/auxiliary_go123.go index 8e9684169f69..c193b2c78b00 100755 --- a/video/livestream/apiv1/auxiliary_go123.go +++ b/video/livestream/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/video/livestream/apiv1/doc.go b/video/livestream/apiv1/doc.go index 24b771387a86..0197f12ab822 100755 --- a/video/livestream/apiv1/doc.go +++ b/video/livestream/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/video/livestream/apiv1/helpers.go b/video/livestream/apiv1/helpers.go index 1ee62624b1bf..3cd39344e2e7 100755 --- a/video/livestream/apiv1/helpers.go +++ b/video/livestream/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/video/livestream/apiv1/livestream_client.go b/video/livestream/apiv1/livestream_client.go index c51748d44e9e..ef47e977dc8e 100755 --- a/video/livestream/apiv1/livestream_client.go +++ b/video/livestream/apiv1/livestream_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/video/livestream/apiv1/livestream_client_example_go123_test.go b/video/livestream/apiv1/livestream_client_example_go123_test.go index ea495ce534ab..4f007bbeaebe 100644 --- a/video/livestream/apiv1/livestream_client_example_go123_test.go +++ b/video/livestream/apiv1/livestream_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/video/livestream/apiv1/livestream_client_example_test.go b/video/livestream/apiv1/livestream_client_example_test.go index 2c15ffcb9017..32065ca67f1d 100644 --- a/video/livestream/apiv1/livestream_client_example_test.go +++ b/video/livestream/apiv1/livestream_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/video/stitcher/apiv1/auxiliary.go b/video/stitcher/apiv1/auxiliary.go index 60949425836f..eb989d3494cc 100755 --- a/video/stitcher/apiv1/auxiliary.go +++ b/video/stitcher/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/video/stitcher/apiv1/auxiliary_go123.go b/video/stitcher/apiv1/auxiliary_go123.go index f10e06baa22f..3cb0ad64c959 100755 --- a/video/stitcher/apiv1/auxiliary_go123.go +++ b/video/stitcher/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/video/stitcher/apiv1/doc.go b/video/stitcher/apiv1/doc.go index 8a8aca4bd771..2061232fe3e8 100755 --- a/video/stitcher/apiv1/doc.go +++ b/video/stitcher/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/video/stitcher/apiv1/helpers.go b/video/stitcher/apiv1/helpers.go index 4c7b78bb9393..282b91975a6c 100755 --- a/video/stitcher/apiv1/helpers.go +++ b/video/stitcher/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/video/stitcher/apiv1/video_stitcher_client.go b/video/stitcher/apiv1/video_stitcher_client.go index a86a8ae58d55..222ca2472894 100755 --- a/video/stitcher/apiv1/video_stitcher_client.go +++ b/video/stitcher/apiv1/video_stitcher_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/video/stitcher/apiv1/video_stitcher_client_example_go123_test.go b/video/stitcher/apiv1/video_stitcher_client_example_go123_test.go index e9c4af45488f..f1e36529b221 100644 --- a/video/stitcher/apiv1/video_stitcher_client_example_go123_test.go +++ b/video/stitcher/apiv1/video_stitcher_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/video/stitcher/apiv1/video_stitcher_client_example_test.go b/video/stitcher/apiv1/video_stitcher_client_example_test.go index 4a36e8afe1f5..33de83cf1028 100644 --- a/video/stitcher/apiv1/video_stitcher_client_example_test.go +++ b/video/stitcher/apiv1/video_stitcher_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/video/transcoder/apiv1/auxiliary.go b/video/transcoder/apiv1/auxiliary.go index 7c1f3c143eb2..f59fab46780c 100755 --- a/video/transcoder/apiv1/auxiliary.go +++ b/video/transcoder/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/video/transcoder/apiv1/auxiliary_go123.go b/video/transcoder/apiv1/auxiliary_go123.go index 568b3642eb93..31da618d26f0 100755 --- a/video/transcoder/apiv1/auxiliary_go123.go +++ b/video/transcoder/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/video/transcoder/apiv1/doc.go b/video/transcoder/apiv1/doc.go index dd9724b9535e..547f402f3f2b 100755 --- a/video/transcoder/apiv1/doc.go +++ b/video/transcoder/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/video/transcoder/apiv1/helpers.go b/video/transcoder/apiv1/helpers.go index 4fa2f47c9c3a..31a22d0ac4cf 100755 --- a/video/transcoder/apiv1/helpers.go +++ b/video/transcoder/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/video/transcoder/apiv1/transcoder_client.go b/video/transcoder/apiv1/transcoder_client.go index f69904e1deb7..a5d3b6bf19ef 100755 --- a/video/transcoder/apiv1/transcoder_client.go +++ b/video/transcoder/apiv1/transcoder_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/video/transcoder/apiv1/transcoder_client_example_go123_test.go b/video/transcoder/apiv1/transcoder_client_example_go123_test.go index 3888a03a2725..dee15d7063d9 100644 --- a/video/transcoder/apiv1/transcoder_client_example_go123_test.go +++ b/video/transcoder/apiv1/transcoder_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/video/transcoder/apiv1/transcoder_client_example_test.go b/video/transcoder/apiv1/transcoder_client_example_test.go index a45d8369cbcb..a79b6024e049 100644 --- a/video/transcoder/apiv1/transcoder_client_example_test.go +++ b/video/transcoder/apiv1/transcoder_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/videointelligence/apiv1/auxiliary.go b/videointelligence/apiv1/auxiliary.go index 3f624d166d85..87ed3440ead7 100755 --- a/videointelligence/apiv1/auxiliary.go +++ b/videointelligence/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/videointelligence/apiv1/auxiliary_go123.go b/videointelligence/apiv1/auxiliary_go123.go index 4217b2979941..302ed2deda31 100755 --- a/videointelligence/apiv1/auxiliary_go123.go +++ b/videointelligence/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/videointelligence/apiv1/doc.go b/videointelligence/apiv1/doc.go index 6f51eb97a1b4..bd730f21d0b2 100755 --- a/videointelligence/apiv1/doc.go +++ b/videointelligence/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/videointelligence/apiv1/helpers.go b/videointelligence/apiv1/helpers.go index 43eda5d19350..5d564e314ed7 100755 --- a/videointelligence/apiv1/helpers.go +++ b/videointelligence/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/videointelligence/apiv1/video_intelligence_client.go b/videointelligence/apiv1/video_intelligence_client.go index 24d23c4b788a..f11c2026c6fb 100755 --- a/videointelligence/apiv1/video_intelligence_client.go +++ b/videointelligence/apiv1/video_intelligence_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/videointelligence/apiv1/video_intelligence_client_example_go123_test.go b/videointelligence/apiv1/video_intelligence_client_example_go123_test.go index 6c460c97c543..9a9f4021d0c9 100644 --- a/videointelligence/apiv1/video_intelligence_client_example_go123_test.go +++ b/videointelligence/apiv1/video_intelligence_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/videointelligence/apiv1/video_intelligence_client_example_test.go b/videointelligence/apiv1/video_intelligence_client_example_test.go index ed07cd1f1c83..c7db9ac2cb28 100644 --- a/videointelligence/apiv1/video_intelligence_client_example_test.go +++ b/videointelligence/apiv1/video_intelligence_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/videointelligence/apiv1beta2/auxiliary.go b/videointelligence/apiv1beta2/auxiliary.go index 0169cdc37e2e..2eedcaab0d74 100755 --- a/videointelligence/apiv1beta2/auxiliary.go +++ b/videointelligence/apiv1beta2/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/videointelligence/apiv1beta2/auxiliary_go123.go b/videointelligence/apiv1beta2/auxiliary_go123.go index 4217b2979941..302ed2deda31 100755 --- a/videointelligence/apiv1beta2/auxiliary_go123.go +++ b/videointelligence/apiv1beta2/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/videointelligence/apiv1beta2/doc.go b/videointelligence/apiv1beta2/doc.go index 2a87ce64c098..ae79c9036107 100755 --- a/videointelligence/apiv1beta2/doc.go +++ b/videointelligence/apiv1beta2/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/videointelligence/apiv1beta2/helpers.go b/videointelligence/apiv1beta2/helpers.go index 43eda5d19350..5d564e314ed7 100755 --- a/videointelligence/apiv1beta2/helpers.go +++ b/videointelligence/apiv1beta2/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/videointelligence/apiv1beta2/video_intelligence_client.go b/videointelligence/apiv1beta2/video_intelligence_client.go index 7b37395f8fe4..08809a81d1be 100755 --- a/videointelligence/apiv1beta2/video_intelligence_client.go +++ b/videointelligence/apiv1beta2/video_intelligence_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/videointelligence/apiv1beta2/video_intelligence_client_example_go123_test.go b/videointelligence/apiv1beta2/video_intelligence_client_example_go123_test.go index 6c460c97c543..9a9f4021d0c9 100644 --- a/videointelligence/apiv1beta2/video_intelligence_client_example_go123_test.go +++ b/videointelligence/apiv1beta2/video_intelligence_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/videointelligence/apiv1beta2/video_intelligence_client_example_test.go b/videointelligence/apiv1beta2/video_intelligence_client_example_test.go index 65577ca8e5af..e6214dab134d 100644 --- a/videointelligence/apiv1beta2/video_intelligence_client_example_test.go +++ b/videointelligence/apiv1beta2/video_intelligence_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/videointelligence/apiv1p3beta1/auxiliary.go b/videointelligence/apiv1p3beta1/auxiliary.go index 91a3be35916f..5e7614d89c51 100755 --- a/videointelligence/apiv1p3beta1/auxiliary.go +++ b/videointelligence/apiv1p3beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/videointelligence/apiv1p3beta1/auxiliary_go123.go b/videointelligence/apiv1p3beta1/auxiliary_go123.go index 4217b2979941..302ed2deda31 100755 --- a/videointelligence/apiv1p3beta1/auxiliary_go123.go +++ b/videointelligence/apiv1p3beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/videointelligence/apiv1p3beta1/doc.go b/videointelligence/apiv1p3beta1/doc.go index 4573a6a52418..d255138ab87a 100755 --- a/videointelligence/apiv1p3beta1/doc.go +++ b/videointelligence/apiv1p3beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/videointelligence/apiv1p3beta1/helpers.go b/videointelligence/apiv1p3beta1/helpers.go index 43eda5d19350..5d564e314ed7 100755 --- a/videointelligence/apiv1p3beta1/helpers.go +++ b/videointelligence/apiv1p3beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/videointelligence/apiv1p3beta1/streaming_video_intelligence_client.go b/videointelligence/apiv1p3beta1/streaming_video_intelligence_client.go index b0b6a1f81882..4fa64376e85c 100755 --- a/videointelligence/apiv1p3beta1/streaming_video_intelligence_client.go +++ b/videointelligence/apiv1p3beta1/streaming_video_intelligence_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/videointelligence/apiv1p3beta1/streaming_video_intelligence_client_example_go123_test.go b/videointelligence/apiv1p3beta1/streaming_video_intelligence_client_example_go123_test.go index 6c460c97c543..9a9f4021d0c9 100644 --- a/videointelligence/apiv1p3beta1/streaming_video_intelligence_client_example_go123_test.go +++ b/videointelligence/apiv1p3beta1/streaming_video_intelligence_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/videointelligence/apiv1p3beta1/streaming_video_intelligence_client_example_test.go b/videointelligence/apiv1p3beta1/streaming_video_intelligence_client_example_test.go index 5fb656f4b4ba..22e20a336858 100644 --- a/videointelligence/apiv1p3beta1/streaming_video_intelligence_client_example_test.go +++ b/videointelligence/apiv1p3beta1/streaming_video_intelligence_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/videointelligence/apiv1p3beta1/video_intelligence_client.go b/videointelligence/apiv1p3beta1/video_intelligence_client.go index 41ecde8896a3..dd5d4d4149ad 100755 --- a/videointelligence/apiv1p3beta1/video_intelligence_client.go +++ b/videointelligence/apiv1p3beta1/video_intelligence_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/videointelligence/apiv1p3beta1/video_intelligence_client_example_go123_test.go b/videointelligence/apiv1p3beta1/video_intelligence_client_example_go123_test.go index 6c460c97c543..9a9f4021d0c9 100644 --- a/videointelligence/apiv1p3beta1/video_intelligence_client_example_go123_test.go +++ b/videointelligence/apiv1p3beta1/video_intelligence_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/videointelligence/apiv1p3beta1/video_intelligence_client_example_test.go b/videointelligence/apiv1p3beta1/video_intelligence_client_example_test.go index db512f226374..e068d170d3e5 100644 --- a/videointelligence/apiv1p3beta1/video_intelligence_client_example_test.go +++ b/videointelligence/apiv1p3beta1/video_intelligence_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vision/apiv1/auxiliary.go b/vision/apiv1/auxiliary.go index 546c6742793c..30d275b3db1d 100755 --- a/vision/apiv1/auxiliary.go +++ b/vision/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vision/apiv1/auxiliary_go123.go b/vision/apiv1/auxiliary_go123.go index c4980fb1a9d0..f01befb28725 100755 --- a/vision/apiv1/auxiliary_go123.go +++ b/vision/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vision/apiv1/doc.go b/vision/apiv1/doc.go index 62d1f9653974..4efc583e0f0c 100755 --- a/vision/apiv1/doc.go +++ b/vision/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vision/apiv1/helpers.go b/vision/apiv1/helpers.go index 22f53cc7fd34..863471318414 100755 --- a/vision/apiv1/helpers.go +++ b/vision/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vision/apiv1/image_annotator_client.go b/vision/apiv1/image_annotator_client.go index ffad3943bc5e..375f42b9b735 100755 --- a/vision/apiv1/image_annotator_client.go +++ b/vision/apiv1/image_annotator_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vision/apiv1/image_annotator_client_example_go123_test.go b/vision/apiv1/image_annotator_client_example_go123_test.go index e613bc7c8f4a..080558884c4e 100644 --- a/vision/apiv1/image_annotator_client_example_go123_test.go +++ b/vision/apiv1/image_annotator_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vision/apiv1/image_annotator_client_example_test.go b/vision/apiv1/image_annotator_client_example_test.go index f6df5be4697d..e87cfd92ea88 100644 --- a/vision/apiv1/image_annotator_client_example_test.go +++ b/vision/apiv1/image_annotator_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vision/apiv1/product_search_client.go b/vision/apiv1/product_search_client.go index 532ab6b87a2f..0ad03428fefd 100755 --- a/vision/apiv1/product_search_client.go +++ b/vision/apiv1/product_search_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vision/apiv1/product_search_client_example_go123_test.go b/vision/apiv1/product_search_client_example_go123_test.go index bd11a19c7d79..d5df3db59245 100644 --- a/vision/apiv1/product_search_client_example_go123_test.go +++ b/vision/apiv1/product_search_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vision/apiv1/product_search_client_example_test.go b/vision/apiv1/product_search_client_example_test.go index f5209e499abb..73b38ec2fa87 100644 --- a/vision/apiv1/product_search_client_example_test.go +++ b/vision/apiv1/product_search_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vision/apiv1p1beta1/auxiliary.go b/vision/apiv1p1beta1/auxiliary.go index 696a44e4c18d..7df200291fce 100755 --- a/vision/apiv1p1beta1/auxiliary.go +++ b/vision/apiv1p1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vision/apiv1p1beta1/auxiliary_go123.go b/vision/apiv1p1beta1/auxiliary_go123.go index 426c06326fe1..c0e33b7df56a 100755 --- a/vision/apiv1p1beta1/auxiliary_go123.go +++ b/vision/apiv1p1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vision/apiv1p1beta1/doc.go b/vision/apiv1p1beta1/doc.go index 0fb6b80fa8b4..a5ac5f3629d9 100755 --- a/vision/apiv1p1beta1/doc.go +++ b/vision/apiv1p1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vision/apiv1p1beta1/helpers.go b/vision/apiv1p1beta1/helpers.go index 22f53cc7fd34..863471318414 100755 --- a/vision/apiv1p1beta1/helpers.go +++ b/vision/apiv1p1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vision/apiv1p1beta1/image_annotator_client.go b/vision/apiv1p1beta1/image_annotator_client.go index 9de150778bd1..909a6bddbeb3 100755 --- a/vision/apiv1p1beta1/image_annotator_client.go +++ b/vision/apiv1p1beta1/image_annotator_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vision/apiv1p1beta1/image_annotator_client_example_go123_test.go b/vision/apiv1p1beta1/image_annotator_client_example_go123_test.go index e613bc7c8f4a..080558884c4e 100644 --- a/vision/apiv1p1beta1/image_annotator_client_example_go123_test.go +++ b/vision/apiv1p1beta1/image_annotator_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vision/apiv1p1beta1/image_annotator_client_example_test.go b/vision/apiv1p1beta1/image_annotator_client_example_test.go index d031af23431a..1efbd35439f2 100644 --- a/vision/apiv1p1beta1/image_annotator_client_example_test.go +++ b/vision/apiv1p1beta1/image_annotator_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/visionai/apiv1/app_platform_client.go b/visionai/apiv1/app_platform_client.go index 7e9320b51bd5..cca92a6316d5 100755 --- a/visionai/apiv1/app_platform_client.go +++ b/visionai/apiv1/app_platform_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/visionai/apiv1/app_platform_client_example_go123_test.go b/visionai/apiv1/app_platform_client_example_go123_test.go index b7752d69607e..fe5a0cfd0234 100644 --- a/visionai/apiv1/app_platform_client_example_go123_test.go +++ b/visionai/apiv1/app_platform_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/visionai/apiv1/app_platform_client_example_test.go b/visionai/apiv1/app_platform_client_example_test.go index b2e5275afe68..d72b14d0e983 100644 --- a/visionai/apiv1/app_platform_client_example_test.go +++ b/visionai/apiv1/app_platform_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/visionai/apiv1/auxiliary.go b/visionai/apiv1/auxiliary.go index babeb832a875..25a691b9a0a4 100755 --- a/visionai/apiv1/auxiliary.go +++ b/visionai/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/visionai/apiv1/auxiliary_go123.go b/visionai/apiv1/auxiliary_go123.go index c3cd99cf9140..dc557df9219e 100755 --- a/visionai/apiv1/auxiliary_go123.go +++ b/visionai/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/visionai/apiv1/doc.go b/visionai/apiv1/doc.go index cd3e12a947d8..63d6b7d97997 100755 --- a/visionai/apiv1/doc.go +++ b/visionai/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/visionai/apiv1/health_check_client.go b/visionai/apiv1/health_check_client.go index 436e30c46953..5327aed40a86 100755 --- a/visionai/apiv1/health_check_client.go +++ b/visionai/apiv1/health_check_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/visionai/apiv1/health_check_client_example_go123_test.go b/visionai/apiv1/health_check_client_example_go123_test.go index 2746244cd0ba..7b4e0a20ff56 100644 --- a/visionai/apiv1/health_check_client_example_go123_test.go +++ b/visionai/apiv1/health_check_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/visionai/apiv1/health_check_client_example_test.go b/visionai/apiv1/health_check_client_example_test.go index 9b948dae9139..dc8979c18176 100644 --- a/visionai/apiv1/health_check_client_example_test.go +++ b/visionai/apiv1/health_check_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/visionai/apiv1/helpers.go b/visionai/apiv1/helpers.go index 4d88f60bc7f9..220cf8b9c0c1 100755 --- a/visionai/apiv1/helpers.go +++ b/visionai/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/visionai/apiv1/live_video_analytics_client.go b/visionai/apiv1/live_video_analytics_client.go index 6023bac1d3cd..7d672d9662ce 100755 --- a/visionai/apiv1/live_video_analytics_client.go +++ b/visionai/apiv1/live_video_analytics_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/visionai/apiv1/live_video_analytics_client_example_go123_test.go b/visionai/apiv1/live_video_analytics_client_example_go123_test.go index 70458852dd11..3c8ca183968b 100644 --- a/visionai/apiv1/live_video_analytics_client_example_go123_test.go +++ b/visionai/apiv1/live_video_analytics_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/visionai/apiv1/live_video_analytics_client_example_test.go b/visionai/apiv1/live_video_analytics_client_example_test.go index e89a579ba35b..2abe5623bf65 100644 --- a/visionai/apiv1/live_video_analytics_client_example_test.go +++ b/visionai/apiv1/live_video_analytics_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/visionai/apiv1/streaming_client.go b/visionai/apiv1/streaming_client.go index 25e7ad30a637..3a2bd7162f5d 100755 --- a/visionai/apiv1/streaming_client.go +++ b/visionai/apiv1/streaming_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/visionai/apiv1/streaming_client_example_go123_test.go b/visionai/apiv1/streaming_client_example_go123_test.go index 83f2b5126610..0ddf15367919 100644 --- a/visionai/apiv1/streaming_client_example_go123_test.go +++ b/visionai/apiv1/streaming_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/visionai/apiv1/streaming_client_example_test.go b/visionai/apiv1/streaming_client_example_test.go index 3346458892e9..48d6ae48b106 100644 --- a/visionai/apiv1/streaming_client_example_test.go +++ b/visionai/apiv1/streaming_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/visionai/apiv1/streams_client.go b/visionai/apiv1/streams_client.go index 48b4c0c39398..2a6ce463d1a2 100755 --- a/visionai/apiv1/streams_client.go +++ b/visionai/apiv1/streams_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/visionai/apiv1/streams_client_example_go123_test.go b/visionai/apiv1/streams_client_example_go123_test.go index a655106e2f96..445e1155562c 100644 --- a/visionai/apiv1/streams_client_example_go123_test.go +++ b/visionai/apiv1/streams_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/visionai/apiv1/streams_client_example_test.go b/visionai/apiv1/streams_client_example_test.go index b11ccdfa0f56..66c0302827db 100644 --- a/visionai/apiv1/streams_client_example_test.go +++ b/visionai/apiv1/streams_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/visionai/apiv1/warehouse_client.go b/visionai/apiv1/warehouse_client.go index 28c4bfcc3354..4ab223aef754 100755 --- a/visionai/apiv1/warehouse_client.go +++ b/visionai/apiv1/warehouse_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/visionai/apiv1/warehouse_client_example_go123_test.go b/visionai/apiv1/warehouse_client_example_go123_test.go index 430d2420465c..d8159a70ca3f 100644 --- a/visionai/apiv1/warehouse_client_example_go123_test.go +++ b/visionai/apiv1/warehouse_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/visionai/apiv1/warehouse_client_example_test.go b/visionai/apiv1/warehouse_client_example_test.go index 038d90cdf2d2..236a55436d3b 100644 --- a/visionai/apiv1/warehouse_client_example_test.go +++ b/visionai/apiv1/warehouse_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vmmigration/apiv1/auxiliary.go b/vmmigration/apiv1/auxiliary.go index 63a2217112e1..4216d68662f8 100755 --- a/vmmigration/apiv1/auxiliary.go +++ b/vmmigration/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vmmigration/apiv1/auxiliary_go123.go b/vmmigration/apiv1/auxiliary_go123.go index 6cd9c2e3ec00..3b016dabc35c 100755 --- a/vmmigration/apiv1/auxiliary_go123.go +++ b/vmmigration/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vmmigration/apiv1/doc.go b/vmmigration/apiv1/doc.go index 574588416540..c29fb626a0e4 100755 --- a/vmmigration/apiv1/doc.go +++ b/vmmigration/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vmmigration/apiv1/helpers.go b/vmmigration/apiv1/helpers.go index 8aaf981e44cf..1d1eddd56fca 100755 --- a/vmmigration/apiv1/helpers.go +++ b/vmmigration/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vmmigration/apiv1/vm_migration_client.go b/vmmigration/apiv1/vm_migration_client.go index f125327c5df6..81627c79da46 100755 --- a/vmmigration/apiv1/vm_migration_client.go +++ b/vmmigration/apiv1/vm_migration_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vmmigration/apiv1/vm_migration_client_example_go123_test.go b/vmmigration/apiv1/vm_migration_client_example_go123_test.go index cc7a38653b77..1cc073b2c368 100644 --- a/vmmigration/apiv1/vm_migration_client_example_go123_test.go +++ b/vmmigration/apiv1/vm_migration_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vmmigration/apiv1/vm_migration_client_example_test.go b/vmmigration/apiv1/vm_migration_client_example_test.go index 028edbafd9b8..47daaf03c0f8 100644 --- a/vmmigration/apiv1/vm_migration_client_example_test.go +++ b/vmmigration/apiv1/vm_migration_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vmwareengine/apiv1/auxiliary.go b/vmwareengine/apiv1/auxiliary.go index 0b0cee4b195c..85a6cb25d70a 100755 --- a/vmwareengine/apiv1/auxiliary.go +++ b/vmwareengine/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vmwareengine/apiv1/auxiliary_go123.go b/vmwareengine/apiv1/auxiliary_go123.go index c569303dc72e..68866e18f6dd 100755 --- a/vmwareengine/apiv1/auxiliary_go123.go +++ b/vmwareengine/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vmwareengine/apiv1/doc.go b/vmwareengine/apiv1/doc.go index dddeb0db3e48..22a7060bcc44 100755 --- a/vmwareengine/apiv1/doc.go +++ b/vmwareengine/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vmwareengine/apiv1/helpers.go b/vmwareengine/apiv1/helpers.go index b2fdf517d8a7..d52e05da8849 100755 --- a/vmwareengine/apiv1/helpers.go +++ b/vmwareengine/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vmwareengine/apiv1/vmware_engine_client.go b/vmwareengine/apiv1/vmware_engine_client.go index 4d4e87e9086d..624923af589d 100755 --- a/vmwareengine/apiv1/vmware_engine_client.go +++ b/vmwareengine/apiv1/vmware_engine_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vmwareengine/apiv1/vmware_engine_client_example_go123_test.go b/vmwareengine/apiv1/vmware_engine_client_example_go123_test.go index b04f67d18599..1e1a0c98cc68 100644 --- a/vmwareengine/apiv1/vmware_engine_client_example_go123_test.go +++ b/vmwareengine/apiv1/vmware_engine_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vmwareengine/apiv1/vmware_engine_client_example_test.go b/vmwareengine/apiv1/vmware_engine_client_example_test.go index 5b422f06c959..6bb045b15feb 100644 --- a/vmwareengine/apiv1/vmware_engine_client_example_test.go +++ b/vmwareengine/apiv1/vmware_engine_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vpcaccess/apiv1/auxiliary.go b/vpcaccess/apiv1/auxiliary.go index 4acc4ae3ce17..c6869a4b3490 100755 --- a/vpcaccess/apiv1/auxiliary.go +++ b/vpcaccess/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vpcaccess/apiv1/auxiliary_go123.go b/vpcaccess/apiv1/auxiliary_go123.go index f467df332a89..d501252a67d9 100755 --- a/vpcaccess/apiv1/auxiliary_go123.go +++ b/vpcaccess/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vpcaccess/apiv1/doc.go b/vpcaccess/apiv1/doc.go index 5d541b88e424..b88543670340 100755 --- a/vpcaccess/apiv1/doc.go +++ b/vpcaccess/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vpcaccess/apiv1/helpers.go b/vpcaccess/apiv1/helpers.go index 6bc551f7ab8b..0009d7a2310c 100755 --- a/vpcaccess/apiv1/helpers.go +++ b/vpcaccess/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vpcaccess/apiv1/vpc_access_client.go b/vpcaccess/apiv1/vpc_access_client.go index ec3907259505..9fc5f980c945 100755 --- a/vpcaccess/apiv1/vpc_access_client.go +++ b/vpcaccess/apiv1/vpc_access_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vpcaccess/apiv1/vpc_access_client_example_go123_test.go b/vpcaccess/apiv1/vpc_access_client_example_go123_test.go index d968a1f8f2ea..0db6e4c06ac0 100644 --- a/vpcaccess/apiv1/vpc_access_client_example_go123_test.go +++ b/vpcaccess/apiv1/vpc_access_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/vpcaccess/apiv1/vpc_access_client_example_test.go b/vpcaccess/apiv1/vpc_access_client_example_test.go index d8c6aaeabf66..8071cb8591d0 100644 --- a/vpcaccess/apiv1/vpc_access_client_example_test.go +++ b/vpcaccess/apiv1/vpc_access_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/webrisk/apiv1/auxiliary.go b/webrisk/apiv1/auxiliary.go index a3152595ffbe..16d69022cedf 100755 --- a/webrisk/apiv1/auxiliary.go +++ b/webrisk/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/webrisk/apiv1/auxiliary_go123.go b/webrisk/apiv1/auxiliary_go123.go index 72637d773467..3a6e3d6da552 100755 --- a/webrisk/apiv1/auxiliary_go123.go +++ b/webrisk/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/webrisk/apiv1/doc.go b/webrisk/apiv1/doc.go index f844e165dac9..c6881174c9bb 100755 --- a/webrisk/apiv1/doc.go +++ b/webrisk/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/webrisk/apiv1/helpers.go b/webrisk/apiv1/helpers.go index 9470bc847f0b..a95acb630644 100755 --- a/webrisk/apiv1/helpers.go +++ b/webrisk/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/webrisk/apiv1/web_risk_client.go b/webrisk/apiv1/web_risk_client.go index e7c6770de470..c4fc8d7b3fdc 100755 --- a/webrisk/apiv1/web_risk_client.go +++ b/webrisk/apiv1/web_risk_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/webrisk/apiv1/web_risk_client_example_go123_test.go b/webrisk/apiv1/web_risk_client_example_go123_test.go index 3f491a22bde0..715425a82ac0 100644 --- a/webrisk/apiv1/web_risk_client_example_go123_test.go +++ b/webrisk/apiv1/web_risk_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/webrisk/apiv1/web_risk_client_example_test.go b/webrisk/apiv1/web_risk_client_example_test.go index 95dc69d7f872..47bd7ce7cb86 100644 --- a/webrisk/apiv1/web_risk_client_example_test.go +++ b/webrisk/apiv1/web_risk_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/webrisk/apiv1beta1/auxiliary.go b/webrisk/apiv1beta1/auxiliary.go index 3f1b9c23981d..3f7b424be735 100755 --- a/webrisk/apiv1beta1/auxiliary.go +++ b/webrisk/apiv1beta1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/webrisk/apiv1beta1/auxiliary_go123.go b/webrisk/apiv1beta1/auxiliary_go123.go index ec10fa7fb27c..5d6229c8c6cd 100755 --- a/webrisk/apiv1beta1/auxiliary_go123.go +++ b/webrisk/apiv1beta1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/webrisk/apiv1beta1/doc.go b/webrisk/apiv1beta1/doc.go index f305a9e8e334..deaf3e24d5cc 100755 --- a/webrisk/apiv1beta1/doc.go +++ b/webrisk/apiv1beta1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/webrisk/apiv1beta1/helpers.go b/webrisk/apiv1beta1/helpers.go index 9470bc847f0b..a95acb630644 100755 --- a/webrisk/apiv1beta1/helpers.go +++ b/webrisk/apiv1beta1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/webrisk/apiv1beta1/web_risk_service_v1_beta1_client.go b/webrisk/apiv1beta1/web_risk_service_v1_beta1_client.go index ef218e664325..d6bf54479989 100755 --- a/webrisk/apiv1beta1/web_risk_service_v1_beta1_client.go +++ b/webrisk/apiv1beta1/web_risk_service_v1_beta1_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/webrisk/apiv1beta1/web_risk_service_v1_beta1_client_example_go123_test.go b/webrisk/apiv1beta1/web_risk_service_v1_beta1_client_example_go123_test.go index 70e81e17b998..8b45ebb06724 100644 --- a/webrisk/apiv1beta1/web_risk_service_v1_beta1_client_example_go123_test.go +++ b/webrisk/apiv1beta1/web_risk_service_v1_beta1_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/webrisk/apiv1beta1/web_risk_service_v1_beta1_client_example_test.go b/webrisk/apiv1beta1/web_risk_service_v1_beta1_client_example_test.go index 712cbf90ecd7..675a4bf99b5c 100644 --- a/webrisk/apiv1beta1/web_risk_service_v1_beta1_client_example_test.go +++ b/webrisk/apiv1beta1/web_risk_service_v1_beta1_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/websecurityscanner/apiv1/auxiliary.go b/websecurityscanner/apiv1/auxiliary.go index 578ae35ff3c8..35524d4a2f83 100755 --- a/websecurityscanner/apiv1/auxiliary.go +++ b/websecurityscanner/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/websecurityscanner/apiv1/auxiliary_go123.go b/websecurityscanner/apiv1/auxiliary_go123.go index c2aebf7da530..42d7447e7491 100755 --- a/websecurityscanner/apiv1/auxiliary_go123.go +++ b/websecurityscanner/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/websecurityscanner/apiv1/doc.go b/websecurityscanner/apiv1/doc.go index ef57849648a2..9ea6eb57cb19 100755 --- a/websecurityscanner/apiv1/doc.go +++ b/websecurityscanner/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/websecurityscanner/apiv1/helpers.go b/websecurityscanner/apiv1/helpers.go index 252ef6f2f5ab..1ab1c672985e 100755 --- a/websecurityscanner/apiv1/helpers.go +++ b/websecurityscanner/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/websecurityscanner/apiv1/web_security_scanner_client.go b/websecurityscanner/apiv1/web_security_scanner_client.go index 4c0186e55a91..dd806cf27c18 100755 --- a/websecurityscanner/apiv1/web_security_scanner_client.go +++ b/websecurityscanner/apiv1/web_security_scanner_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/websecurityscanner/apiv1/web_security_scanner_client_example_go123_test.go b/websecurityscanner/apiv1/web_security_scanner_client_example_go123_test.go index 2dc6def9c1d7..c51dcf116db4 100644 --- a/websecurityscanner/apiv1/web_security_scanner_client_example_go123_test.go +++ b/websecurityscanner/apiv1/web_security_scanner_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/websecurityscanner/apiv1/web_security_scanner_client_example_test.go b/websecurityscanner/apiv1/web_security_scanner_client_example_test.go index bd458de18dbc..e62eaa42ade0 100644 --- a/websecurityscanner/apiv1/web_security_scanner_client_example_test.go +++ b/websecurityscanner/apiv1/web_security_scanner_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workflows/apiv1/auxiliary.go b/workflows/apiv1/auxiliary.go index c740097bd38c..9d5ddc5fee7c 100755 --- a/workflows/apiv1/auxiliary.go +++ b/workflows/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workflows/apiv1/auxiliary_go123.go b/workflows/apiv1/auxiliary_go123.go index aa55a48fe433..e26e1c867651 100755 --- a/workflows/apiv1/auxiliary_go123.go +++ b/workflows/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workflows/apiv1/doc.go b/workflows/apiv1/doc.go index 3f0f0dde3d2d..e8a1b52edee3 100755 --- a/workflows/apiv1/doc.go +++ b/workflows/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workflows/apiv1/helpers.go b/workflows/apiv1/helpers.go index 35a8846f05a7..50e10d018d57 100755 --- a/workflows/apiv1/helpers.go +++ b/workflows/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workflows/apiv1/workflows_client.go b/workflows/apiv1/workflows_client.go index 26cd9d0b6520..8cccf026b58d 100755 --- a/workflows/apiv1/workflows_client.go +++ b/workflows/apiv1/workflows_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workflows/apiv1/workflows_client_example_go123_test.go b/workflows/apiv1/workflows_client_example_go123_test.go index d2fc064cbd95..00efa09e64b0 100644 --- a/workflows/apiv1/workflows_client_example_go123_test.go +++ b/workflows/apiv1/workflows_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workflows/apiv1/workflows_client_example_test.go b/workflows/apiv1/workflows_client_example_test.go index 85d145908f9d..e5357fb3988a 100644 --- a/workflows/apiv1/workflows_client_example_test.go +++ b/workflows/apiv1/workflows_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workflows/apiv1beta/auxiliary.go b/workflows/apiv1beta/auxiliary.go index 9988893525e6..4a992cf909f8 100755 --- a/workflows/apiv1beta/auxiliary.go +++ b/workflows/apiv1beta/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workflows/apiv1beta/auxiliary_go123.go b/workflows/apiv1beta/auxiliary_go123.go index 10630bde3c19..ee4d0076b605 100755 --- a/workflows/apiv1beta/auxiliary_go123.go +++ b/workflows/apiv1beta/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workflows/apiv1beta/doc.go b/workflows/apiv1beta/doc.go index 05a432024860..9cf598017807 100755 --- a/workflows/apiv1beta/doc.go +++ b/workflows/apiv1beta/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workflows/apiv1beta/helpers.go b/workflows/apiv1beta/helpers.go index 35a8846f05a7..50e10d018d57 100755 --- a/workflows/apiv1beta/helpers.go +++ b/workflows/apiv1beta/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workflows/apiv1beta/workflows_client.go b/workflows/apiv1beta/workflows_client.go index d7ede3549970..ed41c0733391 100755 --- a/workflows/apiv1beta/workflows_client.go +++ b/workflows/apiv1beta/workflows_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workflows/apiv1beta/workflows_client_example_go123_test.go b/workflows/apiv1beta/workflows_client_example_go123_test.go index 49ff47a8090b..0b098a2d17bd 100644 --- a/workflows/apiv1beta/workflows_client_example_go123_test.go +++ b/workflows/apiv1beta/workflows_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workflows/apiv1beta/workflows_client_example_test.go b/workflows/apiv1beta/workflows_client_example_test.go index 3420fb04e339..e864bb454161 100644 --- a/workflows/apiv1beta/workflows_client_example_test.go +++ b/workflows/apiv1beta/workflows_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workflows/executions/apiv1/auxiliary.go b/workflows/executions/apiv1/auxiliary.go index f1c0418d2390..5701be22affc 100755 --- a/workflows/executions/apiv1/auxiliary.go +++ b/workflows/executions/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workflows/executions/apiv1/auxiliary_go123.go b/workflows/executions/apiv1/auxiliary_go123.go index bfb9d5ed33f3..a6868ae7083e 100755 --- a/workflows/executions/apiv1/auxiliary_go123.go +++ b/workflows/executions/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workflows/executions/apiv1/doc.go b/workflows/executions/apiv1/doc.go index 576f5aaae0ec..844d0ed0aae6 100755 --- a/workflows/executions/apiv1/doc.go +++ b/workflows/executions/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workflows/executions/apiv1/executions_client.go b/workflows/executions/apiv1/executions_client.go index 97face3895b7..b6e0c4534381 100755 --- a/workflows/executions/apiv1/executions_client.go +++ b/workflows/executions/apiv1/executions_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workflows/executions/apiv1/executions_client_example_go123_test.go b/workflows/executions/apiv1/executions_client_example_go123_test.go index 482badf88368..357c2d3c2616 100644 --- a/workflows/executions/apiv1/executions_client_example_go123_test.go +++ b/workflows/executions/apiv1/executions_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workflows/executions/apiv1/executions_client_example_test.go b/workflows/executions/apiv1/executions_client_example_test.go index b083edcb4186..2307ba8447f4 100644 --- a/workflows/executions/apiv1/executions_client_example_test.go +++ b/workflows/executions/apiv1/executions_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workflows/executions/apiv1/helpers.go b/workflows/executions/apiv1/helpers.go index ef9c6b9ac92b..3beaa8c75bb4 100755 --- a/workflows/executions/apiv1/helpers.go +++ b/workflows/executions/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workflows/executions/apiv1beta/auxiliary.go b/workflows/executions/apiv1beta/auxiliary.go index d2030647c29e..4cd14d47ae41 100755 --- a/workflows/executions/apiv1beta/auxiliary.go +++ b/workflows/executions/apiv1beta/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workflows/executions/apiv1beta/auxiliary_go123.go b/workflows/executions/apiv1beta/auxiliary_go123.go index afa2f6dbc6e6..9ed8853fa018 100755 --- a/workflows/executions/apiv1beta/auxiliary_go123.go +++ b/workflows/executions/apiv1beta/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workflows/executions/apiv1beta/doc.go b/workflows/executions/apiv1beta/doc.go index dc442db9ed36..ac6f2f7606c3 100755 --- a/workflows/executions/apiv1beta/doc.go +++ b/workflows/executions/apiv1beta/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workflows/executions/apiv1beta/executions_client.go b/workflows/executions/apiv1beta/executions_client.go index 4ceebf560ae5..af15ff2b9194 100755 --- a/workflows/executions/apiv1beta/executions_client.go +++ b/workflows/executions/apiv1beta/executions_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workflows/executions/apiv1beta/executions_client_example_go123_test.go b/workflows/executions/apiv1beta/executions_client_example_go123_test.go index d02960e2adf5..e813df9c38cd 100644 --- a/workflows/executions/apiv1beta/executions_client_example_go123_test.go +++ b/workflows/executions/apiv1beta/executions_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workflows/executions/apiv1beta/executions_client_example_test.go b/workflows/executions/apiv1beta/executions_client_example_test.go index be89a4d9451e..763c2d5d3fbc 100644 --- a/workflows/executions/apiv1beta/executions_client_example_test.go +++ b/workflows/executions/apiv1beta/executions_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workflows/executions/apiv1beta/helpers.go b/workflows/executions/apiv1beta/helpers.go index dc7cd37b62c9..e9d2a2742a2a 100755 --- a/workflows/executions/apiv1beta/helpers.go +++ b/workflows/executions/apiv1beta/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workstations/apiv1/auxiliary.go b/workstations/apiv1/auxiliary.go index 4aa48fc014da..673d6383c3e7 100755 --- a/workstations/apiv1/auxiliary.go +++ b/workstations/apiv1/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workstations/apiv1/auxiliary_go123.go b/workstations/apiv1/auxiliary_go123.go index 84e689b1bbac..258f4fcd9778 100755 --- a/workstations/apiv1/auxiliary_go123.go +++ b/workstations/apiv1/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workstations/apiv1/doc.go b/workstations/apiv1/doc.go index e80fee9a86a3..67660a0593e3 100755 --- a/workstations/apiv1/doc.go +++ b/workstations/apiv1/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workstations/apiv1/helpers.go b/workstations/apiv1/helpers.go index 06b3ac681580..ee3630918fdd 100755 --- a/workstations/apiv1/helpers.go +++ b/workstations/apiv1/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workstations/apiv1/workstations_client.go b/workstations/apiv1/workstations_client.go index e76fe52b13c9..b04274fc5a7b 100755 --- a/workstations/apiv1/workstations_client.go +++ b/workstations/apiv1/workstations_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workstations/apiv1/workstations_client_example_go123_test.go b/workstations/apiv1/workstations_client_example_go123_test.go index 82f52dbb5489..6935c717a840 100644 --- a/workstations/apiv1/workstations_client_example_go123_test.go +++ b/workstations/apiv1/workstations_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workstations/apiv1/workstations_client_example_test.go b/workstations/apiv1/workstations_client_example_test.go index 7674ee4cd90e..503a24f2b37a 100644 --- a/workstations/apiv1/workstations_client_example_test.go +++ b/workstations/apiv1/workstations_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workstations/apiv1beta/auxiliary.go b/workstations/apiv1beta/auxiliary.go index 421a93a1bc78..cce20a2511c3 100755 --- a/workstations/apiv1beta/auxiliary.go +++ b/workstations/apiv1beta/auxiliary.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workstations/apiv1beta/auxiliary_go123.go b/workstations/apiv1beta/auxiliary_go123.go index 9d3bfcf857cd..4f1d7eecd2e0 100755 --- a/workstations/apiv1beta/auxiliary_go123.go +++ b/workstations/apiv1beta/auxiliary_go123.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workstations/apiv1beta/doc.go b/workstations/apiv1beta/doc.go index c7b4804928cd..2dc5124fb602 100755 --- a/workstations/apiv1beta/doc.go +++ b/workstations/apiv1beta/doc.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workstations/apiv1beta/helpers.go b/workstations/apiv1beta/helpers.go index 06b3ac681580..ee3630918fdd 100755 --- a/workstations/apiv1beta/helpers.go +++ b/workstations/apiv1beta/helpers.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workstations/apiv1beta/workstations_client.go b/workstations/apiv1beta/workstations_client.go index 0e9368aad785..982e915f7277 100755 --- a/workstations/apiv1beta/workstations_client.go +++ b/workstations/apiv1beta/workstations_client.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workstations/apiv1beta/workstations_client_example_go123_test.go b/workstations/apiv1beta/workstations_client_example_go123_test.go index b7cb8250a371..1fccdea346c9 100644 --- a/workstations/apiv1beta/workstations_client_example_go123_test.go +++ b/workstations/apiv1beta/workstations_client_example_go123_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. diff --git a/workstations/apiv1beta/workstations_client_example_test.go b/workstations/apiv1beta/workstations_client_example_test.go index cb07e9c03934..60ccea2177ea 100644 --- a/workstations/apiv1beta/workstations_client_example_test.go +++ b/workstations/apiv1beta/workstations_client_example_test.go @@ -1,4 +1,4 @@ -// Copyright 2024 Google LLC +// Copyright 2025 Google LLC // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. From 5ebdb1dfe891946793c51a314979a19a520a5f90 Mon Sep 17 00:00:00 2001 From: "release-please[bot]" <55107282+release-please[bot]@users.noreply.github.com> Date: Thu, 2 Jan 2025 20:17:43 -0500 Subject: [PATCH 16/16] chore(main): release bigtable 1.34.0 (#10918) Co-authored-by: release-please[bot] <55107282+release-please[bot]@users.noreply.github.com> --- .release-please-manifest-individual.json | 2 +- bigtable/CHANGES.md | 25 +++++++++++++++++++++++- bigtable/internal/version.go | 2 +- 3 files changed, 26 insertions(+), 3 deletions(-) diff --git a/.release-please-manifest-individual.json b/.release-please-manifest-individual.json index c92075d20bc9..8e1d144959b8 100644 --- a/.release-please-manifest-individual.json +++ b/.release-please-manifest-individual.json @@ -2,7 +2,7 @@ "auth": "0.13.0", "auth/oauth2adapt": "0.2.6", "bigquery": "1.65.0", - "bigtable": "1.33.0", + "bigtable": "1.34.0", "datastore": "1.20.0", "errorreporting": "0.3.2", "firestore": "1.18.0", diff --git a/bigtable/CHANGES.md b/bigtable/CHANGES.md index 9e8135306f30..f66ddcd06361 100644 --- a/bigtable/CHANGES.md +++ b/bigtable/CHANGES.md @@ -1,5 +1,29 @@ # Changes +## [1.34.0](https://github.com/googleapis/google-cloud-go/compare/bigtable/v1.33.0...bigtable/v1.34.0) (2025-01-02) + + +### Features + +* **bigtable/admin:** Add support for Cloud Bigtable Node Scaling Factor for CBT Clusters ([7250d71](https://github.com/googleapis/google-cloud-go/commit/7250d714a638dcd5df3fbe0e91c5f1250c3f80f9)) +* **bigtable:** Add feature flags proto for Direct Access ([2c83297](https://github.com/googleapis/google-cloud-go/commit/2c83297a569117b0252b5b2edaecb09e4924d979)) +* **bigtable:** Async refresh dry run in parallel with sync refresh ([#11066](https://github.com/googleapis/google-cloud-go/issues/11066)) ([169e309](https://github.com/googleapis/google-cloud-go/commit/169e3096150599899788169368f96ce4470e5599)) + + +### Bug Fixes + +* **bigtable:** Correct the 'method' label value ([#11350](https://github.com/googleapis/google-cloud-go/issues/11350)) ([6aa27dc](https://github.com/googleapis/google-cloud-go/commit/6aa27dc79046df09e34e93044dbfe47cb3e9aa54)) +* **bigtable:** Resolve discrepancy between server and client qps ([#11224](https://github.com/googleapis/google-cloud-go/issues/11224)) ([c500179](https://github.com/googleapis/google-cloud-go/commit/c500179e771ac45ca3c2f5f7939444c8f65eafd3)) +* **bigtable:** Update golang.org/x/net to v0.33.0 ([e9b0b69](https://github.com/googleapis/google-cloud-go/commit/e9b0b69644ea5b276cacff0a707e8a5e87efafc9)) +* **bigtable:** Update google.golang.org/api to v0.203.0 ([8bb87d5](https://github.com/googleapis/google-cloud-go/commit/8bb87d56af1cba736e0fe243979723e747e5e11e)) +* **bigtable:** WARNING: On approximately Dec 1, 2024, an update to Protobuf will change service registration function signatures to use an interface instead of a concrete type in generated .pb.go files. This change is expected to affect very few if any users of this client library. For more information, see https://togithub.com/googleapis/google-cloud-go/issues/11020. ([8bb87d5](https://github.com/googleapis/google-cloud-go/commit/8bb87d56af1cba736e0fe243979723e747e5e11e)) + + +### Documentation + +* **bigtable:** Add todos ([#11280](https://github.com/googleapis/google-cloud-go/issues/11280)) ([d4f2449](https://github.com/googleapis/google-cloud-go/commit/d4f2449c5c2192b49de2bb42c7027beffb7517a2)) +* **bigtable:** Adding shut down log ([#11293](https://github.com/googleapis/google-cloud-go/issues/11293)) ([6cf33a8](https://github.com/googleapis/google-cloud-go/commit/6cf33a8d5605f37c1666de2c4e49554ec8fcc1a1)) + ## [1.33.0](https://github.com/googleapis/google-cloud-go/compare/bigtable/v1.32.0...bigtable/v1.33.0) (2024-09-23) @@ -420,4 +444,3 @@ This is the first tag to carve out bigtable as its own module. See: https://github.com/golang/go/wiki/Modules#is-it-possible-to-add-a-module-to-a-multi-module-repository. - diff --git a/bigtable/internal/version.go b/bigtable/internal/version.go index ba70a43673b7..a018e6275b14 100644 --- a/bigtable/internal/version.go +++ b/bigtable/internal/version.go @@ -15,4 +15,4 @@ package internal // Version is the current tagged release of the library. -const Version = "1.33.0" +const Version = "1.34.0"